You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@arrow.apache.org by gi...@apache.org on 2024/02/21 18:25:05 UTC

(arrow-rs) branch asf-site updated: deploy: ef63fb9faf27d0948429fdd77eb8873d75cdcbae

This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch asf-site
in repository https://gitbox.apache.org/repos/asf/arrow-rs.git


The following commit(s) were added to refs/heads/asf-site by this push:
     new 73e496542ba deploy: ef63fb9faf27d0948429fdd77eb8873d75cdcbae
73e496542ba is described below

commit 73e496542ba3a81c6cce39df232d032ec8f2385f
Author: tustvold <tu...@users.noreply.github.com>
AuthorDate: Wed Feb 21 18:24:55 2024 +0000

    deploy: ef63fb9faf27d0948429fdd77eb8873d75cdcbae
---
 arrow/all.html                                     |   2 +-
 arrow/alloc/constant.ALIGNMENT.html                |   4 +-
 arrow/alloc/index.html                             |   4 +-
 arrow/alloc/trait.Allocation.html                  |   6 +-
 arrow/array/array/fn.make_array.html               |   4 +-
 arrow/array/array/fn.new_empty_array.html          |   4 +-
 arrow/array/array/fn.new_null_array.html           |   4 +-
 arrow/array/array/index.html                       |   4 +-
 arrow/array/array/struct.BooleanArray.html         |  68 ++--
 arrow/array/array/struct.DictionaryArray.html      |  90 ++---
 arrow/array/array/struct.FixedSizeBinaryArray.html |  62 +--
 arrow/array/array/struct.FixedSizeListArray.html   |  56 +--
 arrow/array/array/struct.GenericByteArray.html     | 154 +++----
 arrow/array/array/struct.GenericListArray.html     |  82 ++--
 arrow/array/array/struct.MapArray.html             |  58 +--
 arrow/array/array/struct.NativeAdapter.html        |  18 +-
 arrow/array/array/struct.NullArray.html            |  32 +-
 arrow/array/array/struct.PrimitiveArray.html       | 268 ++++++-------
 arrow/array/array/struct.RunArray.html             |  66 +--
 arrow/array/array/struct.StructArray.html          |  56 +--
 arrow/array/array/struct.TypedDictionaryArray.html |  44 +-
 arrow/array/array/struct.TypedRunArray.html        |  46 +--
 arrow/array/array/struct.UnionArray.html           |  48 +--
 arrow/array/array/trait.AnyDictionaryArray.html    |  14 +-
 arrow/array/array/trait.Array.html                 |  86 ++--
 arrow/array/array/trait.ArrayAccessor.html         |  20 +-
 arrow/array/array/trait.ArrowPrimitiveType.html    |  14 +-
 arrow/array/array/trait.OffsetSizeTrait.html       |  10 +-
 arrow/array/array/type.ArrayRef.html               |   4 +-
 arrow/array/array/type.BinaryArray.html            |   4 +-
 arrow/array/array/type.Date32Array.html            |   4 +-
 arrow/array/array/type.Date64Array.html            |   4 +-
 arrow/array/array/type.Decimal128Array.html        |   4 +-
 arrow/array/array/type.Decimal256Array.html        |   4 +-
 .../array/array/type.DurationMicrosecondArray.html |   4 +-
 .../array/array/type.DurationMillisecondArray.html |   4 +-
 .../array/array/type.DurationNanosecondArray.html  |   4 +-
 arrow/array/array/type.DurationSecondArray.html    |   4 +-
 arrow/array/array/type.Float16Array.html           |   4 +-
 arrow/array/array/type.Float32Array.html           |   4 +-
 arrow/array/array/type.Float64Array.html           |   4 +-
 arrow/array/array/type.GenericBinaryArray.html     |   4 +-
 arrow/array/array/type.GenericStringArray.html     |   4 +-
 arrow/array/array/type.Int16Array.html             |   4 +-
 arrow/array/array/type.Int16DictionaryArray.html   |   4 +-
 arrow/array/array/type.Int16RunArray.html          |   4 +-
 arrow/array/array/type.Int32Array.html             |   4 +-
 arrow/array/array/type.Int32DictionaryArray.html   |   4 +-
 arrow/array/array/type.Int32RunArray.html          |   4 +-
 arrow/array/array/type.Int64Array.html             |   4 +-
 arrow/array/array/type.Int64DictionaryArray.html   |   4 +-
 arrow/array/array/type.Int64RunArray.html          |   4 +-
 arrow/array/array/type.Int8Array.html              |   4 +-
 arrow/array/array/type.Int8DictionaryArray.html    |   4 +-
 arrow/array/array/type.IntervalDayTimeArray.html   |   4 +-
 .../array/type.IntervalMonthDayNanoArray.html      |   4 +-
 arrow/array/array/type.IntervalYearMonthArray.html |   4 +-
 arrow/array/array/type.LargeBinaryArray.html       |   4 +-
 arrow/array/array/type.LargeListArray.html         |   4 +-
 arrow/array/array/type.LargeStringArray.html       |   4 +-
 arrow/array/array/type.ListArray.html              |   4 +-
 arrow/array/array/type.StringArray.html            |   4 +-
 arrow/array/array/type.Time32MillisecondArray.html |   4 +-
 arrow/array/array/type.Time32SecondArray.html      |   4 +-
 arrow/array/array/type.Time64MicrosecondArray.html |   4 +-
 arrow/array/array/type.Time64NanosecondArray.html  |   4 +-
 .../array/type.TimestampMicrosecondArray.html      |   4 +-
 .../array/type.TimestampMillisecondArray.html      |   4 +-
 .../array/array/type.TimestampNanosecondArray.html |   4 +-
 arrow/array/array/type.TimestampSecondArray.html   |   4 +-
 arrow/array/array/type.UInt16Array.html            |   4 +-
 arrow/array/array/type.UInt16DictionaryArray.html  |   4 +-
 arrow/array/array/type.UInt32Array.html            |   4 +-
 arrow/array/array/type.UInt32DictionaryArray.html  |   4 +-
 arrow/array/array/type.UInt64Array.html            |   4 +-
 arrow/array/array/type.UInt64DictionaryArray.html  |   4 +-
 arrow/array/array/type.UInt8Array.html             |   4 +-
 arrow/array/array/type.UInt8DictionaryArray.html   |   4 +-
 arrow/array/builder/fn.make_builder.html           |   4 +-
 arrow/array/builder/index.html                     |   4 +-
 .../array/builder/struct.BooleanBufferBuilder.html |  52 +--
 arrow/array/builder/struct.BooleanBuilder.html     |  50 +--
 arrow/array/builder/struct.BufferBuilder.html      |  62 +--
 .../builder/struct.FixedSizeBinaryBuilder.html     |  38 +-
 .../array/builder/struct.FixedSizeListBuilder.html |  48 +--
 arrow/array/builder/struct.GenericByteBuilder.html |  64 +--
 .../struct.GenericByteDictionaryBuilder.html       |  54 +--
 .../builder/struct.GenericByteRunBuilder.html      |  50 +--
 arrow/array/builder/struct.GenericListBuilder.html |  62 +--
 arrow/array/builder/struct.MapBuilder.html         |  38 +-
 arrow/array/builder/struct.MapFieldNames.html      |  12 +-
 arrow/array/builder/struct.NullBuilder.html        |  42 +-
 arrow/array/builder/struct.PrimitiveBuilder.html   |  84 ++--
 .../builder/struct.PrimitiveDictionaryBuilder.html |  62 +--
 .../array/builder/struct.PrimitiveRunBuilder.html  |  50 +--
 arrow/array/builder/struct.StructBuilder.html      |  40 +-
 arrow/array/builder/struct.UnionBuilder.html       |  26 +-
 arrow/array/builder/trait.ArrayBuilder.html        |  36 +-
 arrow/array/builder/type.BinaryBuilder.html        |   8 +-
 .../builder/type.BinaryDictionaryBuilder.html      |   4 +-
 arrow/array/builder/type.BinaryRunBuilder.html     |   4 +-
 arrow/array/builder/type.Date32BufferBuilder.html  |   4 +-
 arrow/array/builder/type.Date32Builder.html        |   8 +-
 arrow/array/builder/type.Date64BufferBuilder.html  |   4 +-
 arrow/array/builder/type.Date64Builder.html        |   8 +-
 .../builder/type.Decimal128BufferBuilder.html      |   4 +-
 arrow/array/builder/type.Decimal128Builder.html    |   8 +-
 .../builder/type.Decimal256BufferBuilder.html      |   4 +-
 arrow/array/builder/type.Decimal256Builder.html    |   8 +-
 .../type.DurationMicrosecondBufferBuilder.html     |   4 +-
 .../builder/type.DurationMicrosecondBuilder.html   |   8 +-
 .../type.DurationMillisecondBufferBuilder.html     |   4 +-
 .../builder/type.DurationMillisecondBuilder.html   |   8 +-
 .../type.DurationNanosecondBufferBuilder.html      |   4 +-
 .../builder/type.DurationNanosecondBuilder.html    |   8 +-
 .../builder/type.DurationSecondBufferBuilder.html  |   4 +-
 .../array/builder/type.DurationSecondBuilder.html  |   8 +-
 arrow/array/builder/type.Float16BufferBuilder.html |   4 +-
 arrow/array/builder/type.Float16Builder.html       |   8 +-
 arrow/array/builder/type.Float32BufferBuilder.html |   4 +-
 arrow/array/builder/type.Float32Builder.html       |   8 +-
 arrow/array/builder/type.Float64BufferBuilder.html |   4 +-
 arrow/array/builder/type.Float64Builder.html       |   8 +-
 arrow/array/builder/type.GenericBinaryBuilder.html |   8 +-
 arrow/array/builder/type.GenericStringBuilder.html |   8 +-
 arrow/array/builder/type.Int16BufferBuilder.html   |   4 +-
 arrow/array/builder/type.Int16Builder.html         |   8 +-
 arrow/array/builder/type.Int32BufferBuilder.html   |   4 +-
 arrow/array/builder/type.Int32Builder.html         |   8 +-
 arrow/array/builder/type.Int64BufferBuilder.html   |   4 +-
 arrow/array/builder/type.Int64Builder.html         |   8 +-
 arrow/array/builder/type.Int8BufferBuilder.html    |   4 +-
 arrow/array/builder/type.Int8Builder.html          |   8 +-
 .../builder/type.IntervalDayTimeBufferBuilder.html |   4 +-
 .../array/builder/type.IntervalDayTimeBuilder.html |   8 +-
 .../type.IntervalMonthDayNanoBufferBuilder.html    |   4 +-
 .../builder/type.IntervalMonthDayNanoBuilder.html  |   8 +-
 .../type.IntervalYearMonthBufferBuilder.html       |   4 +-
 .../builder/type.IntervalYearMonthBuilder.html     |   8 +-
 arrow/array/builder/type.LargeBinaryBuilder.html   |   8 +-
 .../builder/type.LargeBinaryDictionaryBuilder.html |   4 +-
 .../array/builder/type.LargeBinaryRunBuilder.html  |   4 +-
 arrow/array/builder/type.LargeListBuilder.html     |   8 +-
 arrow/array/builder/type.LargeStringBuilder.html   |   8 +-
 .../builder/type.LargeStringDictionaryBuilder.html |   4 +-
 .../array/builder/type.LargeStringRunBuilder.html  |   4 +-
 arrow/array/builder/type.ListBuilder.html          |   8 +-
 arrow/array/builder/type.StringBuilder.html        |   8 +-
 .../builder/type.StringDictionaryBuilder.html      |   4 +-
 arrow/array/builder/type.StringRunBuilder.html     |   4 +-
 .../type.Time32MillisecondBufferBuilder.html       |   4 +-
 .../builder/type.Time32MillisecondBuilder.html     |   8 +-
 .../builder/type.Time32SecondBufferBuilder.html    |   4 +-
 arrow/array/builder/type.Time32SecondBuilder.html  |   8 +-
 .../type.Time64MicrosecondBufferBuilder.html       |   4 +-
 .../builder/type.Time64MicrosecondBuilder.html     |   8 +-
 .../type.Time64NanosecondBufferBuilder.html        |   4 +-
 .../builder/type.Time64NanosecondBuilder.html      |   8 +-
 .../type.TimestampMicrosecondBufferBuilder.html    |   4 +-
 .../builder/type.TimestampMicrosecondBuilder.html  |   8 +-
 .../type.TimestampMillisecondBufferBuilder.html    |   4 +-
 .../builder/type.TimestampMillisecondBuilder.html  |   8 +-
 .../type.TimestampNanosecondBufferBuilder.html     |   4 +-
 .../builder/type.TimestampNanosecondBuilder.html   |   8 +-
 .../builder/type.TimestampSecondBufferBuilder.html |   4 +-
 .../array/builder/type.TimestampSecondBuilder.html |   8 +-
 arrow/array/builder/type.UInt16BufferBuilder.html  |   4 +-
 arrow/array/builder/type.UInt16Builder.html        |   8 +-
 arrow/array/builder/type.UInt32BufferBuilder.html  |   4 +-
 arrow/array/builder/type.UInt32Builder.html        |   8 +-
 arrow/array/builder/type.UInt64BufferBuilder.html  |   4 +-
 arrow/array/builder/type.UInt64Builder.html        |   8 +-
 arrow/array/builder/type.UInt8BufferBuilder.html   |   4 +-
 arrow/array/builder/type.UInt8Builder.html         |   8 +-
 arrow/array/cast/fn.as_boolean_array.html          |   4 +-
 arrow/array/cast/fn.as_decimal_array.html          |   4 +-
 arrow/array/cast/fn.as_dictionary_array.html       |   4 +-
 arrow/array/cast/fn.as_fixed_size_list_array.html  |   4 +-
 arrow/array/cast/fn.as_generic_binary_array.html   |   4 +-
 arrow/array/cast/fn.as_generic_list_array.html     |   4 +-
 arrow/array/cast/fn.as_large_list_array.html       |   4 +-
 arrow/array/cast/fn.as_largestring_array.html      |   4 +-
 arrow/array/cast/fn.as_list_array.html             |   4 +-
 arrow/array/cast/fn.as_map_array.html              |   4 +-
 arrow/array/cast/fn.as_null_array.html             |   4 +-
 arrow/array/cast/fn.as_primitive_array.html        |   4 +-
 arrow/array/cast/fn.as_run_array.html              |   4 +-
 arrow/array/cast/fn.as_string_array.html           |   4 +-
 arrow/array/cast/fn.as_struct_array.html           |   4 +-
 arrow/array/cast/fn.as_union_array.html            |   4 +-
 arrow/array/cast/fn.downcast_array.html            |   4 +-
 arrow/array/cast/index.html                        |   4 +-
 arrow/array/cast/trait.AsArray.html                |  62 +--
 arrow/array/enum.BufferSpec.html                   |  14 +-
 arrow/array/enum.Capacities.html                   |  12 +-
 arrow/array/ffi/fn.export_array_into_raw.html      |   2 +-
 arrow/array/ffi/index.html                         |   2 +-
 arrow/array/fn.as_boolean_array.html               |   4 +-
 arrow/array/fn.as_decimal_array.html               |   4 +-
 arrow/array/fn.as_dictionary_array.html            |   4 +-
 arrow/array/fn.as_fixed_size_list_array.html       |   4 +-
 arrow/array/fn.as_generic_binary_array.html        |   4 +-
 arrow/array/fn.as_generic_list_array.html          |   4 +-
 arrow/array/fn.as_large_list_array.html            |   4 +-
 arrow/array/fn.as_largestring_array.html           |   4 +-
 arrow/array/fn.as_list_array.html                  |   4 +-
 arrow/array/fn.as_map_array.html                   |   4 +-
 arrow/array/fn.as_null_array.html                  |   4 +-
 arrow/array/fn.as_primitive_array.html             |   4 +-
 arrow/array/fn.as_run_array.html                   |   4 +-
 arrow/array/fn.as_string_array.html                |   4 +-
 arrow/array/fn.as_struct_array.html                |   4 +-
 arrow/array/fn.as_union_array.html                 |   4 +-
 arrow/array/fn.build_compare.html                  |   6 +-
 arrow/array/fn.downcast_array.html                 |   4 +-
 arrow/array/fn.export_array_into_raw.html          |   2 +-
 arrow/array/fn.layout.html                         |   4 +-
 arrow/array/fn.make_array.html                     |   4 +-
 arrow/array/fn.make_builder.html                   |   4 +-
 arrow/array/fn.new_empty_array.html                |   4 +-
 arrow/array/fn.new_null_array.html                 |   4 +-
 arrow/array/index.html                             |   4 +-
 arrow/array/iterator/index.html                    |   4 +-
 arrow/array/iterator/struct.ArrayIter.html         |  26 +-
 arrow/array/iterator/type.BooleanIter.html         |   4 +-
 arrow/array/iterator/type.FixedSizeBinaryIter.html |   4 +-
 arrow/array/iterator/type.FixedSizeListIter.html   |   4 +-
 arrow/array/iterator/type.GenericBinaryIter.html   |   4 +-
 .../array/iterator/type.GenericListArrayIter.html  |   4 +-
 arrow/array/iterator/type.GenericStringIter.html   |   4 +-
 arrow/array/iterator/type.MapArrayIter.html        |   4 +-
 arrow/array/iterator/type.PrimitiveIter.html       |   4 +-
 arrow/array/macro.downcast_dictionary_array.html   |   4 +-
 arrow/array/macro.downcast_integer.html            |   4 +-
 arrow/array/macro.downcast_primitive.html          |   4 +-
 arrow/array/macro.downcast_primitive_array.html    |   4 +-
 arrow/array/macro.downcast_run_array.html          |   4 +-
 arrow/array/macro.downcast_run_end_index.html      |   4 +-
 arrow/array/macro.downcast_temporal.html           |   4 +-
 arrow/array/macro.downcast_temporal_array.html     |   4 +-
 arrow/array/run_iterator/index.html                |   4 +-
 arrow/array/run_iterator/struct.RunArrayIter.html  |  24 +-
 arrow/array/struct.ArrayData.html                  |  88 ++--
 arrow/array/struct.ArrayDataBuilder.html           |  18 +-
 arrow/array/struct.ArrayIter.html                  |  26 +-
 arrow/array/struct.BooleanArray.html               |  68 ++--
 arrow/array/struct.BooleanBufferBuilder.html       |  52 +--
 arrow/array/struct.BooleanBuilder.html             |  50 +--
 arrow/array/struct.BufferBuilder.html              |  62 +--
 arrow/array/struct.DataTypeLayout.html             |  20 +-
 arrow/array/struct.DictionaryArray.html            |  90 ++---
 arrow/array/struct.FixedSizeBinaryArray.html       |  62 +--
 arrow/array/struct.FixedSizeBinaryBuilder.html     |  38 +-
 arrow/array/struct.FixedSizeListArray.html         |  56 +--
 arrow/array/struct.FixedSizeListBuilder.html       |  48 +--
 arrow/array/struct.GenericByteArray.html           | 154 +++----
 arrow/array/struct.GenericByteBuilder.html         |  64 +--
 .../array/struct.GenericByteDictionaryBuilder.html |  54 +--
 arrow/array/struct.GenericByteRunBuilder.html      |  50 +--
 arrow/array/struct.GenericListArray.html           |  82 ++--
 arrow/array/struct.GenericListBuilder.html         |  62 +--
 arrow/array/struct.MapArray.html                   |  58 +--
 arrow/array/struct.MapBuilder.html                 |  38 +-
 arrow/array/struct.MapFieldNames.html              |  12 +-
 arrow/array/struct.MutableArrayData.html           |  36 +-
 arrow/array/struct.NativeAdapter.html              |  18 +-
 arrow/array/struct.NullArray.html                  |  32 +-
 arrow/array/struct.NullBuilder.html                |  42 +-
 arrow/array/struct.PrimitiveArray.html             | 268 ++++++-------
 arrow/array/struct.PrimitiveBuilder.html           |  84 ++--
 arrow/array/struct.PrimitiveDictionaryBuilder.html |  62 +--
 arrow/array/struct.PrimitiveRunBuilder.html        |  50 +--
 arrow/array/struct.RecordBatch.html                |  46 +--
 arrow/array/struct.RecordBatchIterator.html        |  22 +-
 arrow/array/struct.RecordBatchOptions.html         |  18 +-
 arrow/array/struct.RunArray.html                   |  66 +--
 arrow/array/struct.Scalar.html                     |  22 +-
 arrow/array/struct.StructArray.html                |  56 +--
 arrow/array/struct.StructBuilder.html              |  40 +-
 arrow/array/struct.TypedDictionaryArray.html       |  44 +-
 arrow/array/struct.TypedRunArray.html              |  46 +--
 arrow/array/struct.UnionArray.html                 |  48 +--
 arrow/array/struct.UnionBuilder.html               |  26 +-
 .../constant.EPOCH_DAYS_FROM_CE.html               |   4 +-
 .../constant.MICROSECONDS.html                     |   4 +-
 .../constant.MICROSECONDS_IN_DAY.html              |   4 +-
 .../constant.MILLISECONDS.html                     |   4 +-
 .../constant.MILLISECONDS_IN_DAY.html              |   4 +-
 .../temporal_conversions/constant.NANOSECONDS.html |   4 +-
 .../constant.NANOSECONDS_IN_DAY.html               |   4 +-
 .../constant.SECONDS_IN_DAY.html                   |   4 +-
 arrow/array/temporal_conversions/fn.as_date.html   |   4 +-
 .../array/temporal_conversions/fn.as_datetime.html |   4 +-
 .../fn.as_datetime_with_timezone.html              |   4 +-
 .../array/temporal_conversions/fn.as_duration.html |   4 +-
 arrow/array/temporal_conversions/fn.as_time.html   |   4 +-
 .../fn.date32_to_datetime.html                     |   4 +-
 .../fn.date64_to_datetime.html                     |   4 +-
 .../fn.duration_ms_to_duration.html                |   4 +-
 .../fn.duration_ns_to_duration.html                |   4 +-
 .../fn.duration_s_to_duration.html                 |   4 +-
 .../fn.duration_us_to_duration.html                |   4 +-
 .../temporal_conversions/fn.time32ms_to_time.html  |   4 +-
 .../temporal_conversions/fn.time32s_to_time.html   |   4 +-
 .../temporal_conversions/fn.time64ns_to_time.html  |   4 +-
 .../temporal_conversions/fn.time64us_to_time.html  |   4 +-
 .../temporal_conversions/fn.time_to_time32ms.html  |   4 +-
 .../temporal_conversions/fn.time_to_time32s.html   |   4 +-
 .../temporal_conversions/fn.time_to_time64ns.html  |   4 +-
 .../temporal_conversions/fn.time_to_time64us.html  |   4 +-
 .../fn.timestamp_ms_to_datetime.html               |   4 +-
 .../fn.timestamp_ns_to_datetime.html               |   4 +-
 .../fn.timestamp_s_to_datetime.html                |   4 +-
 .../fn.timestamp_us_to_datetime.html               |   4 +-
 arrow/array/temporal_conversions/index.html        |   4 +-
 arrow/array/timezone/index.html                    |   4 +-
 arrow/array/timezone/struct.Tz.html                |  20 +-
 arrow/array/timezone/struct.TzOffset.html          |  12 +-
 arrow/array/trait.AnyDictionaryArray.html          |  14 +-
 arrow/array/trait.Array.html                       |  86 ++--
 arrow/array/trait.ArrayAccessor.html               |  20 +-
 arrow/array/trait.ArrayBuilder.html                |  36 +-
 arrow/array/trait.ArrowNativeTypeOp.html           |  58 +--
 arrow/array/trait.ArrowNumericType.html            |   6 +-
 arrow/array/trait.ArrowPrimitiveType.html          |  14 +-
 arrow/array/trait.AsArray.html                     |  62 +--
 arrow/array/trait.Datum.html                       |  10 +-
 arrow/array/trait.OffsetSizeTrait.html             |  10 +-
 arrow/array/trait.RecordBatchReader.html           |  20 +-
 arrow/array/trait.RecordBatchWriter.html           |  16 +-
 arrow/array/type.ArrayDataRef.html                 |   4 +-
 arrow/array/type.ArrayRef.html                     |   4 +-
 arrow/array/type.BinaryArray.html                  |   4 +-
 arrow/array/type.BinaryBuilder.html                |   8 +-
 arrow/array/type.BinaryDictionaryBuilder.html      |   4 +-
 arrow/array/type.BinaryRunBuilder.html             |   4 +-
 arrow/array/type.BooleanIter.html                  |   4 +-
 arrow/array/type.Date32Array.html                  |   4 +-
 arrow/array/type.Date32BufferBuilder.html          |   4 +-
 arrow/array/type.Date32Builder.html                |   8 +-
 arrow/array/type.Date64Array.html                  |   4 +-
 arrow/array/type.Date64BufferBuilder.html          |   4 +-
 arrow/array/type.Date64Builder.html                |   8 +-
 arrow/array/type.Decimal128Array.html              |   4 +-
 arrow/array/type.Decimal128BufferBuilder.html      |   4 +-
 arrow/array/type.Decimal128Builder.html            |   8 +-
 arrow/array/type.Decimal256Array.html              |   4 +-
 arrow/array/type.Decimal256BufferBuilder.html      |   4 +-
 arrow/array/type.Decimal256Builder.html            |   8 +-
 arrow/array/type.DurationMicrosecondArray.html     |   4 +-
 .../type.DurationMicrosecondBufferBuilder.html     |   4 +-
 arrow/array/type.DurationMicrosecondBuilder.html   |   8 +-
 arrow/array/type.DurationMillisecondArray.html     |   4 +-
 .../type.DurationMillisecondBufferBuilder.html     |   4 +-
 arrow/array/type.DurationMillisecondBuilder.html   |   8 +-
 arrow/array/type.DurationNanosecondArray.html      |   4 +-
 .../type.DurationNanosecondBufferBuilder.html      |   4 +-
 arrow/array/type.DurationNanosecondBuilder.html    |   8 +-
 arrow/array/type.DurationSecondArray.html          |   4 +-
 arrow/array/type.DurationSecondBufferBuilder.html  |   4 +-
 arrow/array/type.DurationSecondBuilder.html        |   8 +-
 arrow/array/type.DynComparator.html                |   6 +-
 arrow/array/type.FixedSizeBinaryIter.html          |   4 +-
 arrow/array/type.FixedSizeListIter.html            |   4 +-
 arrow/array/type.Float16Array.html                 |   4 +-
 arrow/array/type.Float16BufferBuilder.html         |   4 +-
 arrow/array/type.Float16Builder.html               |   8 +-
 arrow/array/type.Float32Array.html                 |   4 +-
 arrow/array/type.Float32BufferBuilder.html         |   4 +-
 arrow/array/type.Float32Builder.html               |   8 +-
 arrow/array/type.Float64Array.html                 |   4 +-
 arrow/array/type.Float64BufferBuilder.html         |   4 +-
 arrow/array/type.Float64Builder.html               |   8 +-
 arrow/array/type.GenericBinaryArray.html           |   4 +-
 arrow/array/type.GenericBinaryBuilder.html         |   8 +-
 arrow/array/type.GenericBinaryIter.html            |   4 +-
 arrow/array/type.GenericListArrayIter.html         |   4 +-
 arrow/array/type.GenericStringArray.html           |   4 +-
 arrow/array/type.GenericStringBuilder.html         |   8 +-
 arrow/array/type.GenericStringIter.html            |   4 +-
 arrow/array/type.Int16Array.html                   |   4 +-
 arrow/array/type.Int16BufferBuilder.html           |   4 +-
 arrow/array/type.Int16Builder.html                 |   8 +-
 arrow/array/type.Int16DictionaryArray.html         |   4 +-
 arrow/array/type.Int16RunArray.html                |   4 +-
 arrow/array/type.Int32Array.html                   |   4 +-
 arrow/array/type.Int32BufferBuilder.html           |   4 +-
 arrow/array/type.Int32Builder.html                 |   8 +-
 arrow/array/type.Int32DictionaryArray.html         |   4 +-
 arrow/array/type.Int32RunArray.html                |   4 +-
 arrow/array/type.Int64Array.html                   |   4 +-
 arrow/array/type.Int64BufferBuilder.html           |   4 +-
 arrow/array/type.Int64Builder.html                 |   8 +-
 arrow/array/type.Int64DictionaryArray.html         |   4 +-
 arrow/array/type.Int64RunArray.html                |   4 +-
 arrow/array/type.Int8Array.html                    |   4 +-
 arrow/array/type.Int8BufferBuilder.html            |   4 +-
 arrow/array/type.Int8Builder.html                  |   8 +-
 arrow/array/type.Int8DictionaryArray.html          |   4 +-
 arrow/array/type.IntervalDayTimeArray.html         |   4 +-
 arrow/array/type.IntervalDayTimeBufferBuilder.html |   4 +-
 arrow/array/type.IntervalDayTimeBuilder.html       |   8 +-
 arrow/array/type.IntervalMonthDayNanoArray.html    |   4 +-
 .../type.IntervalMonthDayNanoBufferBuilder.html    |   4 +-
 arrow/array/type.IntervalMonthDayNanoBuilder.html  |   8 +-
 arrow/array/type.IntervalYearMonthArray.html       |   4 +-
 .../array/type.IntervalYearMonthBufferBuilder.html |   4 +-
 arrow/array/type.IntervalYearMonthBuilder.html     |   8 +-
 arrow/array/type.LargeBinaryArray.html             |   4 +-
 arrow/array/type.LargeBinaryBuilder.html           |   8 +-
 arrow/array/type.LargeBinaryDictionaryBuilder.html |   4 +-
 arrow/array/type.LargeBinaryRunBuilder.html        |   4 +-
 arrow/array/type.LargeListArray.html               |   4 +-
 arrow/array/type.LargeListBuilder.html             |   8 +-
 arrow/array/type.LargeStringArray.html             |   4 +-
 arrow/array/type.LargeStringBuilder.html           |   8 +-
 arrow/array/type.LargeStringDictionaryBuilder.html |   4 +-
 arrow/array/type.LargeStringRunBuilder.html        |   4 +-
 arrow/array/type.ListArray.html                    |   4 +-
 arrow/array/type.ListBuilder.html                  |   8 +-
 arrow/array/type.MapArrayIter.html                 |   4 +-
 arrow/array/type.PrimitiveIter.html                |   4 +-
 arrow/array/type.StringArray.html                  |   4 +-
 arrow/array/type.StringBuilder.html                |   8 +-
 arrow/array/type.StringDictionaryBuilder.html      |   4 +-
 arrow/array/type.StringRunBuilder.html             |   4 +-
 arrow/array/type.Time32MillisecondArray.html       |   4 +-
 .../array/type.Time32MillisecondBufferBuilder.html |   4 +-
 arrow/array/type.Time32MillisecondBuilder.html     |   8 +-
 arrow/array/type.Time32SecondArray.html            |   4 +-
 arrow/array/type.Time32SecondBufferBuilder.html    |   4 +-
 arrow/array/type.Time32SecondBuilder.html          |   8 +-
 arrow/array/type.Time64MicrosecondArray.html       |   4 +-
 .../array/type.Time64MicrosecondBufferBuilder.html |   4 +-
 arrow/array/type.Time64MicrosecondBuilder.html     |   8 +-
 arrow/array/type.Time64NanosecondArray.html        |   4 +-
 .../array/type.Time64NanosecondBufferBuilder.html  |   4 +-
 arrow/array/type.Time64NanosecondBuilder.html      |   8 +-
 arrow/array/type.TimestampMicrosecondArray.html    |   4 +-
 .../type.TimestampMicrosecondBufferBuilder.html    |   4 +-
 arrow/array/type.TimestampMicrosecondBuilder.html  |   8 +-
 arrow/array/type.TimestampMillisecondArray.html    |   4 +-
 .../type.TimestampMillisecondBufferBuilder.html    |   4 +-
 arrow/array/type.TimestampMillisecondBuilder.html  |   8 +-
 arrow/array/type.TimestampNanosecondArray.html     |   4 +-
 .../type.TimestampNanosecondBufferBuilder.html     |   4 +-
 arrow/array/type.TimestampNanosecondBuilder.html   |   8 +-
 arrow/array/type.TimestampSecondArray.html         |   4 +-
 arrow/array/type.TimestampSecondBufferBuilder.html |   4 +-
 arrow/array/type.TimestampSecondBuilder.html       |   8 +-
 arrow/array/type.UInt16Array.html                  |   4 +-
 arrow/array/type.UInt16BufferBuilder.html          |   4 +-
 arrow/array/type.UInt16Builder.html                |   8 +-
 arrow/array/type.UInt16DictionaryArray.html        |   4 +-
 arrow/array/type.UInt32Array.html                  |   4 +-
 arrow/array/type.UInt32BufferBuilder.html          |   4 +-
 arrow/array/type.UInt32Builder.html                |   8 +-
 arrow/array/type.UInt32DictionaryArray.html        |   4 +-
 arrow/array/type.UInt64Array.html                  |   4 +-
 arrow/array/type.UInt64BufferBuilder.html          |   4 +-
 arrow/array/type.UInt64Builder.html                |   8 +-
 arrow/array/type.UInt64DictionaryArray.html        |   4 +-
 arrow/array/type.UInt8Array.html                   |   4 +-
 arrow/array/type.UInt8BufferBuilder.html           |   4 +-
 arrow/array/type.UInt8Builder.html                 |   8 +-
 arrow/array/type.UInt8DictionaryArray.html         |   4 +-
 .../fn.validate_decimal_precision_and_scale.html   |   4 +-
 arrow/array/types/index.html                       |   4 +-
 arrow/array/types/struct.BooleanType.html          |  14 +-
 arrow/array/types/struct.Date32Type.html           |  30 +-
 arrow/array/types/struct.Date64Type.html           |  30 +-
 arrow/array/types/struct.Decimal128Type.html       |  16 +-
 arrow/array/types/struct.Decimal256Type.html       |  16 +-
 .../types/struct.DurationMicrosecondType.html      |  14 +-
 .../types/struct.DurationMillisecondType.html      |  14 +-
 .../array/types/struct.DurationNanosecondType.html |  14 +-
 arrow/array/types/struct.DurationSecondType.html   |  14 +-
 arrow/array/types/struct.Float16Type.html          |  14 +-
 arrow/array/types/struct.Float32Type.html          |  14 +-
 arrow/array/types/struct.Float64Type.html          |  14 +-
 arrow/array/types/struct.GenericBinaryType.html    |  14 +-
 arrow/array/types/struct.GenericStringType.html    |  14 +-
 arrow/array/types/struct.Int16Type.html            |  14 +-
 arrow/array/types/struct.Int32Type.html            |  14 +-
 arrow/array/types/struct.Int64Type.html            |  14 +-
 arrow/array/types/struct.Int8Type.html             |  14 +-
 arrow/array/types/struct.IntervalDayTimeType.html  |  18 +-
 .../types/struct.IntervalMonthDayNanoType.html     |  18 +-
 .../array/types/struct.IntervalYearMonthType.html  |  18 +-
 .../array/types/struct.Time32MillisecondType.html  |  18 +-
 arrow/array/types/struct.Time32SecondType.html     |  18 +-
 .../array/types/struct.Time64MicrosecondType.html  |  18 +-
 arrow/array/types/struct.Time64NanosecondType.html |  18 +-
 .../types/struct.TimestampMicrosecondType.html     |  26 +-
 .../types/struct.TimestampMillisecondType.html     |  26 +-
 .../types/struct.TimestampNanosecondType.html      |  26 +-
 arrow/array/types/struct.TimestampSecondType.html  |  26 +-
 arrow/array/types/struct.UInt16Type.html           |  14 +-
 arrow/array/types/struct.UInt32Type.html           |  14 +-
 arrow/array/types/struct.UInt64Type.html           |  14 +-
 arrow/array/types/struct.UInt8Type.html            |  14 +-
 .../array/types/trait.ArrowDictionaryKeyType.html  |   6 +-
 arrow/array/types/trait.ArrowPrimitiveType.html    |  14 +-
 arrow/array/types/trait.ArrowTemporalType.html     |   6 +-
 arrow/array/types/trait.ArrowTimestampType.html    |  12 +-
 arrow/array/types/trait.ByteArrayType.html         |  22 +-
 arrow/array/types/trait.DecimalType.html           |  22 +-
 arrow/array/types/trait.RunEndIndexType.html       |   6 +-
 arrow/array/types/type.BinaryType.html             |   4 +-
 arrow/array/types/type.LargeBinaryType.html        |   4 +-
 arrow/array/types/type.LargeUtf8Type.html          |   4 +-
 arrow/array/types/type.Utf8Type.html               |   4 +-
 arrow/buffer/fn.bitwise_bin_op_helper.html         |   4 +-
 arrow/buffer/fn.bitwise_quaternary_op_helper.html  |   4 +-
 arrow/buffer/fn.bitwise_unary_op_helper.html       |   4 +-
 arrow/buffer/fn.buffer_bin_and.html                |   4 +-
 arrow/buffer/fn.buffer_bin_and_not.html            |   4 +-
 arrow/buffer/fn.buffer_bin_or.html                 |   4 +-
 arrow/buffer/fn.buffer_bin_xor.html                |   4 +-
 arrow/buffer/fn.buffer_unary_not.html              |   4 +-
 arrow/buffer/index.html                            |   4 +-
 arrow/buffer/struct.BooleanBuffer.html             |  64 +--
 arrow/buffer/struct.Buffer.html                    | 244 +++++------
 arrow/buffer/struct.MutableBuffer.html             | 446 ++++++++++-----------
 arrow/buffer/struct.NullBuffer.html                |  60 +--
 arrow/buffer/struct.OffsetBuffer.html              | 208 +++++-----
 arrow/buffer/struct.RunEndBuffer.html              |  44 +-
 arrow/buffer/struct.ScalarBuffer.html              | 220 +++++-----
 arrow/compute/enum.DatePart.html                   |  14 +-
 arrow/compute/fn.and.html                          |   4 +-
 arrow/compute/fn.and_kleene.html                   |   4 +-
 arrow/compute/fn.and_not.html                      |   4 +-
 arrow/compute/fn.binary.html                       |   4 +-
 arrow/compute/fn.binary_mut.html                   |   4 +-
 arrow/compute/fn.bit_and.html                      |   4 +-
 arrow/compute/fn.bit_or.html                       |   4 +-
 arrow/compute/fn.bit_xor.html                      |   4 +-
 arrow/compute/fn.bool_and.html                     |   4 +-
 arrow/compute/fn.bool_or.html                      |   4 +-
 arrow/compute/fn.build_filter.html                 |   4 +-
 arrow/compute/fn.can_cast_types.html               |   4 +-
 arrow/compute/fn.cast.html                         |   4 +-
 arrow/compute/fn.cast_with_options.html            |   4 +-
 arrow/compute/fn.concat.html                       |   4 +-
 arrow/compute/fn.concat_batches.html               |   4 +-
 arrow/compute/fn.date_part.html                    |   4 +-
 arrow/compute/fn.day.html                          |   4 +-
 arrow/compute/fn.day_dyn.html                      |   4 +-
 arrow/compute/fn.doy.html                          |   4 +-
 arrow/compute/fn.doy_dyn.html                      |   4 +-
 arrow/compute/fn.filter.html                       |   4 +-
 arrow/compute/fn.filter_record_batch.html          |   4 +-
 arrow/compute/fn.hour.html                         |   4 +-
 arrow/compute/fn.hour_dyn.html                     |   4 +-
 arrow/compute/fn.interleave.html                   |   4 +-
 arrow/compute/fn.is_not_null.html                  |   4 +-
 arrow/compute/fn.is_null.html                      |   4 +-
 .../fn.lexicographical_partition_ranges.html       |   4 +-
 arrow/compute/fn.lexsort.html                      |   4 +-
 arrow/compute/fn.lexsort_to_indices.html           |   4 +-
 arrow/compute/fn.max.html                          |   4 +-
 arrow/compute/fn.max_array.html                    |   4 +-
 arrow/compute/fn.max_binary.html                   |   4 +-
 arrow/compute/fn.max_boolean.html                  |   4 +-
 arrow/compute/fn.max_string.html                   |   4 +-
 arrow/compute/fn.microsecond.html                  |   4 +-
 arrow/compute/fn.microsecond_dyn.html              |   4 +-
 arrow/compute/fn.millisecond.html                  |   4 +-
 arrow/compute/fn.millisecond_dyn.html              |   4 +-
 arrow/compute/fn.min.html                          |   4 +-
 arrow/compute/fn.min_array.html                    |   4 +-
 arrow/compute/fn.min_binary.html                   |   4 +-
 arrow/compute/fn.min_boolean.html                  |   4 +-
 arrow/compute/fn.min_string.html                   |   4 +-
 arrow/compute/fn.minute.html                       |   4 +-
 arrow/compute/fn.minute_dyn.html                   |   4 +-
 arrow/compute/fn.month.html                        |   4 +-
 arrow/compute/fn.month_dyn.html                    |   4 +-
 arrow/compute/fn.multiply_fixed_point.html         |   4 +-
 arrow/compute/fn.multiply_fixed_point_checked.html |   4 +-
 arrow/compute/fn.multiply_fixed_point_dyn.html     |   4 +-
 arrow/compute/fn.nanosecond.html                   |   4 +-
 arrow/compute/fn.nanosecond_dyn.html               |   4 +-
 arrow/compute/fn.not.html                          |   4 +-
 arrow/compute/fn.nullif.html                       |   4 +-
 arrow/compute/fn.num_days_from_monday.html         |   4 +-
 arrow/compute/fn.num_days_from_monday_dyn.html     |   4 +-
 arrow/compute/fn.num_days_from_sunday.html         |   4 +-
 arrow/compute/fn.num_days_from_sunday_dyn.html     |   4 +-
 arrow/compute/fn.or.html                           |   4 +-
 arrow/compute/fn.or_kleene.html                    |   4 +-
 arrow/compute/fn.partial_sort.html                 |   4 +-
 arrow/compute/fn.partition.html                    |   4 +-
 arrow/compute/fn.prep_null_mask_filter.html        |   4 +-
 arrow/compute/fn.quarter.html                      |   4 +-
 arrow/compute/fn.quarter_dyn.html                  |   4 +-
 arrow/compute/fn.rank.html                         |   4 +-
 arrow/compute/fn.regexp_is_match_utf8.html         |   4 +-
 arrow/compute/fn.regexp_is_match_utf8_scalar.html  |   4 +-
 arrow/compute/fn.regexp_match.html                 |   4 +-
 arrow/compute/fn.second.html                       |   4 +-
 arrow/compute/fn.second_dyn.html                   |   4 +-
 arrow/compute/fn.shift.html                        |   4 +-
 arrow/compute/fn.sort.html                         |   4 +-
 arrow/compute/fn.sort_limit.html                   |   4 +-
 arrow/compute/fn.sort_to_indices.html              |   4 +-
 arrow/compute/fn.sum.html                          |   4 +-
 arrow/compute/fn.sum_array.html                    |   4 +-
 arrow/compute/fn.sum_array_checked.html            |   4 +-
 arrow/compute/fn.sum_checked.html                  |   4 +-
 arrow/compute/fn.take.html                         |   4 +-
 arrow/compute/fn.take_record_batch.html            |   4 +-
 arrow/compute/fn.try_binary.html                   |   4 +-
 arrow/compute/fn.try_binary_mut.html               |   4 +-
 arrow/compute/fn.try_unary.html                    |   4 +-
 arrow/compute/fn.try_unary_dyn.html                |   4 +-
 arrow/compute/fn.try_unary_mut.html                |   4 +-
 arrow/compute/fn.unary.html                        |   4 +-
 arrow/compute/fn.unary_dyn.html                    |   4 +-
 arrow/compute/fn.unary_mut.html                    |   4 +-
 ...fn.using_chrono_tz_and_utc_naive_date_time.html |   4 +-
 arrow/compute/fn.week.html                         |   4 +-
 arrow/compute/fn.week_dyn.html                     |   4 +-
 arrow/compute/fn.year.html                         |   4 +-
 arrow/compute/fn.year_dyn.html                     |   4 +-
 arrow/compute/index.html                           |   2 +-
 arrow/compute/kernels/aggregate/fn.bit_and.html    |   4 +-
 arrow/compute/kernels/aggregate/fn.bit_or.html     |   4 +-
 arrow/compute/kernels/aggregate/fn.bit_xor.html    |   4 +-
 arrow/compute/kernels/aggregate/fn.bool_and.html   |   4 +-
 arrow/compute/kernels/aggregate/fn.bool_or.html    |   4 +-
 arrow/compute/kernels/aggregate/fn.max.html        |   4 +-
 arrow/compute/kernels/aggregate/fn.max_array.html  |   4 +-
 arrow/compute/kernels/aggregate/fn.max_binary.html |   4 +-
 .../compute/kernels/aggregate/fn.max_boolean.html  |   4 +-
 arrow/compute/kernels/aggregate/fn.max_string.html |   4 +-
 arrow/compute/kernels/aggregate/fn.min.html        |   4 +-
 arrow/compute/kernels/aggregate/fn.min_array.html  |   4 +-
 arrow/compute/kernels/aggregate/fn.min_binary.html |   4 +-
 .../compute/kernels/aggregate/fn.min_boolean.html  |   4 +-
 arrow/compute/kernels/aggregate/fn.min_string.html |   4 +-
 arrow/compute/kernels/aggregate/fn.sum.html        |   4 +-
 arrow/compute/kernels/aggregate/fn.sum_array.html  |   4 +-
 .../kernels/aggregate/fn.sum_array_checked.html    |   4 +-
 .../compute/kernels/aggregate/fn.sum_checked.html  |   4 +-
 arrow/compute/kernels/aggregate/index.html         |   4 +-
 arrow/compute/kernels/arity/fn.binary.html         |   4 +-
 arrow/compute/kernels/arity/fn.binary_mut.html     |   4 +-
 arrow/compute/kernels/arity/fn.try_binary.html     |   4 +-
 arrow/compute/kernels/arity/fn.try_binary_mut.html |   4 +-
 arrow/compute/kernels/arity/fn.try_unary.html      |   4 +-
 arrow/compute/kernels/arity/fn.try_unary_dyn.html  |   4 +-
 arrow/compute/kernels/arity/fn.try_unary_mut.html  |   4 +-
 arrow/compute/kernels/arity/fn.unary.html          |   4 +-
 arrow/compute/kernels/arity/fn.unary_dyn.html      |   4 +-
 arrow/compute/kernels/arity/fn.unary_mut.html      |   4 +-
 arrow/compute/kernels/arity/index.html             |   4 +-
 arrow/compute/kernels/bitwise/fn.bitwise_and.html  |   4 +-
 .../kernels/bitwise/fn.bitwise_and_not.html        |   4 +-
 .../kernels/bitwise/fn.bitwise_and_scalar.html     |   4 +-
 arrow/compute/kernels/bitwise/fn.bitwise_not.html  |   4 +-
 arrow/compute/kernels/bitwise/fn.bitwise_or.html   |   4 +-
 .../kernels/bitwise/fn.bitwise_or_scalar.html      |   4 +-
 .../kernels/bitwise/fn.bitwise_shift_left.html     |   4 +-
 .../bitwise/fn.bitwise_shift_left_scalar.html      |   4 +-
 .../kernels/bitwise/fn.bitwise_shift_right.html    |   4 +-
 .../bitwise/fn.bitwise_shift_right_scalar.html     |   4 +-
 arrow/compute/kernels/bitwise/fn.bitwise_xor.html  |   4 +-
 .../kernels/bitwise/fn.bitwise_xor_scalar.html     |   4 +-
 arrow/compute/kernels/bitwise/index.html           |   4 +-
 arrow/compute/kernels/boolean/fn.and.html          |   4 +-
 arrow/compute/kernels/boolean/fn.and_kleene.html   |   4 +-
 arrow/compute/kernels/boolean/fn.and_not.html      |   4 +-
 arrow/compute/kernels/boolean/fn.is_not_null.html  |   4 +-
 arrow/compute/kernels/boolean/fn.is_null.html      |   4 +-
 arrow/compute/kernels/boolean/fn.not.html          |   4 +-
 arrow/compute/kernels/boolean/fn.or.html           |   4 +-
 arrow/compute/kernels/boolean/fn.or_kleene.html    |   4 +-
 arrow/compute/kernels/boolean/index.html           |   4 +-
 arrow/compute/kernels/cast/fn.can_cast_types.html  |   4 +-
 arrow/compute/kernels/cast/fn.cast.html            |   4 +-
 .../compute/kernels/cast/fn.cast_with_options.html |   4 +-
 arrow/compute/kernels/cast/index.html              |   4 +-
 arrow/compute/kernels/cast/struct.CastOptions.html |  16 +-
 .../kernels/cast_utils/fn.parse_decimal.html       |   4 +-
 .../cast_utils/fn.parse_interval_day_time.html     |   4 +-
 .../fn.parse_interval_month_day_nano.html          |   4 +-
 .../cast_utils/fn.parse_interval_year_month.html   |   4 +-
 .../kernels/cast_utils/fn.string_to_datetime.html  |   4 +-
 .../cast_utils/fn.string_to_time_nanoseconds.html  |   4 +-
 .../cast_utils/fn.string_to_timestamp_nanos.html   |   4 +-
 arrow/compute/kernels/cast_utils/index.html        |   4 +-
 arrow/compute/kernels/cast_utils/trait.Parser.html |   6 +-
 .../kernels/cast_utils/type.MonthDayNano.html      |   4 +-
 arrow/compute/kernels/cmp/fn.distinct.html         |   4 +-
 arrow/compute/kernels/cmp/fn.eq.html               |   4 +-
 arrow/compute/kernels/cmp/fn.gt.html               |   4 +-
 arrow/compute/kernels/cmp/fn.gt_eq.html            |   4 +-
 arrow/compute/kernels/cmp/fn.lt.html               |   4 +-
 arrow/compute/kernels/cmp/fn.lt_eq.html            |   4 +-
 arrow/compute/kernels/cmp/fn.neq.html              |   4 +-
 arrow/compute/kernels/cmp/fn.not_distinct.html     |   4 +-
 arrow/compute/kernels/cmp/index.html               |   4 +-
 arrow/compute/kernels/comparison/fn.contains.html  |   4 +-
 arrow/compute/kernels/comparison/fn.ends_with.html |   4 +-
 arrow/compute/kernels/comparison/fn.eq.html        |   4 +-
 arrow/compute/kernels/comparison/fn.eq_binary.html |   4 +-
 .../kernels/comparison/fn.eq_binary_scalar.html    |   4 +-
 arrow/compute/kernels/comparison/fn.eq_bool.html   |   4 +-
 .../kernels/comparison/fn.eq_bool_scalar.html      |   4 +-
 arrow/compute/kernels/comparison/fn.eq_dyn.html    |   4 +-
 .../comparison/fn.eq_dyn_binary_scalar.html        |   4 +-
 .../kernels/comparison/fn.eq_dyn_bool_scalar.html  |   4 +-
 .../kernels/comparison/fn.eq_dyn_scalar.html       |   4 +-
 .../kernels/comparison/fn.eq_dyn_utf8_scalar.html  |   4 +-
 arrow/compute/kernels/comparison/fn.eq_scalar.html |   4 +-
 arrow/compute/kernels/comparison/fn.eq_utf8.html   |   4 +-
 .../kernels/comparison/fn.eq_utf8_scalar.html      |   4 +-
 arrow/compute/kernels/comparison/fn.gt.html        |   4 +-
 arrow/compute/kernels/comparison/fn.gt_binary.html |   4 +-
 .../kernels/comparison/fn.gt_binary_scalar.html    |   4 +-
 arrow/compute/kernels/comparison/fn.gt_bool.html   |   4 +-
 .../kernels/comparison/fn.gt_bool_scalar.html      |   4 +-
 arrow/compute/kernels/comparison/fn.gt_dyn.html    |   4 +-
 .../comparison/fn.gt_dyn_binary_scalar.html        |   4 +-
 .../kernels/comparison/fn.gt_dyn_bool_scalar.html  |   4 +-
 .../kernels/comparison/fn.gt_dyn_scalar.html       |   4 +-
 .../kernels/comparison/fn.gt_dyn_utf8_scalar.html  |   4 +-
 arrow/compute/kernels/comparison/fn.gt_eq.html     |   4 +-
 .../kernels/comparison/fn.gt_eq_binary.html        |   4 +-
 .../kernels/comparison/fn.gt_eq_binary_scalar.html |   4 +-
 .../compute/kernels/comparison/fn.gt_eq_bool.html  |   4 +-
 .../kernels/comparison/fn.gt_eq_bool_scalar.html   |   4 +-
 arrow/compute/kernels/comparison/fn.gt_eq_dyn.html |   4 +-
 .../comparison/fn.gt_eq_dyn_binary_scalar.html     |   4 +-
 .../comparison/fn.gt_eq_dyn_bool_scalar.html       |   4 +-
 .../kernels/comparison/fn.gt_eq_dyn_scalar.html    |   4 +-
 .../comparison/fn.gt_eq_dyn_utf8_scalar.html       |   4 +-
 .../kernels/comparison/fn.gt_eq_scalar.html        |   4 +-
 .../compute/kernels/comparison/fn.gt_eq_utf8.html  |   4 +-
 .../kernels/comparison/fn.gt_eq_utf8_scalar.html   |   4 +-
 arrow/compute/kernels/comparison/fn.gt_scalar.html |   4 +-
 arrow/compute/kernels/comparison/fn.gt_utf8.html   |   4 +-
 .../kernels/comparison/fn.gt_utf8_scalar.html      |   4 +-
 arrow/compute/kernels/comparison/fn.ilike.html     |   4 +-
 arrow/compute/kernels/comparison/fn.in_list.html   |   4 +-
 .../kernels/comparison/fn.in_list_utf8.html        |   4 +-
 arrow/compute/kernels/comparison/fn.like.html      |   4 +-
 arrow/compute/kernels/comparison/fn.lt.html        |   4 +-
 arrow/compute/kernels/comparison/fn.lt_binary.html |   4 +-
 .../kernels/comparison/fn.lt_binary_scalar.html    |   4 +-
 arrow/compute/kernels/comparison/fn.lt_bool.html   |   4 +-
 .../kernels/comparison/fn.lt_bool_scalar.html      |   4 +-
 arrow/compute/kernels/comparison/fn.lt_dyn.html    |   4 +-
 .../comparison/fn.lt_dyn_binary_scalar.html        |   4 +-
 .../kernels/comparison/fn.lt_dyn_bool_scalar.html  |   4 +-
 .../kernels/comparison/fn.lt_dyn_scalar.html       |   4 +-
 .../kernels/comparison/fn.lt_dyn_utf8_scalar.html  |   4 +-
 arrow/compute/kernels/comparison/fn.lt_eq.html     |   4 +-
 .../kernels/comparison/fn.lt_eq_binary.html        |   4 +-
 .../kernels/comparison/fn.lt_eq_binary_scalar.html |   4 +-
 .../compute/kernels/comparison/fn.lt_eq_bool.html  |   4 +-
 .../kernels/comparison/fn.lt_eq_bool_scalar.html   |   4 +-
 arrow/compute/kernels/comparison/fn.lt_eq_dyn.html |   4 +-
 .../comparison/fn.lt_eq_dyn_binary_scalar.html     |   4 +-
 .../comparison/fn.lt_eq_dyn_bool_scalar.html       |   4 +-
 .../kernels/comparison/fn.lt_eq_dyn_scalar.html    |   4 +-
 .../comparison/fn.lt_eq_dyn_utf8_scalar.html       |   4 +-
 .../kernels/comparison/fn.lt_eq_scalar.html        |   4 +-
 .../compute/kernels/comparison/fn.lt_eq_utf8.html  |   4 +-
 .../kernels/comparison/fn.lt_eq_utf8_scalar.html   |   4 +-
 arrow/compute/kernels/comparison/fn.lt_scalar.html |   4 +-
 arrow/compute/kernels/comparison/fn.lt_utf8.html   |   4 +-
 .../kernels/comparison/fn.lt_utf8_scalar.html      |   4 +-
 arrow/compute/kernels/comparison/fn.neq.html       |   4 +-
 .../compute/kernels/comparison/fn.neq_binary.html  |   4 +-
 .../kernels/comparison/fn.neq_binary_scalar.html   |   4 +-
 arrow/compute/kernels/comparison/fn.neq_bool.html  |   4 +-
 .../kernels/comparison/fn.neq_bool_scalar.html     |   4 +-
 arrow/compute/kernels/comparison/fn.neq_dyn.html   |   4 +-
 .../comparison/fn.neq_dyn_binary_scalar.html       |   4 +-
 .../kernels/comparison/fn.neq_dyn_bool_scalar.html |   4 +-
 .../kernels/comparison/fn.neq_dyn_scalar.html      |   4 +-
 .../kernels/comparison/fn.neq_dyn_utf8_scalar.html |   4 +-
 .../compute/kernels/comparison/fn.neq_scalar.html  |   4 +-
 arrow/compute/kernels/comparison/fn.neq_utf8.html  |   4 +-
 .../kernels/comparison/fn.neq_utf8_scalar.html     |   4 +-
 arrow/compute/kernels/comparison/fn.nilike.html    |   4 +-
 arrow/compute/kernels/comparison/fn.nlike.html     |   4 +-
 .../comparison/fn.regexp_is_match_utf8.html        |   4 +-
 .../comparison/fn.regexp_is_match_utf8_scalar.html |   4 +-
 .../compute/kernels/comparison/fn.starts_with.html |   4 +-
 arrow/compute/kernels/comparison/fn.unary_cmp.html |   4 +-
 arrow/compute/kernels/comparison/index.html        |   2 +-
 arrow/compute/kernels/concat/fn.concat.html        |   4 +-
 .../compute/kernels/concat/fn.concat_batches.html  |   4 +-
 arrow/compute/kernels/concat/index.html            |   4 +-
 .../concat_elements/fn.concat_element_binary.html  |   4 +-
 .../concat_elements/fn.concat_elements_bytes.html  |   4 +-
 .../concat_elements/fn.concat_elements_dyn.html    |   4 +-
 .../concat_elements/fn.concat_elements_utf8.html   |   4 +-
 .../fn.concat_elements_utf8_many.html              |   4 +-
 arrow/compute/kernels/concat_elements/index.html   |   4 +-
 arrow/compute/kernels/filter/fn.build_filter.html  |   4 +-
 arrow/compute/kernels/filter/fn.filter.html        |   4 +-
 .../kernels/filter/fn.filter_record_batch.html     |   4 +-
 .../kernels/filter/fn.prep_null_mask_filter.html   |   4 +-
 arrow/compute/kernels/filter/index.html            |   4 +-
 .../kernels/filter/struct.FilterBuilder.html       |  20 +-
 .../kernels/filter/struct.FilterPredicate.html     |  18 +-
 .../kernels/filter/struct.SlicesIterator.html      |  12 +-
 arrow/compute/kernels/filter/type.Filter.html      |   4 +-
 arrow/compute/kernels/fn.cast.html                 |   4 +-
 arrow/compute/kernels/index.html                   |   2 +-
 .../compute/kernels/interleave/fn.interleave.html  |   4 +-
 arrow/compute/kernels/interleave/index.html        |   4 +-
 arrow/compute/kernels/length/fn.bit_length.html    |   4 +-
 arrow/compute/kernels/length/fn.length.html        |   4 +-
 arrow/compute/kernels/length/index.html            |   4 +-
 arrow/compute/kernels/nullif/fn.nullif.html        |   4 +-
 arrow/compute/kernels/nullif/index.html            |   4 +-
 arrow/compute/kernels/numeric/fn.add.html          |   4 +-
 arrow/compute/kernels/numeric/fn.add_wrapping.html |   4 +-
 arrow/compute/kernels/numeric/fn.div.html          |   4 +-
 arrow/compute/kernels/numeric/fn.mul.html          |   4 +-
 arrow/compute/kernels/numeric/fn.mul_wrapping.html |   4 +-
 arrow/compute/kernels/numeric/fn.neg.html          |   4 +-
 arrow/compute/kernels/numeric/fn.neg_wrapping.html |   4 +-
 arrow/compute/kernels/numeric/fn.rem.html          |   4 +-
 arrow/compute/kernels/numeric/fn.sub.html          |   4 +-
 arrow/compute/kernels/numeric/fn.sub_wrapping.html |   4 +-
 arrow/compute/kernels/numeric/index.html           |   4 +-
 .../fn.lexicographical_partition_ranges.html       |   4 +-
 arrow/compute/kernels/partition/fn.partition.html  |   4 +-
 arrow/compute/kernels/partition/index.html         |   4 +-
 .../kernels/partition/struct.Partitions.html       |  18 +-
 arrow/compute/kernels/rank/fn.rank.html            |   4 +-
 arrow/compute/kernels/rank/index.html              |   4 +-
 .../kernels/regexp/fn.regexp_is_match_utf8.html    |   4 +-
 .../regexp/fn.regexp_is_match_utf8_scalar.html     |   4 +-
 arrow/compute/kernels/regexp/fn.regexp_match.html  |   4 +-
 arrow/compute/kernels/regexp/index.html            |   4 +-
 arrow/compute/kernels/sort/fn.lexsort.html         |   4 +-
 .../kernels/sort/fn.lexsort_to_indices.html        |   4 +-
 arrow/compute/kernels/sort/fn.partial_sort.html    |   4 +-
 arrow/compute/kernels/sort/fn.sort.html            |   4 +-
 arrow/compute/kernels/sort/fn.sort_limit.html      |   4 +-
 arrow/compute/kernels/sort/fn.sort_to_indices.html |   4 +-
 arrow/compute/kernels/sort/index.html              |   4 +-
 .../sort/struct.LexicographicalComparator.html     |  14 +-
 arrow/compute/kernels/sort/struct.SortColumn.html  |  10 +-
 arrow/compute/kernels/sort/struct.SortOptions.html |  22 +-
 arrow/compute/kernels/substring/fn.substring.html  |   4 +-
 .../kernels/substring/fn.substring_by_char.html    |   4 +-
 arrow/compute/kernels/substring/index.html         |   4 +-
 arrow/compute/kernels/take/fn.take.html            |   4 +-
 .../compute/kernels/take/fn.take_record_batch.html |   4 +-
 arrow/compute/kernels/take/index.html              |   4 +-
 arrow/compute/kernels/take/struct.TakeOptions.html |  12 +-
 arrow/compute/kernels/temporal/enum.DatePart.html  |  14 +-
 arrow/compute/kernels/temporal/fn.date_part.html   |   4 +-
 arrow/compute/kernels/temporal/fn.day.html         |   4 +-
 arrow/compute/kernels/temporal/fn.day_dyn.html     |   4 +-
 arrow/compute/kernels/temporal/fn.doy.html         |   4 +-
 arrow/compute/kernels/temporal/fn.doy_dyn.html     |   4 +-
 arrow/compute/kernels/temporal/fn.hour.html        |   4 +-
 arrow/compute/kernels/temporal/fn.hour_dyn.html    |   4 +-
 arrow/compute/kernels/temporal/fn.microsecond.html |   4 +-
 .../kernels/temporal/fn.microsecond_dyn.html       |   4 +-
 arrow/compute/kernels/temporal/fn.millisecond.html |   4 +-
 .../kernels/temporal/fn.millisecond_dyn.html       |   4 +-
 arrow/compute/kernels/temporal/fn.minute.html      |   4 +-
 arrow/compute/kernels/temporal/fn.minute_dyn.html  |   4 +-
 arrow/compute/kernels/temporal/fn.month.html       |   4 +-
 arrow/compute/kernels/temporal/fn.month_dyn.html   |   4 +-
 arrow/compute/kernels/temporal/fn.nanosecond.html  |   4 +-
 .../kernels/temporal/fn.nanosecond_dyn.html        |   4 +-
 .../kernels/temporal/fn.num_days_from_monday.html  |   4 +-
 .../temporal/fn.num_days_from_monday_dyn.html      |   4 +-
 .../kernels/temporal/fn.num_days_from_sunday.html  |   4 +-
 .../temporal/fn.num_days_from_sunday_dyn.html      |   4 +-
 arrow/compute/kernels/temporal/fn.quarter.html     |   4 +-
 arrow/compute/kernels/temporal/fn.quarter_dyn.html |   4 +-
 arrow/compute/kernels/temporal/fn.second.html      |   4 +-
 arrow/compute/kernels/temporal/fn.second_dyn.html  |   4 +-
 ...fn.using_chrono_tz_and_utc_naive_date_time.html |   4 +-
 arrow/compute/kernels/temporal/fn.week.html        |   4 +-
 arrow/compute/kernels/temporal/fn.week_dyn.html    |   4 +-
 arrow/compute/kernels/temporal/fn.year.html        |   4 +-
 arrow/compute/kernels/temporal/fn.year_dyn.html    |   4 +-
 arrow/compute/kernels/temporal/index.html          |   4 +-
 arrow/compute/kernels/window/fn.shift.html         |   4 +-
 arrow/compute/kernels/window/index.html            |   4 +-
 arrow/compute/kernels/zip/fn.zip.html              |   4 +-
 arrow/compute/kernels/zip/index.html               |   4 +-
 arrow/compute/struct.CastOptions.html              |  16 +-
 arrow/compute/struct.FilterBuilder.html            |  20 +-
 arrow/compute/struct.FilterPredicate.html          |  18 +-
 .../compute/struct.LexicographicalComparator.html  |  14 +-
 arrow/compute/struct.Partitions.html               |  18 +-
 arrow/compute/struct.SlicesIterator.html           |  12 +-
 arrow/compute/struct.SortColumn.html               |  10 +-
 arrow/compute/struct.SortOptions.html              |  22 +-
 arrow/compute/struct.TakeOptions.html              |  12 +-
 arrow/compute/type.Filter.html                     |   4 +-
 .../constant.DECIMAL128_MAX_PRECISION.html         |   4 +-
 arrow/datatypes/constant.DECIMAL128_MAX_SCALE.html |   4 +-
 .../constant.DECIMAL256_MAX_PRECISION.html         |   4 +-
 arrow/datatypes/constant.DECIMAL256_MAX_SCALE.html |   4 +-
 .../datatypes/constant.DECIMAL_DEFAULT_SCALE.html  |   4 +-
 .../constant.MAX_DECIMAL_FOR_EACH_PRECISION.html   |   4 +-
 .../constant.MIN_DECIMAL_FOR_EACH_PRECISION.html   |   4 +-
 arrow/datatypes/enum.DataType.html                 |  64 +--
 arrow/datatypes/enum.IntervalUnit.html             |  24 +-
 arrow/datatypes/enum.TimeUnit.html                 |  24 +-
 arrow/datatypes/enum.UnionMode.html                |  24 +-
 .../fn.validate_decimal256_precision.html          |   4 +-
 arrow/datatypes/fn.validate_decimal_precision.html |   4 +-
 .../fn.validate_decimal_precision_and_scale.html   |   4 +-
 arrow/datatypes/index.html                         |   2 +-
 arrow/datatypes/struct.BooleanType.html            |  14 +-
 arrow/datatypes/struct.Date32Type.html             |  30 +-
 arrow/datatypes/struct.Date64Type.html             |  30 +-
 arrow/datatypes/struct.Decimal128Type.html         |  16 +-
 arrow/datatypes/struct.Decimal256Type.html         |  16 +-
 .../datatypes/struct.DurationMicrosecondType.html  |  14 +-
 .../datatypes/struct.DurationMillisecondType.html  |  14 +-
 arrow/datatypes/struct.DurationNanosecondType.html |  14 +-
 arrow/datatypes/struct.DurationSecondType.html     |  14 +-
 arrow/datatypes/struct.Field.html                  |  78 ++--
 arrow/datatypes/struct.Fields.html                 | 204 +++++-----
 arrow/datatypes/struct.Float16Type.html            |  14 +-
 arrow/datatypes/struct.Float32Type.html            |  14 +-
 arrow/datatypes/struct.Float64Type.html            |  14 +-
 arrow/datatypes/struct.GenericBinaryType.html      |  14 +-
 arrow/datatypes/struct.GenericStringType.html      |  14 +-
 arrow/datatypes/struct.Int16Type.html              |  14 +-
 arrow/datatypes/struct.Int32Type.html              |  14 +-
 arrow/datatypes/struct.Int64Type.html              |  14 +-
 arrow/datatypes/struct.Int8Type.html               |  14 +-
 arrow/datatypes/struct.IntervalDayTimeType.html    |  18 +-
 .../datatypes/struct.IntervalMonthDayNanoType.html |  18 +-
 arrow/datatypes/struct.IntervalYearMonthType.html  |  18 +-
 arrow/datatypes/struct.Schema.html                 |  50 +--
 arrow/datatypes/struct.SchemaBuilder.html          |  38 +-
 arrow/datatypes/struct.Time32MillisecondType.html  |  18 +-
 arrow/datatypes/struct.Time32SecondType.html       |  18 +-
 arrow/datatypes/struct.Time64MicrosecondType.html  |  18 +-
 arrow/datatypes/struct.Time64NanosecondType.html   |  18 +-
 .../datatypes/struct.TimestampMicrosecondType.html |  26 +-
 .../datatypes/struct.TimestampMillisecondType.html |  26 +-
 .../datatypes/struct.TimestampNanosecondType.html  |  26 +-
 arrow/datatypes/struct.TimestampSecondType.html    |  26 +-
 arrow/datatypes/struct.UInt16Type.html             |  14 +-
 arrow/datatypes/struct.UInt32Type.html             |  14 +-
 arrow/datatypes/struct.UInt64Type.html             |  14 +-
 arrow/datatypes/struct.UInt8Type.html              |  14 +-
 arrow/datatypes/struct.UnionFields.html            |  38 +-
 arrow/datatypes/struct.i256.html                   | 100 ++---
 arrow/datatypes/trait.ArrowDictionaryKeyType.html  |   6 +-
 arrow/datatypes/trait.ArrowNativeType.html         |  22 +-
 arrow/datatypes/trait.ArrowNativeTypeOp.html       |  58 +--
 arrow/datatypes/trait.ArrowNumericType.html        |   6 +-
 arrow/datatypes/trait.ArrowPrimitiveType.html      |  14 +-
 arrow/datatypes/trait.ArrowTemporalType.html       |   6 +-
 arrow/datatypes/trait.ArrowTimestampType.html      |  12 +-
 arrow/datatypes/trait.ByteArrayType.html           |  22 +-
 arrow/datatypes/trait.DecimalType.html             |  22 +-
 arrow/datatypes/trait.RunEndIndexType.html         |   6 +-
 arrow/datatypes/trait.ToByteSlice.html             |  10 +-
 arrow/datatypes/type.BinaryType.html               |   4 +-
 arrow/datatypes/type.FieldRef.html                 |   4 +-
 arrow/datatypes/type.LargeBinaryType.html          |   4 +-
 arrow/datatypes/type.LargeUtf8Type.html            |   4 +-
 arrow/datatypes/type.SchemaRef.html                |   4 +-
 arrow/datatypes/type.Utf8Type.html                 |   4 +-
 arrow/error/enum.ArrowError.html                   |  18 +-
 arrow/error/index.html                             |   2 +-
 arrow/error/type.Result.html                       |   2 +-
 arrow/ffi/fn.bit_width.html                        |   2 +-
 arrow/ffi/fn.create_buffer.html                    |   2 +-
 arrow/ffi/fn.from_ffi.html                         |   2 +-
 arrow/ffi/fn.from_ffi_and_data_type.html           |   2 +-
 arrow/ffi/fn.to_ffi.html                           |   2 +-
 arrow/ffi/index.html                               |   2 +-
 arrow/ffi/struct.FFI_ArrowArray.html               |  38 +-
 arrow/ffi/struct.FFI_ArrowSchema.html              |  26 +-
 arrow/ffi/struct.Flags.html                        |  78 ++--
 arrow/ffi/struct.ImportedArrowArray.html           |   8 +-
 arrow/ffi_stream/constant.EINVAL.html              |   2 +-
 arrow/ffi_stream/constant.EIO.html                 |   2 +-
 arrow/ffi_stream/constant.ENOMEM.html              |   2 +-
 arrow/ffi_stream/constant.ENOSYS.html              |   2 +-
 arrow/ffi_stream/fn.export_reader_into_raw.html    |   2 +-
 arrow/ffi_stream/fn.get_error_code.html            |   2 +-
 arrow/ffi_stream/fn.get_last_error.html            |   2 +-
 arrow/ffi_stream/fn.get_next.html                  |   2 +-
 arrow/ffi_stream/fn.get_schema.html                |   2 +-
 arrow/ffi_stream/fn.get_stream_schema.html         |   2 +-
 arrow/ffi_stream/fn.release_stream.html            |   2 +-
 arrow/ffi_stream/index.html                        |   2 +-
 .../ffi_stream/struct.ArrowArrayStreamReader.html  |   8 +-
 arrow/ffi_stream/struct.ExportedArrayStream.html   |   6 +-
 arrow/ffi_stream/struct.FFI_ArrowArrayStream.html  |   6 +-
 arrow/ffi_stream/struct.StreamPrivateData.html     |   6 +-
 arrow/index.html                                   |  34 +-
 arrow/macro.downcast_dictionary_array.html         |   4 +-
 arrow/macro.downcast_primitive_array.html          |   4 +-
 arrow/pyarrow/fn.to_py_err.html                    |   2 +-
 arrow/pyarrow/fn.validate_class.html               |   2 +-
 arrow/pyarrow/fn.validate_pycapsule.html           |   2 +-
 arrow/pyarrow/index.html                           |   2 +-
 arrow/pyarrow/struct.ArrowException.html           |   8 +-
 arrow/pyarrow/struct.PyArrowType.html              |   8 +-
 arrow/pyarrow/trait.FromPyArrow.html               |   4 +-
 arrow/pyarrow/trait.IntoPyArrow.html               |   2 +-
 arrow/pyarrow/trait.ToPyArrow.html                 |   4 +-
 arrow/pyarrow/type.PyArrowException.html           |   2 +-
 arrow/record_batch/index.html                      |   2 +-
 arrow/record_batch/struct.RecordBatch.html         |  46 +--
 arrow/record_batch/struct.RecordBatchIterator.html |  22 +-
 arrow/record_batch/struct.RecordBatchOptions.html  |  18 +-
 arrow/record_batch/trait.RecordBatchReader.html    |  20 +-
 arrow/record_batch/trait.RecordBatchWriter.html    |  16 +-
 .../constant.EPOCH_DAYS_FROM_CE.html               |   4 +-
 .../constant.MICROSECONDS.html                     |   4 +-
 .../constant.MICROSECONDS_IN_DAY.html              |   4 +-
 .../constant.MILLISECONDS.html                     |   4 +-
 .../constant.MILLISECONDS_IN_DAY.html              |   4 +-
 .../temporal_conversions/constant.NANOSECONDS.html |   4 +-
 .../constant.NANOSECONDS_IN_DAY.html               |   4 +-
 .../constant.SECONDS_IN_DAY.html                   |   4 +-
 arrow/temporal_conversions/fn.as_date.html         |   4 +-
 arrow/temporal_conversions/fn.as_datetime.html     |   4 +-
 .../fn.as_datetime_with_timezone.html              |   4 +-
 arrow/temporal_conversions/fn.as_duration.html     |   4 +-
 arrow/temporal_conversions/fn.as_time.html         |   4 +-
 .../fn.date32_to_datetime.html                     |   4 +-
 .../fn.date64_to_datetime.html                     |   4 +-
 .../fn.duration_ms_to_duration.html                |   4 +-
 .../fn.duration_ns_to_duration.html                |   4 +-
 .../fn.duration_s_to_duration.html                 |   4 +-
 .../fn.duration_us_to_duration.html                |   4 +-
 .../temporal_conversions/fn.time32ms_to_time.html  |   4 +-
 arrow/temporal_conversions/fn.time32s_to_time.html |   4 +-
 .../temporal_conversions/fn.time64ns_to_time.html  |   4 +-
 .../temporal_conversions/fn.time64us_to_time.html  |   4 +-
 .../temporal_conversions/fn.time_to_time32ms.html  |   4 +-
 arrow/temporal_conversions/fn.time_to_time32s.html |   4 +-
 .../temporal_conversions/fn.time_to_time64ns.html  |   4 +-
 .../temporal_conversions/fn.time_to_time64us.html  |   4 +-
 .../fn.timestamp_ms_to_datetime.html               |   4 +-
 .../fn.timestamp_ns_to_datetime.html               |   4 +-
 .../fn.timestamp_s_to_datetime.html                |   4 +-
 .../fn.timestamp_us_to_datetime.html               |   4 +-
 arrow/temporal_conversions/index.html              |   4 +-
 arrow/tensor/fn.compute_column_major_strides.html  |   2 +-
 arrow/tensor/fn.compute_row_major_strides.html     |   2 +-
 arrow/tensor/index.html                            |   2 +-
 arrow/tensor/struct.Tensor.html                    |   8 +-
 arrow/tensor/type.BooleanTensor.html               |   2 +-
 arrow/tensor/type.Date32Tensor.html                |   2 +-
 arrow/tensor/type.Date64Tensor.html                |   2 +-
 arrow/tensor/type.Decimal128Tensor.html            |   2 +-
 arrow/tensor/type.Decimal256Tensor.html            |   2 +-
 arrow/tensor/type.DurationMicrosecondTensor.html   |   2 +-
 arrow/tensor/type.DurationMillisecondTensor.html   |   2 +-
 arrow/tensor/type.DurationNanosecondTensor.html    |   2 +-
 arrow/tensor/type.DurationSecondTensor.html        |   2 +-
 arrow/tensor/type.Float16Tensor.html               |   2 +-
 arrow/tensor/type.Float32Tensor.html               |   2 +-
 arrow/tensor/type.Float64Tensor.html               |   2 +-
 arrow/tensor/type.Int16Tensor.html                 |   2 +-
 arrow/tensor/type.Int32Tensor.html                 |   2 +-
 arrow/tensor/type.Int64Tensor.html                 |   2 +-
 arrow/tensor/type.Int8Tensor.html                  |   2 +-
 arrow/tensor/type.IntervalDayTimeTensor.html       |   2 +-
 arrow/tensor/type.IntervalMonthDayNanoTensor.html  |   2 +-
 arrow/tensor/type.IntervalYearMonthTensor.html     |   2 +-
 arrow/tensor/type.Time32MillisecondTensor.html     |   2 +-
 arrow/tensor/type.Time32SecondTensor.html          |   2 +-
 arrow/tensor/type.Time64MicrosecondTensor.html     |   2 +-
 arrow/tensor/type.Time64NanosecondTensor.html      |   2 +-
 arrow/tensor/type.TimestampMicrosecondTensor.html  |   2 +-
 arrow/tensor/type.TimestampMillisecondTensor.html  |   2 +-
 arrow/tensor/type.TimestampNanosecondTensor.html   |   2 +-
 arrow/tensor/type.TimestampSecondTensor.html       |   2 +-
 arrow/tensor/type.UInt16Tensor.html                |   2 +-
 arrow/tensor/type.UInt32Tensor.html                |   2 +-
 arrow/tensor/type.UInt64Tensor.html                |   2 +-
 arrow/tensor/type.UInt8Tensor.html                 |   2 +-
 arrow/util/bench_util/fn.create_binary_array.html  |   2 +-
 arrow/util/bench_util/fn.create_boolean_array.html |   2 +-
 .../bench_util/fn.create_dict_from_values.html     |   2 +-
 arrow/util/bench_util/fn.create_fsb_array.html     |   2 +-
 .../util/bench_util/fn.create_primitive_array.html |   2 +-
 .../fn.create_primitive_array_with_seed.html       |   2 +-
 .../bench_util/fn.create_primitive_run_array.html  |   2 +-
 .../fn.create_sparse_dict_from_values.html         |   2 +-
 arrow/util/bench_util/fn.create_string_array.html  |   2 +-
 .../fn.create_string_array_for_runs.html           |   2 +-
 .../fn.create_string_array_with_len.html           |   2 +-
 .../bench_util/fn.create_string_dict_array.html    |   2 +-
 arrow/util/bench_util/index.html                   |   2 +-
 arrow/util/bit_chunk_iterator/index.html           |   4 +-
 .../struct.BitChunkIterator.html                   |  12 +-
 .../util/bit_chunk_iterator/struct.BitChunks.html  |  22 +-
 .../struct.UnalignedBitChunk.html                  |  18 +-
 .../type.UnalignedBitChunkIterator.html            |   4 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   4 +-
 arrow/util/bit_iterator/index.html                 |   4 +-
 .../util/bit_iterator/struct.BitIndexIterator.html |  14 +-
 arrow/util/bit_iterator/struct.BitIterator.html    |  16 +-
 .../util/bit_iterator/struct.BitSliceIterator.html |  14 +-
 arrow/util/bit_mask/fn.set_bits.html               |   4 +-
 arrow/util/bit_mask/index.html                     |   4 +-
 arrow/util/bit_util/fn.ceil.html                   |   4 +-
 arrow/util/bit_util/fn.get_bit.html                |   4 +-
 arrow/util/bit_util/fn.get_bit_raw.html            |   4 +-
 .../bit_util/fn.round_upto_multiple_of_64.html     |   4 +-
 arrow/util/bit_util/fn.round_upto_power_of_2.html  |   4 +-
 arrow/util/bit_util/fn.set_bit.html                |   4 +-
 arrow/util/bit_util/fn.set_bit_raw.html            |   4 +-
 arrow/util/bit_util/fn.unset_bit.html              |   4 +-
 arrow/util/bit_util/fn.unset_bit_raw.html          |   4 +-
 arrow/util/bit_util/index.html                     |   4 +-
 arrow/util/data_gen/fn.create_random_array.html    |   2 +-
 arrow/util/data_gen/fn.create_random_batch.html    |   2 +-
 .../util/data_gen/fn.create_random_list_array.html |   2 +-
 .../data_gen/fn.create_random_null_buffer.html     |   2 +-
 arrow/util/data_gen/fn.create_random_offsets.html  |   2 +-
 arrow/util/data_gen/index.html                     |   2 +-
 arrow/util/display/enum.DurationFormat.html        |  16 +-
 arrow/util/display/fn.array_value_to_string.html   |   4 +-
 arrow/util/display/fn.lexical_to_string.html       |   4 +-
 arrow/util/display/index.html                      |   4 +-
 arrow/util/display/struct.ArrayFormatter.html      |  14 +-
 arrow/util/display/struct.FormatOptions.html       |  32 +-
 arrow/util/display/struct.ValueFormatter.html      |  14 +-
 arrow/util/index.html                              |   2 +-
 arrow/util/pretty/fn.pretty_format_batches.html    |   4 +-
 .../fn.pretty_format_batches_with_options.html     |   4 +-
 arrow/util/pretty/fn.pretty_format_columns.html    |   4 +-
 .../fn.pretty_format_columns_with_options.html     |   4 +-
 arrow/util/pretty/fn.print_batches.html            |   4 +-
 arrow/util/pretty/fn.print_columns.html            |   4 +-
 arrow/util/pretty/index.html                       |   4 +-
 arrow/util/string_writer/index.html                |   2 +-
 arrow/util/string_writer/struct.StringWriter.html  |   8 +-
 arrow/util/test_util/fn.arrow_test_data.html       |   2 +-
 arrow/util/test_util/fn.get_data_dir.html          |   2 +-
 arrow/util/test_util/fn.get_temp_file.html         |   2 +-
 arrow/util/test_util/fn.parquet_test_data.html     |   2 +-
 arrow/util/test_util/fn.random_bytes.html          |   2 +-
 arrow/util/test_util/fn.seedable_rng.html          |   2 +-
 arrow/util/test_util/index.html                    |   2 +-
 arrow/util/test_util/struct.BadIterator.html       |   8 +-
 .../aggregate/constant.PREFERRED_VECTOR_SIZE.html  |   2 +-
 .../constant.PREFERRED_VECTOR_SIZE_NON_NULL.html   |   2 +-
 arrow_arith/aggregate/fn.aggregate.html            |   2 +-
 .../aggregate/fn.aggregate_nonnull_chunk.html      |   2 +-
 .../aggregate/fn.aggregate_nonnull_lanes.html      |   2 +-
 .../aggregate/fn.aggregate_nonnull_simple.html     |   2 +-
 .../aggregate/fn.aggregate_nullable_chunk.html     |   2 +-
 .../aggregate/fn.aggregate_nullable_lanes.html     |   2 +-
 arrow_arith/aggregate/fn.bit_and.html              |   2 +-
 arrow_arith/aggregate/fn.bit_or.html               |   2 +-
 arrow_arith/aggregate/fn.bit_xor.html              |   2 +-
 arrow_arith/aggregate/fn.bool_and.html             |   2 +-
 arrow_arith/aggregate/fn.bool_or.html              |   2 +-
 arrow_arith/aggregate/fn.max.html                  |   2 +-
 arrow_arith/aggregate/fn.max_array.html            |   2 +-
 arrow_arith/aggregate/fn.max_binary.html           |   2 +-
 arrow_arith/aggregate/fn.max_boolean.html          |   2 +-
 arrow_arith/aggregate/fn.max_string.html           |   2 +-
 arrow_arith/aggregate/fn.min.html                  |   2 +-
 arrow_arith/aggregate/fn.min_array.html            |   2 +-
 arrow_arith/aggregate/fn.min_binary.html           |   2 +-
 arrow_arith/aggregate/fn.min_boolean.html          |   2 +-
 arrow_arith/aggregate/fn.min_max_array_helper.html |   2 +-
 arrow_arith/aggregate/fn.min_max_helper.html       |   2 +-
 arrow_arith/aggregate/fn.min_string.html           |   2 +-
 arrow_arith/aggregate/fn.reduce_accumulators.html  |   2 +-
 arrow_arith/aggregate/fn.select.html               |   2 +-
 arrow_arith/aggregate/fn.sum.html                  |   2 +-
 arrow_arith/aggregate/fn.sum_array.html            |   2 +-
 arrow_arith/aggregate/fn.sum_array_checked.html    |   2 +-
 arrow_arith/aggregate/fn.sum_checked.html          |   2 +-
 arrow_arith/aggregate/index.html                   |   2 +-
 arrow_arith/aggregate/macro.bit_operation.html     |   2 +-
 arrow_arith/aggregate/struct.MaxAccumulator.html   |   6 +-
 arrow_arith/aggregate/struct.MinAccumulator.html   |   6 +-
 arrow_arith/aggregate/struct.SumAccumulator.html   |   6 +-
 .../aggregate/trait.NumericAccumulator.html        |   2 +-
 arrow_arith/all.html                               |   2 +-
 arrow_arith/arity/fn.binary.html                   |   2 +-
 arrow_arith/arity/fn.binary_mut.html               |   2 +-
 arrow_arith/arity/fn.try_binary.html               |   2 +-
 arrow_arith/arity/fn.try_binary_mut.html           |   2 +-
 arrow_arith/arity/fn.try_binary_no_nulls.html      |   2 +-
 arrow_arith/arity/fn.try_binary_no_nulls_mut.html  |   2 +-
 arrow_arith/arity/fn.try_unary.html                |   2 +-
 arrow_arith/arity/fn.try_unary_dict.html           |   2 +-
 arrow_arith/arity/fn.try_unary_dyn.html            |   2 +-
 arrow_arith/arity/fn.try_unary_mut.html            |   2 +-
 arrow_arith/arity/fn.unary.html                    |   2 +-
 arrow_arith/arity/fn.unary_dict.html               |   2 +-
 arrow_arith/arity/fn.unary_dyn.html                |   2 +-
 arrow_arith/arity/fn.unary_mut.html                |   2 +-
 arrow_arith/arity/index.html                       |   2 +-
 arrow_arith/bitwise/fn.bitwise_and.html            |   2 +-
 arrow_arith/bitwise/fn.bitwise_and_not.html        |   2 +-
 arrow_arith/bitwise/fn.bitwise_and_scalar.html     |   2 +-
 arrow_arith/bitwise/fn.bitwise_not.html            |   2 +-
 arrow_arith/bitwise/fn.bitwise_op.html             |   2 +-
 arrow_arith/bitwise/fn.bitwise_or.html             |   2 +-
 arrow_arith/bitwise/fn.bitwise_or_scalar.html      |   2 +-
 arrow_arith/bitwise/fn.bitwise_shift_left.html     |   2 +-
 .../bitwise/fn.bitwise_shift_left_scalar.html      |   2 +-
 arrow_arith/bitwise/fn.bitwise_shift_right.html    |   2 +-
 .../bitwise/fn.bitwise_shift_right_scalar.html     |   2 +-
 arrow_arith/bitwise/fn.bitwise_xor.html            |   2 +-
 arrow_arith/bitwise/fn.bitwise_xor_scalar.html     |   2 +-
 arrow_arith/bitwise/index.html                     |   2 +-
 arrow_arith/boolean/fn.and.html                    |   2 +-
 arrow_arith/boolean/fn.and_kleene.html             |   2 +-
 arrow_arith/boolean/fn.and_not.html                |   2 +-
 arrow_arith/boolean/fn.binary_boolean_kernel.html  |   2 +-
 arrow_arith/boolean/fn.is_not_null.html            |   2 +-
 arrow_arith/boolean/fn.is_null.html                |   2 +-
 arrow_arith/boolean/fn.not.html                    |   2 +-
 arrow_arith/boolean/fn.or.html                     |   2 +-
 arrow_arith/boolean/fn.or_kleene.html              |   2 +-
 arrow_arith/boolean/index.html                     |   2 +-
 arrow_arith/index.html                             |   2 +-
 arrow_arith/numeric/enum.Op.html                   |   8 +-
 arrow_arith/numeric/fn.add.html                    |   2 +-
 arrow_arith/numeric/fn.add_wrapping.html           |   2 +-
 arrow_arith/numeric/fn.arithmetic_op.html          |   2 +-
 arrow_arith/numeric/fn.date_op.html                |   2 +-
 arrow_arith/numeric/fn.decimal_op.html             |   2 +-
 arrow_arith/numeric/fn.div.html                    |   2 +-
 arrow_arith/numeric/fn.duration_op.html            |   2 +-
 arrow_arith/numeric/fn.float_op.html               |   2 +-
 arrow_arith/numeric/fn.integer_op.html             |   2 +-
 arrow_arith/numeric/fn.interval_op.html            |   2 +-
 arrow_arith/numeric/fn.mul.html                    |   2 +-
 arrow_arith/numeric/fn.mul_wrapping.html           |   2 +-
 arrow_arith/numeric/fn.neg.html                    |   2 +-
 arrow_arith/numeric/fn.neg_wrapping.html           |   2 +-
 arrow_arith/numeric/fn.rem.html                    |   2 +-
 arrow_arith/numeric/fn.sub.html                    |   2 +-
 arrow_arith/numeric/fn.sub_wrapping.html           |   2 +-
 arrow_arith/numeric/fn.timestamp_op.html           |   2 +-
 arrow_arith/numeric/index.html                     |   2 +-
 arrow_arith/numeric/macro.date.html                |   2 +-
 arrow_arith/numeric/macro.neg_checked.html         |   2 +-
 arrow_arith/numeric/macro.neg_wrapping.html        |   2 +-
 arrow_arith/numeric/macro.op.html                  |   2 +-
 arrow_arith/numeric/macro.op_ref.html              |   2 +-
 arrow_arith/numeric/macro.timestamp.html           |   2 +-
 arrow_arith/numeric/macro.try_op.html              |   2 +-
 arrow_arith/numeric/macro.try_op_ref.html          |   2 +-
 arrow_arith/numeric/trait.DateOp.html              |   2 +-
 arrow_arith/numeric/trait.IntervalOp.html          |   2 +-
 arrow_arith/numeric/trait.TimestampOp.html         |   2 +-
 arrow_arith/temporal/enum.DatePart.html            |   8 +-
 arrow_arith/temporal/fn.date_part.html             |   2 +-
 arrow_arith/temporal/fn.date_part_primitive.html   |   2 +-
 arrow_arith/temporal/fn.day.html                   |   2 +-
 arrow_arith/temporal/fn.day_dyn.html               |   2 +-
 arrow_arith/temporal/fn.doy.html                   |   2 +-
 arrow_arith/temporal/fn.doy_dyn.html               |   2 +-
 .../temporal/fn.get_date_time_part_extract_fn.html |   2 +-
 arrow_arith/temporal/fn.get_tz.html                |   2 +-
 arrow_arith/temporal/fn.hour.html                  |   2 +-
 arrow_arith/temporal/fn.hour_dyn.html              |   2 +-
 arrow_arith/temporal/fn.microsecond.html           |   2 +-
 arrow_arith/temporal/fn.microsecond_dyn.html       |   2 +-
 arrow_arith/temporal/fn.millisecond.html           |   2 +-
 arrow_arith/temporal/fn.millisecond_dyn.html       |   2 +-
 arrow_arith/temporal/fn.minute.html                |   2 +-
 arrow_arith/temporal/fn.minute_dyn.html            |   2 +-
 arrow_arith/temporal/fn.month.html                 |   2 +-
 arrow_arith/temporal/fn.month_dyn.html             |   2 +-
 arrow_arith/temporal/fn.nanosecond.html            |   2 +-
 arrow_arith/temporal/fn.nanosecond_dyn.html        |   2 +-
 arrow_arith/temporal/fn.num_days_from_monday.html  |   2 +-
 .../temporal/fn.num_days_from_monday_dyn.html      |   2 +-
 arrow_arith/temporal/fn.num_days_from_sunday.html  |   2 +-
 .../temporal/fn.num_days_from_sunday_dyn.html      |   2 +-
 arrow_arith/temporal/fn.quarter.html               |   2 +-
 arrow_arith/temporal/fn.quarter_dyn.html           |   2 +-
 arrow_arith/temporal/fn.second.html                |   2 +-
 arrow_arith/temporal/fn.second_dyn.html            |   2 +-
 ...fn.using_chrono_tz_and_utc_naive_date_time.html |   2 +-
 arrow_arith/temporal/fn.week.html                  |   2 +-
 arrow_arith/temporal/fn.week_dyn.html              |   2 +-
 arrow_arith/temporal/fn.year.html                  |   2 +-
 arrow_arith/temporal/fn.year_dyn.html              |   2 +-
 arrow_arith/temporal/index.html                    |   2 +-
 .../temporal/macro.return_compute_error_with.html  |   2 +-
 arrow_arith/temporal/trait.ChronoDateExt.html      |   2 +-
 arrow_arith/temporal/trait.ExtractDatePartExt.html |   2 +-
 arrow_array/all.html                               |   2 +-
 arrow_array/arithmetic/index.html                  |   2 +-
 .../arithmetic/macro.native_type_float_op.html     |   2 +-
 arrow_array/arithmetic/macro.native_type_op.html   |   2 +-
 .../arithmetic/trait.ArrowNativeTypeOp.html        |   4 +-
 arrow_array/array/binary_array/index.html          |   2 +-
 .../array/binary_array/type.BinaryArray.html       |   2 +-
 .../binary_array/type.GenericBinaryArray.html      |   4 +-
 .../array/binary_array/type.LargeBinaryArray.html  |   2 +-
 arrow_array/array/boolean_array/index.html         |   2 +-
 .../array/boolean_array/struct.BooleanArray.html   |   8 +-
 arrow_array/array/byte_array/index.html            |   2 +-
 .../array/byte_array/struct.GenericByteArray.html  |  12 +-
 arrow_array/array/dictionary_array/index.html      |   2 +-
 .../dictionary_array/struct.DictionaryArray.html   |  14 +-
 .../struct.TypedDictionaryArray.html               |   6 +-
 .../dictionary_array/trait.AnyDictionaryArray.html |   2 +-
 .../type.Int16DictionaryArray.html                 |   2 +-
 .../type.Int32DictionaryArray.html                 |   2 +-
 .../type.Int64DictionaryArray.html                 |   2 +-
 .../dictionary_array/type.Int8DictionaryArray.html |   2 +-
 .../type.UInt16DictionaryArray.html                |   2 +-
 .../type.UInt32DictionaryArray.html                |   2 +-
 .../type.UInt64DictionaryArray.html                |   2 +-
 .../type.UInt8DictionaryArray.html                 |   2 +-
 .../array/fixed_size_binary_array/index.html       |   2 +-
 .../struct.FixedSizeBinaryArray.html               |  10 +-
 arrow_array/array/fixed_size_list_array/index.html |   2 +-
 .../struct.FixedSizeListArray.html                 |  10 +-
 arrow_array/array/fn.get_offsets.html              |   2 +-
 arrow_array/array/fn.make_array.html               |   2 +-
 arrow_array/array/fn.new_empty_array.html          |   2 +-
 arrow_array/array/fn.new_null_array.html           |   2 +-
 arrow_array/array/fn.print_long_array.html         |   2 +-
 arrow_array/array/index.html                       |   2 +-
 arrow_array/array/list_array/index.html            |   2 +-
 .../array/list_array/struct.GenericListArray.html  |   8 +-
 .../array/list_array/trait.OffsetSizeTrait.html    |   2 +-
 .../array/list_array/type.LargeListArray.html      |   2 +-
 arrow_array/array/list_array/type.ListArray.html   |   2 +-
 arrow_array/array/map_array/index.html             |   2 +-
 arrow_array/array/map_array/struct.MapArray.html   |   6 +-
 arrow_array/array/null_array/index.html            |   2 +-
 arrow_array/array/null_array/struct.NullArray.html |   8 +-
 arrow_array/array/primitive_array/index.html       |   2 +-
 .../macro.def_from_for_primitive.html              |   2 +-
 .../macro.def_numeric_from_vec.html                |   2 +-
 .../primitive_array/struct.NativeAdapter.html      |   8 +-
 .../primitive_array/struct.PrimitiveArray.html     |  60 +--
 .../array/primitive_array/type.Date32Array.html    |   2 +-
 .../array/primitive_array/type.Date64Array.html    |   2 +-
 .../primitive_array/type.Decimal128Array.html      |   2 +-
 .../primitive_array/type.Decimal256Array.html      |   2 +-
 .../type.DurationMicrosecondArray.html             |   2 +-
 .../type.DurationMillisecondArray.html             |   2 +-
 .../type.DurationNanosecondArray.html              |   2 +-
 .../primitive_array/type.DurationSecondArray.html  |   2 +-
 .../array/primitive_array/type.Float16Array.html   |   2 +-
 .../array/primitive_array/type.Float32Array.html   |   2 +-
 .../array/primitive_array/type.Float64Array.html   |   2 +-
 .../array/primitive_array/type.Int16Array.html     |   2 +-
 .../array/primitive_array/type.Int32Array.html     |   2 +-
 .../array/primitive_array/type.Int64Array.html     |   2 +-
 .../array/primitive_array/type.Int8Array.html      |   2 +-
 .../primitive_array/type.IntervalDayTimeArray.html |   2 +-
 .../type.IntervalMonthDayNanoArray.html            |   2 +-
 .../type.IntervalYearMonthArray.html               |   2 +-
 .../type.Time32MillisecondArray.html               |   2 +-
 .../primitive_array/type.Time32SecondArray.html    |   2 +-
 .../type.Time64MicrosecondArray.html               |   2 +-
 .../type.Time64NanosecondArray.html                |   2 +-
 .../type.TimestampMicrosecondArray.html            |   2 +-
 .../type.TimestampMillisecondArray.html            |   2 +-
 .../type.TimestampNanosecondArray.html             |   2 +-
 .../primitive_array/type.TimestampSecondArray.html |   2 +-
 .../array/primitive_array/type.UInt16Array.html    |   2 +-
 .../array/primitive_array/type.UInt32Array.html    |   2 +-
 .../array/primitive_array/type.UInt64Array.html    |   2 +-
 .../array/primitive_array/type.UInt8Array.html     |   2 +-
 arrow_array/array/run_array/index.html             |   2 +-
 arrow_array/array/run_array/struct.RunArray.html   |  14 +-
 .../array/run_array/struct.TypedRunArray.html      |  10 +-
 .../array/run_array/type.Int16RunArray.html        |   2 +-
 .../array/run_array/type.Int32RunArray.html        |   2 +-
 .../array/run_array/type.Int64RunArray.html        |   2 +-
 arrow_array/array/string_array/index.html          |   2 +-
 .../string_array/type.GenericStringArray.html      |   4 +-
 .../array/string_array/type.LargeStringArray.html  |   2 +-
 .../array/string_array/type.StringArray.html       |   2 +-
 arrow_array/array/struct.BooleanArray.html         |   8 +-
 arrow_array/array/struct.DictionaryArray.html      |  14 +-
 arrow_array/array/struct.FixedSizeBinaryArray.html |  10 +-
 arrow_array/array/struct.FixedSizeListArray.html   |  10 +-
 arrow_array/array/struct.GenericByteArray.html     |  12 +-
 arrow_array/array/struct.GenericListArray.html     |   8 +-
 arrow_array/array/struct.MapArray.html             |   6 +-
 arrow_array/array/struct.NativeAdapter.html        |   8 +-
 arrow_array/array/struct.NullArray.html            |   8 +-
 arrow_array/array/struct.PrimitiveArray.html       |  60 +--
 arrow_array/array/struct.RunArray.html             |  14 +-
 arrow_array/array/struct.StructArray.html          |   8 +-
 arrow_array/array/struct.TypedDictionaryArray.html |   6 +-
 arrow_array/array/struct.TypedRunArray.html        |  10 +-
 arrow_array/array/struct.UnionArray.html           |   8 +-
 arrow_array/array/struct_array/index.html          |   2 +-
 .../array/struct_array/struct.StructArray.html     |   8 +-
 arrow_array/array/trait.AnyDictionaryArray.html    |   2 +-
 arrow_array/array/trait.Array.html                 |   8 +-
 arrow_array/array/trait.ArrayAccessor.html         |   2 +-
 arrow_array/array/trait.OffsetSizeTrait.html       |   2 +-
 arrow_array/array/type.ArrayRef.html               |   2 +-
 arrow_array/array/type.BinaryArray.html            |   2 +-
 arrow_array/array/type.Date32Array.html            |   2 +-
 arrow_array/array/type.Date64Array.html            |   2 +-
 arrow_array/array/type.Decimal128Array.html        |   2 +-
 arrow_array/array/type.Decimal256Array.html        |   2 +-
 .../array/type.DurationMicrosecondArray.html       |   2 +-
 .../array/type.DurationMillisecondArray.html       |   2 +-
 .../array/type.DurationNanosecondArray.html        |   2 +-
 arrow_array/array/type.DurationSecondArray.html    |   2 +-
 arrow_array/array/type.Float16Array.html           |   2 +-
 arrow_array/array/type.Float32Array.html           |   2 +-
 arrow_array/array/type.Float64Array.html           |   2 +-
 arrow_array/array/type.GenericBinaryArray.html     |   4 +-
 arrow_array/array/type.GenericStringArray.html     |   4 +-
 arrow_array/array/type.Int16Array.html             |   2 +-
 arrow_array/array/type.Int16DictionaryArray.html   |   2 +-
 arrow_array/array/type.Int16RunArray.html          |   2 +-
 arrow_array/array/type.Int32Array.html             |   2 +-
 arrow_array/array/type.Int32DictionaryArray.html   |   2 +-
 arrow_array/array/type.Int32RunArray.html          |   2 +-
 arrow_array/array/type.Int64Array.html             |   2 +-
 arrow_array/array/type.Int64DictionaryArray.html   |   2 +-
 arrow_array/array/type.Int64RunArray.html          |   2 +-
 arrow_array/array/type.Int8Array.html              |   2 +-
 arrow_array/array/type.Int8DictionaryArray.html    |   2 +-
 arrow_array/array/type.IntervalDayTimeArray.html   |   2 +-
 .../array/type.IntervalMonthDayNanoArray.html      |   2 +-
 arrow_array/array/type.IntervalYearMonthArray.html |   2 +-
 arrow_array/array/type.LargeBinaryArray.html       |   2 +-
 arrow_array/array/type.LargeListArray.html         |   2 +-
 arrow_array/array/type.LargeStringArray.html       |   2 +-
 arrow_array/array/type.ListArray.html              |   2 +-
 arrow_array/array/type.StringArray.html            |   2 +-
 arrow_array/array/type.Time32MillisecondArray.html |   2 +-
 arrow_array/array/type.Time32SecondArray.html      |   2 +-
 arrow_array/array/type.Time64MicrosecondArray.html |   2 +-
 arrow_array/array/type.Time64NanosecondArray.html  |   2 +-
 .../array/type.TimestampMicrosecondArray.html      |   2 +-
 .../array/type.TimestampMillisecondArray.html      |   2 +-
 .../array/type.TimestampNanosecondArray.html       |   2 +-
 arrow_array/array/type.TimestampSecondArray.html   |   2 +-
 arrow_array/array/type.UInt16Array.html            |   2 +-
 arrow_array/array/type.UInt16DictionaryArray.html  |   2 +-
 arrow_array/array/type.UInt32Array.html            |   2 +-
 arrow_array/array/type.UInt32DictionaryArray.html  |   2 +-
 arrow_array/array/type.UInt64Array.html            |   2 +-
 arrow_array/array/type.UInt64DictionaryArray.html  |   2 +-
 arrow_array/array/type.UInt8Array.html             |   2 +-
 arrow_array/array/type.UInt8DictionaryArray.html   |   2 +-
 arrow_array/array/union_array/index.html           |   2 +-
 .../array/union_array/struct.UnionArray.html       |   8 +-
 arrow_array/builder/boolean_builder/index.html     |   2 +-
 .../boolean_builder/struct.BooleanBuilder.html     |   6 +-
 arrow_array/builder/buffer_builder/index.html      |   2 +-
 .../buffer_builder/struct.BufferBuilder.html       |   6 +-
 .../buffer_builder/type.Date32BufferBuilder.html   |   2 +-
 .../buffer_builder/type.Date64BufferBuilder.html   |   2 +-
 .../type.Decimal128BufferBuilder.html              |   2 +-
 .../type.Decimal256BufferBuilder.html              |   2 +-
 .../type.DurationMicrosecondBufferBuilder.html     |   2 +-
 .../type.DurationMillisecondBufferBuilder.html     |   2 +-
 .../type.DurationNanosecondBufferBuilder.html      |   2 +-
 .../type.DurationSecondBufferBuilder.html          |   2 +-
 .../buffer_builder/type.Float16BufferBuilder.html  |   2 +-
 .../buffer_builder/type.Float32BufferBuilder.html  |   2 +-
 .../buffer_builder/type.Float64BufferBuilder.html  |   2 +-
 .../buffer_builder/type.Int16BufferBuilder.html    |   2 +-
 .../buffer_builder/type.Int32BufferBuilder.html    |   2 +-
 .../buffer_builder/type.Int64BufferBuilder.html    |   2 +-
 .../buffer_builder/type.Int8BufferBuilder.html     |   2 +-
 .../type.IntervalDayTimeBufferBuilder.html         |   2 +-
 .../type.IntervalMonthDayNanoBufferBuilder.html    |   2 +-
 .../type.IntervalYearMonthBufferBuilder.html       |   2 +-
 .../type.Time32MillisecondBufferBuilder.html       |   2 +-
 .../type.Time32SecondBufferBuilder.html            |   2 +-
 .../type.Time64MicrosecondBufferBuilder.html       |   2 +-
 .../type.Time64NanosecondBufferBuilder.html        |   2 +-
 .../type.TimestampMicrosecondBufferBuilder.html    |   2 +-
 .../type.TimestampMillisecondBufferBuilder.html    |   2 +-
 .../type.TimestampNanosecondBufferBuilder.html     |   2 +-
 .../type.TimestampSecondBufferBuilder.html         |   2 +-
 .../buffer_builder/type.UInt16BufferBuilder.html   |   2 +-
 .../buffer_builder/type.UInt32BufferBuilder.html   |   2 +-
 .../buffer_builder/type.UInt64BufferBuilder.html   |   2 +-
 .../buffer_builder/type.UInt8BufferBuilder.html    |   2 +-
 .../builder/fixed_size_binary_builder/index.html   |   2 +-
 .../struct.FixedSizeBinaryBuilder.html             |   6 +-
 .../builder/fixed_size_list_builder/index.html     |   2 +-
 .../struct.FixedSizeListBuilder.html               |   6 +-
 arrow_array/builder/fn.make_builder.html           |   2 +-
 .../builder/generic_byte_run_builder/index.html    |   2 +-
 .../struct.GenericByteRunBuilder.html              |   6 +-
 .../type.BinaryRunBuilder.html                     |   2 +-
 .../type.LargeBinaryRunBuilder.html                |   2 +-
 .../type.LargeStringRunBuilder.html                |   2 +-
 .../type.StringRunBuilder.html                     |   2 +-
 .../builder/generic_bytes_builder/index.html       |   2 +-
 .../struct.GenericByteBuilder.html                 |   6 +-
 .../type.GenericBinaryBuilder.html                 |   2 +-
 .../type.GenericStringBuilder.html                 |   2 +-
 .../fn.get_bytes.html                              |   2 +-
 .../generic_bytes_dictionary_builder/index.html    |   2 +-
 .../struct.GenericByteDictionaryBuilder.html       |   6 +-
 .../type.BinaryDictionaryBuilder.html              |   2 +-
 .../type.LargeBinaryDictionaryBuilder.html         |   2 +-
 .../type.LargeStringDictionaryBuilder.html         |   2 +-
 .../type.StringDictionaryBuilder.html              |   2 +-
 .../builder/generic_list_builder/index.html        |   2 +-
 .../struct.GenericListBuilder.html                 |   6 +-
 arrow_array/builder/index.html                     |   2 +-
 arrow_array/builder/map_builder/index.html         |   2 +-
 .../builder/map_builder/struct.MapBuilder.html     |   6 +-
 .../builder/map_builder/struct.MapFieldNames.html  |   6 +-
 arrow_array/builder/null_builder/index.html        |   2 +-
 .../builder/null_builder/struct.NullBuilder.html   |   6 +-
 arrow_array/builder/primitive_builder/index.html   |   2 +-
 .../primitive_builder/struct.PrimitiveBuilder.html |   6 +-
 .../primitive_builder/type.Date32Builder.html      |   2 +-
 .../primitive_builder/type.Date64Builder.html      |   2 +-
 .../primitive_builder/type.Decimal128Builder.html  |   2 +-
 .../primitive_builder/type.Decimal256Builder.html  |   2 +-
 .../type.DurationMicrosecondBuilder.html           |   2 +-
 .../type.DurationMillisecondBuilder.html           |   2 +-
 .../type.DurationNanosecondBuilder.html            |   2 +-
 .../type.DurationSecondBuilder.html                |   2 +-
 .../primitive_builder/type.Float16Builder.html     |   2 +-
 .../primitive_builder/type.Float32Builder.html     |   2 +-
 .../primitive_builder/type.Float64Builder.html     |   2 +-
 .../primitive_builder/type.Int16Builder.html       |   2 +-
 .../primitive_builder/type.Int32Builder.html       |   2 +-
 .../primitive_builder/type.Int64Builder.html       |   2 +-
 .../primitive_builder/type.Int8Builder.html        |   2 +-
 .../type.IntervalDayTimeBuilder.html               |   2 +-
 .../type.IntervalMonthDayNanoBuilder.html          |   2 +-
 .../type.IntervalYearMonthBuilder.html             |   2 +-
 .../type.Time32MillisecondBuilder.html             |   2 +-
 .../type.Time32SecondBuilder.html                  |   2 +-
 .../type.Time64MicrosecondBuilder.html             |   2 +-
 .../type.Time64NanosecondBuilder.html              |   2 +-
 .../type.TimestampMicrosecondBuilder.html          |   2 +-
 .../type.TimestampMillisecondBuilder.html          |   2 +-
 .../type.TimestampNanosecondBuilder.html           |   2 +-
 .../type.TimestampSecondBuilder.html               |   2 +-
 .../primitive_builder/type.UInt16Builder.html      |   2 +-
 .../primitive_builder/type.UInt32Builder.html      |   2 +-
 .../primitive_builder/type.UInt64Builder.html      |   2 +-
 .../primitive_builder/type.UInt8Builder.html       |   2 +-
 .../primitive_dictionary_builder/index.html        |   2 +-
 .../struct.PrimitiveDictionaryBuilder.html         |   6 +-
 .../primitive_dictionary_builder/struct.Value.html |   6 +-
 .../builder/primitive_run_builder/index.html       |   2 +-
 .../struct.PrimitiveRunBuilder.html                |   6 +-
 .../builder/struct.BooleanBufferBuilder.html       |   6 +-
 arrow_array/builder/struct.BooleanBuilder.html     |   6 +-
 arrow_array/builder/struct.BufferBuilder.html      |   6 +-
 .../builder/struct.FixedSizeBinaryBuilder.html     |   6 +-
 .../builder/struct.FixedSizeListBuilder.html       |   6 +-
 arrow_array/builder/struct.GenericByteBuilder.html |   6 +-
 .../struct.GenericByteDictionaryBuilder.html       |   6 +-
 .../builder/struct.GenericByteRunBuilder.html      |   6 +-
 arrow_array/builder/struct.GenericListBuilder.html |   6 +-
 arrow_array/builder/struct.MapBuilder.html         |   6 +-
 arrow_array/builder/struct.MapFieldNames.html      |   6 +-
 arrow_array/builder/struct.NullBuilder.html        |   6 +-
 arrow_array/builder/struct.PrimitiveBuilder.html   |   6 +-
 .../builder/struct.PrimitiveDictionaryBuilder.html |   6 +-
 .../builder/struct.PrimitiveRunBuilder.html        |   6 +-
 arrow_array/builder/struct.StructBuilder.html      |   6 +-
 arrow_array/builder/struct.UnionBuilder.html       |   6 +-
 .../builder/struct_builder/fn.make_builder.html    |   2 +-
 arrow_array/builder/struct_builder/index.html      |   2 +-
 .../struct_builder/struct.StructBuilder.html       |   6 +-
 arrow_array/builder/trait.ArrayBuilder.html        |   2 +-
 arrow_array/builder/type.BinaryBuilder.html        |   2 +-
 .../builder/type.BinaryDictionaryBuilder.html      |   2 +-
 arrow_array/builder/type.BinaryRunBuilder.html     |   2 +-
 arrow_array/builder/type.Date32BufferBuilder.html  |   2 +-
 arrow_array/builder/type.Date32Builder.html        |   2 +-
 arrow_array/builder/type.Date64BufferBuilder.html  |   2 +-
 arrow_array/builder/type.Date64Builder.html        |   2 +-
 .../builder/type.Decimal128BufferBuilder.html      |   2 +-
 arrow_array/builder/type.Decimal128Builder.html    |   2 +-
 .../builder/type.Decimal256BufferBuilder.html      |   2 +-
 arrow_array/builder/type.Decimal256Builder.html    |   2 +-
 .../type.DurationMicrosecondBufferBuilder.html     |   2 +-
 .../builder/type.DurationMicrosecondBuilder.html   |   2 +-
 .../type.DurationMillisecondBufferBuilder.html     |   2 +-
 .../builder/type.DurationMillisecondBuilder.html   |   2 +-
 .../type.DurationNanosecondBufferBuilder.html      |   2 +-
 .../builder/type.DurationNanosecondBuilder.html    |   2 +-
 .../builder/type.DurationSecondBufferBuilder.html  |   2 +-
 .../builder/type.DurationSecondBuilder.html        |   2 +-
 arrow_array/builder/type.Float16BufferBuilder.html |   2 +-
 arrow_array/builder/type.Float16Builder.html       |   2 +-
 arrow_array/builder/type.Float32BufferBuilder.html |   2 +-
 arrow_array/builder/type.Float32Builder.html       |   2 +-
 arrow_array/builder/type.Float64BufferBuilder.html |   2 +-
 arrow_array/builder/type.Float64Builder.html       |   2 +-
 arrow_array/builder/type.GenericBinaryBuilder.html |   2 +-
 arrow_array/builder/type.GenericStringBuilder.html |   2 +-
 arrow_array/builder/type.Int16BufferBuilder.html   |   2 +-
 arrow_array/builder/type.Int16Builder.html         |   2 +-
 arrow_array/builder/type.Int32BufferBuilder.html   |   2 +-
 arrow_array/builder/type.Int32Builder.html         |   2 +-
 arrow_array/builder/type.Int64BufferBuilder.html   |   2 +-
 arrow_array/builder/type.Int64Builder.html         |   2 +-
 arrow_array/builder/type.Int8BufferBuilder.html    |   2 +-
 arrow_array/builder/type.Int8Builder.html          |   2 +-
 .../builder/type.IntervalDayTimeBufferBuilder.html |   2 +-
 .../builder/type.IntervalDayTimeBuilder.html       |   2 +-
 .../type.IntervalMonthDayNanoBufferBuilder.html    |   2 +-
 .../builder/type.IntervalMonthDayNanoBuilder.html  |   2 +-
 .../type.IntervalYearMonthBufferBuilder.html       |   2 +-
 .../builder/type.IntervalYearMonthBuilder.html     |   2 +-
 arrow_array/builder/type.LargeBinaryBuilder.html   |   2 +-
 .../builder/type.LargeBinaryDictionaryBuilder.html |   2 +-
 .../builder/type.LargeBinaryRunBuilder.html        |   2 +-
 arrow_array/builder/type.LargeListBuilder.html     |   2 +-
 arrow_array/builder/type.LargeStringBuilder.html   |   2 +-
 .../builder/type.LargeStringDictionaryBuilder.html |   2 +-
 .../builder/type.LargeStringRunBuilder.html        |   2 +-
 arrow_array/builder/type.ListBuilder.html          |   2 +-
 arrow_array/builder/type.StringBuilder.html        |   2 +-
 .../builder/type.StringDictionaryBuilder.html      |   2 +-
 arrow_array/builder/type.StringRunBuilder.html     |   2 +-
 .../type.Time32MillisecondBufferBuilder.html       |   2 +-
 .../builder/type.Time32MillisecondBuilder.html     |   2 +-
 .../builder/type.Time32SecondBufferBuilder.html    |   2 +-
 arrow_array/builder/type.Time32SecondBuilder.html  |   2 +-
 .../type.Time64MicrosecondBufferBuilder.html       |   2 +-
 .../builder/type.Time64MicrosecondBuilder.html     |   2 +-
 .../type.Time64NanosecondBufferBuilder.html        |   2 +-
 .../builder/type.Time64NanosecondBuilder.html      |   2 +-
 .../type.TimestampMicrosecondBufferBuilder.html    |   2 +-
 .../builder/type.TimestampMicrosecondBuilder.html  |   2 +-
 .../type.TimestampMillisecondBufferBuilder.html    |   2 +-
 .../builder/type.TimestampMillisecondBuilder.html  |   2 +-
 .../type.TimestampNanosecondBufferBuilder.html     |   2 +-
 .../builder/type.TimestampNanosecondBuilder.html   |   2 +-
 .../builder/type.TimestampSecondBufferBuilder.html |   2 +-
 .../builder/type.TimestampSecondBuilder.html       |   2 +-
 arrow_array/builder/type.UInt16BufferBuilder.html  |   2 +-
 arrow_array/builder/type.UInt16Builder.html        |   2 +-
 arrow_array/builder/type.UInt32BufferBuilder.html  |   2 +-
 arrow_array/builder/type.UInt32Builder.html        |   2 +-
 arrow_array/builder/type.UInt64BufferBuilder.html  |   2 +-
 arrow_array/builder/type.UInt64Builder.html        |   2 +-
 arrow_array/builder/type.UInt8BufferBuilder.html   |   2 +-
 arrow_array/builder/type.UInt8Builder.html         |   2 +-
 arrow_array/builder/union_builder/index.html       |   2 +-
 .../builder/union_builder/struct.FieldData.html    |   6 +-
 .../builder/union_builder/struct.UnionBuilder.html |   6 +-
 .../union_builder/trait.FieldDataValues.html       |   2 +-
 arrow_array/cast/fn.as_boolean_array.html          |   2 +-
 arrow_array/cast/fn.as_decimal_array.html          |   2 +-
 arrow_array/cast/fn.as_dictionary_array.html       |   2 +-
 arrow_array/cast/fn.as_fixed_size_list_array.html  |   2 +-
 arrow_array/cast/fn.as_generic_binary_array.html   |   2 +-
 arrow_array/cast/fn.as_generic_list_array.html     |   2 +-
 arrow_array/cast/fn.as_large_list_array.html       |   2 +-
 arrow_array/cast/fn.as_largestring_array.html      |   2 +-
 arrow_array/cast/fn.as_list_array.html             |   2 +-
 arrow_array/cast/fn.as_map_array.html              |   2 +-
 arrow_array/cast/fn.as_null_array.html             |   2 +-
 arrow_array/cast/fn.as_primitive_array.html        |   2 +-
 arrow_array/cast/fn.as_run_array.html              |   2 +-
 arrow_array/cast/fn.as_string_array.html           |   2 +-
 arrow_array/cast/fn.as_struct_array.html           |   2 +-
 arrow_array/cast/fn.as_union_array.html            |   2 +-
 arrow_array/cast/fn.downcast_array.html            |   2 +-
 arrow_array/cast/index.html                        |   2 +-
 arrow_array/cast/macro.array_downcast_fn.html      |   2 +-
 arrow_array/cast/private/index.html                |   2 +-
 arrow_array/cast/private/trait.Sealed.html         |   2 +-
 arrow_array/cast/trait.AsArray.html                |   2 +-
 arrow_array/delta/fn.add_days_datetime.html        |   2 +-
 arrow_array/delta/fn.add_months_datetime.html      |   2 +-
 arrow_array/delta/fn.shift_months.html             |   2 +-
 arrow_array/delta/fn.sub_days_datetime.html        |   2 +-
 arrow_array/delta/fn.sub_months_datetime.html      |   2 +-
 arrow_array/delta/index.html                       |   2 +-
 arrow_array/index.html                             |   2 +-
 arrow_array/iterator/index.html                    |   2 +-
 arrow_array/iterator/struct.ArrayIter.html         |   6 +-
 arrow_array/iterator/type.BooleanIter.html         |   2 +-
 arrow_array/iterator/type.FixedSizeBinaryIter.html |   2 +-
 arrow_array/iterator/type.FixedSizeListIter.html   |   2 +-
 arrow_array/iterator/type.GenericBinaryIter.html   |   2 +-
 .../iterator/type.GenericListArrayIter.html        |   2 +-
 arrow_array/iterator/type.GenericStringIter.html   |   2 +-
 arrow_array/iterator/type.MapArrayIter.html        |   2 +-
 arrow_array/iterator/type.PrimitiveIter.html       |   2 +-
 arrow_array/macro.downcast_dictionary_array.html   |   2 +-
 arrow_array/macro.downcast_integer.html            |   2 +-
 arrow_array/macro.downcast_primitive.html          |   2 +-
 arrow_array/macro.downcast_primitive_array.html    |   2 +-
 arrow_array/macro.downcast_run_array.html          |   2 +-
 arrow_array/macro.downcast_run_end_index.html      |   2 +-
 arrow_array/macro.downcast_temporal.html           |   2 +-
 arrow_array/macro.downcast_temporal_array.html     |   2 +-
 arrow_array/numeric/index.html                     |   2 +-
 arrow_array/numeric/trait.ArrowNumericType.html    |   2 +-
 arrow_array/record_batch/index.html                |   2 +-
 arrow_array/record_batch/struct.RecordBatch.html   |   8 +-
 .../record_batch/struct.RecordBatchIterator.html   |   6 +-
 .../record_batch/struct.RecordBatchOptions.html    |   6 +-
 .../record_batch/trait.RecordBatchReader.html      |   2 +-
 .../record_batch/trait.RecordBatchWriter.html      |   2 +-
 arrow_array/run_iterator/index.html                |   2 +-
 arrow_array/run_iterator/struct.RunArrayIter.html  |   6 +-
 arrow_array/scalar/index.html                      |   2 +-
 arrow_array/scalar/struct.Scalar.html              |   6 +-
 arrow_array/scalar/trait.Datum.html                |   2 +-
 arrow_array/struct.RecordBatch.html                |   8 +-
 arrow_array/struct.RecordBatchIterator.html        |   6 +-
 arrow_array/struct.RecordBatchOptions.html         |   6 +-
 arrow_array/struct.Scalar.html                     |   6 +-
 .../constant.EPOCH_DAYS_FROM_CE.html               |   2 +-
 .../constant.MICROSECONDS.html                     |   2 +-
 .../constant.MICROSECONDS_IN_DAY.html              |   2 +-
 .../constant.MILLISECONDS.html                     |   2 +-
 .../constant.MILLISECONDS_IN_DAY.html              |   2 +-
 .../temporal_conversions/constant.NANOSECONDS.html |   2 +-
 .../constant.NANOSECONDS_IN_DAY.html               |   2 +-
 .../constant.SECONDS_IN_DAY.html                   |   2 +-
 arrow_array/temporal_conversions/fn.as_date.html   |   2 +-
 .../temporal_conversions/fn.as_datetime.html       |   2 +-
 .../fn.as_datetime_with_timezone.html              |   2 +-
 .../temporal_conversions/fn.as_duration.html       |   2 +-
 arrow_array/temporal_conversions/fn.as_time.html   |   2 +-
 .../fn.date32_to_datetime.html                     |   2 +-
 .../fn.date64_to_datetime.html                     |   2 +-
 .../fn.duration_ms_to_duration.html                |   2 +-
 .../fn.duration_ns_to_duration.html                |   2 +-
 .../fn.duration_s_to_duration.html                 |   2 +-
 .../fn.duration_us_to_duration.html                |   2 +-
 .../temporal_conversions/fn.split_second.html      |   2 +-
 .../temporal_conversions/fn.time32ms_to_time.html  |   2 +-
 .../temporal_conversions/fn.time32s_to_time.html   |   2 +-
 .../temporal_conversions/fn.time64ns_to_time.html  |   2 +-
 .../temporal_conversions/fn.time64us_to_time.html  |   2 +-
 .../temporal_conversions/fn.time_to_time32ms.html  |   2 +-
 .../temporal_conversions/fn.time_to_time32s.html   |   2 +-
 .../temporal_conversions/fn.time_to_time64ns.html  |   2 +-
 .../temporal_conversions/fn.time_to_time64us.html  |   2 +-
 .../fn.timestamp_ms_to_datetime.html               |   2 +-
 .../fn.timestamp_ns_to_datetime.html               |   2 +-
 .../fn.timestamp_s_to_datetime.html                |   2 +-
 .../fn.timestamp_us_to_datetime.html               |   2 +-
 arrow_array/temporal_conversions/index.html        |   2 +-
 arrow_array/timezone/fn.parse_fixed_offset.html    |   2 +-
 arrow_array/timezone/index.html                    |   2 +-
 arrow_array/timezone/private/enum.TzInner.html     |   6 +-
 arrow_array/timezone/private/index.html            |   2 +-
 arrow_array/timezone/private/macro.tz.html         |   2 +-
 arrow_array/timezone/private/struct.Tz.html        |   6 +-
 arrow_array/timezone/private/struct.TzOffset.html  |   8 +-
 arrow_array/timezone/struct.Tz.html                |   6 +-
 arrow_array/timezone/struct.TzOffset.html          |   8 +-
 arrow_array/trait.ArrowNativeTypeOp.html           |   4 +-
 arrow_array/trait.ArrowNumericType.html            |   2 +-
 arrow_array/trait.Datum.html                       |   2 +-
 arrow_array/trait.RecordBatchReader.html           |   2 +-
 arrow_array/trait.RecordBatchWriter.html           |   2 +-
 arrow_array/trusted_len/fn.trusted_len_unzip.html  |   2 +-
 arrow_array/trusted_len/index.html                 |   2 +-
 arrow_array/types/bytes/index.html                 |   2 +-
 .../types/bytes/trait.ByteArrayNativeType.html     |   2 +-
 .../types/bytes/trait.ByteArrayTypeSealed.html     |   2 +-
 arrow_array/types/decimal/index.html               |   2 +-
 .../types/decimal/trait.DecimalTypeSealed.html     |   2 +-
 arrow_array/types/fn.add_day_time.html             |   2 +-
 arrow_array/types/fn.add_month_day_nano.html       |   2 +-
 arrow_array/types/fn.add_year_months.html          |   2 +-
 arrow_array/types/fn.format_decimal_str.html       |   2 +-
 arrow_array/types/fn.subtract_day_time.html        |   2 +-
 arrow_array/types/fn.subtract_month_day_nano.html  |   2 +-
 arrow_array/types/fn.subtract_year_months.html     |   2 +-
 .../fn.validate_decimal_precision_and_scale.html   |   2 +-
 arrow_array/types/index.html                       |   2 +-
 arrow_array/types/macro.make_type.html             |   2 +-
 arrow_array/types/primitive/index.html             |   2 +-
 .../types/primitive/trait.PrimitiveTypeSealed.html |   2 +-
 arrow_array/types/struct.BooleanType.html          |   6 +-
 arrow_array/types/struct.Date32Type.html           |   6 +-
 arrow_array/types/struct.Date64Type.html           |   6 +-
 arrow_array/types/struct.Decimal128Type.html       |   6 +-
 arrow_array/types/struct.Decimal256Type.html       |   6 +-
 .../types/struct.DurationMicrosecondType.html      |   6 +-
 .../types/struct.DurationMillisecondType.html      |   6 +-
 .../types/struct.DurationNanosecondType.html       |   6 +-
 arrow_array/types/struct.DurationSecondType.html   |   6 +-
 arrow_array/types/struct.Float16Type.html          |   6 +-
 arrow_array/types/struct.Float32Type.html          |   6 +-
 arrow_array/types/struct.Float64Type.html          |   6 +-
 arrow_array/types/struct.GenericBinaryType.html    |   6 +-
 arrow_array/types/struct.GenericStringType.html    |   6 +-
 arrow_array/types/struct.Int16Type.html            |   6 +-
 arrow_array/types/struct.Int32Type.html            |   6 +-
 arrow_array/types/struct.Int64Type.html            |   6 +-
 arrow_array/types/struct.Int8Type.html             |   6 +-
 arrow_array/types/struct.IntervalDayTimeType.html  |   6 +-
 .../types/struct.IntervalMonthDayNanoType.html     |   6 +-
 .../types/struct.IntervalYearMonthType.html        |   6 +-
 .../types/struct.Time32MillisecondType.html        |   6 +-
 arrow_array/types/struct.Time32SecondType.html     |   6 +-
 .../types/struct.Time64MicrosecondType.html        |   6 +-
 arrow_array/types/struct.Time64NanosecondType.html |   6 +-
 .../types/struct.TimestampMicrosecondType.html     |   6 +-
 .../types/struct.TimestampMillisecondType.html     |   6 +-
 .../types/struct.TimestampNanosecondType.html      |   6 +-
 arrow_array/types/struct.TimestampSecondType.html  |   6 +-
 arrow_array/types/struct.UInt16Type.html           |   6 +-
 arrow_array/types/struct.UInt32Type.html           |   6 +-
 arrow_array/types/struct.UInt64Type.html           |   6 +-
 arrow_array/types/struct.UInt8Type.html            |   6 +-
 .../types/trait.ArrowDictionaryKeyType.html        |   2 +-
 arrow_array/types/trait.ArrowPrimitiveType.html    |   2 +-
 arrow_array/types/trait.ArrowTemporalType.html     |   2 +-
 arrow_array/types/trait.ArrowTimestampType.html    |   2 +-
 arrow_array/types/trait.ByteArrayType.html         |   2 +-
 arrow_array/types/trait.DecimalType.html           |   2 +-
 arrow_array/types/trait.RunEndIndexType.html       |   2 +-
 arrow_array/types/type.BinaryType.html             |   2 +-
 arrow_array/types/type.LargeBinaryType.html        |   2 +-
 arrow_array/types/type.LargeUtf8Type.html          |   2 +-
 arrow_array/types/type.Utf8Type.html               |   2 +-
 arrow_avro/all.html                                |   2 +-
 arrow_avro/codec/enum.Codec.html                   |   8 +-
 arrow_avro/codec/enum.Nulls.html                   |   6 +-
 arrow_avro/codec/fn.make_data_type.html            |   4 +-
 arrow_avro/codec/index.html                        |   2 +-
 arrow_avro/codec/struct.AvroDataType.html          |   8 +-
 arrow_avro/codec/struct.AvroField.html             |  10 +-
 arrow_avro/codec/struct.Resolver.html              |   8 +-
 .../compression/constant.CODEC_METADATA_KEY.html   |   2 +-
 arrow_avro/compression/enum.CompressionCodec.html  |   8 +-
 arrow_avro/compression/index.html                  |   2 +-
 arrow_avro/index.html                              |   2 +-
 .../reader/block/enum.BlockDecoderState.html       |   6 +-
 arrow_avro/reader/block/index.html                 |   2 +-
 arrow_avro/reader/block/struct.Block.html          |   6 +-
 arrow_avro/reader/block/struct.BlockDecoder.html   |   8 +-
 arrow_avro/reader/fn.read_blocks.html              |   4 +-
 arrow_avro/reader/fn.read_header.html              |   4 +-
 arrow_avro/reader/header/constant.MAGIC.html       |   2 +-
 .../reader/header/enum.HeaderDecoderState.html     |   6 +-
 arrow_avro/reader/header/index.html                |   2 +-
 arrow_avro/reader/header/struct.Header.html        |   8 +-
 arrow_avro/reader/header/struct.HeaderDecoder.html |   8 +-
 arrow_avro/reader/index.html                       |   2 +-
 arrow_avro/reader/vlq/index.html                   |   2 +-
 arrow_avro/reader/vlq/struct.VLQDecoder.html       |   6 +-
 .../schema/constant.SCHEMA_METADATA_KEY.html       |   2 +-
 arrow_avro/schema/enum.ComplexType.html            |   6 +-
 arrow_avro/schema/enum.PrimitiveType.html          |   6 +-
 arrow_avro/schema/enum.Schema.html                 |   8 +-
 arrow_avro/schema/enum.TypeName.html               |   6 +-
 arrow_avro/schema/index.html                       |   2 +-
 arrow_avro/schema/struct.Array.html                |   6 +-
 arrow_avro/schema/struct.Attributes.html           |   6 +-
 arrow_avro/schema/struct.Enum.html                 |   6 +-
 arrow_avro/schema/struct.Field.html                |   6 +-
 arrow_avro/schema/struct.Fixed.html                |   6 +-
 arrow_avro/schema/struct.Map.html                  |   6 +-
 arrow_avro/schema/struct.Record.html               |   6 +-
 arrow_avro/schema/struct.Type.html                 |   6 +-
 arrow_buffer/all.html                              |   2 +-
 .../alloc/alignment/constant.ALIGNMENT.html        |   2 +-
 arrow_buffer/alloc/alignment/index.html            |   2 +-
 arrow_buffer/alloc/constant.ALIGNMENT.html         |   2 +-
 arrow_buffer/alloc/enum.Deallocation.html          |   6 +-
 arrow_buffer/alloc/index.html                      |   2 +-
 arrow_buffer/alloc/trait.Allocation.html           |   2 +-
 arrow_buffer/bigint/div/fn.add_assign.html         |   2 +-
 arrow_buffer/bigint/div/fn.binop_slice.html        |   2 +-
 arrow_buffer/bigint/div/fn.bits.html               |   2 +-
 arrow_buffer/bigint/div/fn.div_rem.html            |   2 +-
 arrow_buffer/bigint/div/fn.div_rem_knuth.html      |   2 +-
 arrow_buffer/bigint/div/fn.div_rem_small.html      |   2 +-
 arrow_buffer/bigint/div/fn.div_rem_word.html       |   2 +-
 arrow_buffer/bigint/div/fn.full_mul_u64.html       |   2 +-
 arrow_buffer/bigint/div/fn.full_shl.html           |   2 +-
 arrow_buffer/bigint/div/fn.full_shr.html           |   2 +-
 arrow_buffer/bigint/div/fn.shl_word.html           |   2 +-
 arrow_buffer/bigint/div/fn.sub_assign.html         |   2 +-
 arrow_buffer/bigint/div/index.html                 |   2 +-
 arrow_buffer/bigint/div/struct.ArrayPlusOne.html   | 360 ++++++++---------
 arrow_buffer/bigint/enum.DivRemError.html          |   6 +-
 arrow_buffer/bigint/fn.mulx.html                   |   2 +-
 arrow_buffer/bigint/fn.parse_impl.html             |   2 +-
 arrow_buffer/bigint/fn.split_array.html            |   2 +-
 arrow_buffer/bigint/index.html                     |   2 +-
 arrow_buffer/bigint/macro.define_as_primitive.html |   2 +-
 arrow_buffer/bigint/macro.derive_op.html           |   2 +-
 arrow_buffer/bigint/struct.ParseI256Error.html     |   8 +-
 arrow_buffer/bigint/struct.i256.html               |  12 +-
 arrow_buffer/bit_chunk_iterator/index.html         |   2 +-
 .../struct.BitChunkIterator.html                   |   6 +-
 .../bit_chunk_iterator/struct.BitChunks.html       |   6 +-
 .../struct.UnalignedBitChunk.html                  |   6 +-
 .../type.UnalignedBitChunkIterator.html            |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 arrow_buffer/bit_iterator/index.html               |   2 +-
 .../bit_iterator/struct.BitIndexIterator.html      |   6 +-
 arrow_buffer/bit_iterator/struct.BitIterator.html  |   6 +-
 .../bit_iterator/struct.BitSliceIterator.html      |   6 +-
 arrow_buffer/bit_mask/fn.set_bits.html             |   2 +-
 arrow_buffer/bit_mask/index.html                   |   2 +-
 arrow_buffer/bit_util/fn.ceil.html                 |   2 +-
 arrow_buffer/bit_util/fn.get_bit.html              |   2 +-
 arrow_buffer/bit_util/fn.get_bit_raw.html          |   2 +-
 .../bit_util/fn.round_upto_multiple_of_64.html     |   2 +-
 .../bit_util/fn.round_upto_power_of_2.html         |   2 +-
 arrow_buffer/bit_util/fn.set_bit.html              |   2 +-
 arrow_buffer/bit_util/fn.set_bit_raw.html          |   2 +-
 arrow_buffer/bit_util/fn.unset_bit.html            |   2 +-
 arrow_buffer/bit_util/fn.unset_bit_raw.html        |   2 +-
 arrow_buffer/bit_util/index.html                   |   2 +-
 arrow_buffer/buffer/boolean/index.html             |   2 +-
 .../buffer/boolean/struct.BooleanBuffer.html       |   8 +-
 arrow_buffer/buffer/fn.bitwise_bin_op_helper.html  |   2 +-
 .../buffer/fn.bitwise_quaternary_op_helper.html    |   2 +-
 .../buffer/fn.bitwise_unary_op_helper.html         |   2 +-
 arrow_buffer/buffer/fn.buffer_bin_and.html         |   2 +-
 arrow_buffer/buffer/fn.buffer_bin_and_not.html     |   2 +-
 arrow_buffer/buffer/fn.buffer_bin_or.html          |   2 +-
 arrow_buffer/buffer/fn.buffer_bin_xor.html         |   2 +-
 arrow_buffer/buffer/fn.buffer_unary_not.html       |   2 +-
 arrow_buffer/buffer/immutable/index.html           |   2 +-
 arrow_buffer/buffer/immutable/struct.Buffer.html   | 178 ++++----
 arrow_buffer/buffer/index.html                     |   2 +-
 arrow_buffer/buffer/mutable/fn.dangling_ptr.html   |   2 +-
 arrow_buffer/buffer/mutable/index.html             |   2 +-
 .../buffer/mutable/struct.MutableBuffer.html       | 364 ++++++++---------
 .../buffer/mutable/struct.SetLenOnDrop.html        |   6 +-
 arrow_buffer/buffer/null/index.html                |   2 +-
 arrow_buffer/buffer/null/struct.NullBuffer.html    |   8 +-
 arrow_buffer/buffer/offset/index.html              |   2 +-
 .../buffer/offset/struct.OffsetBuffer.html         | 172 ++++----
 .../buffer/ops/fn.bitwise_bin_op_helper.html       |   2 +-
 .../ops/fn.bitwise_quaternary_op_helper.html       |   2 +-
 .../buffer/ops/fn.bitwise_unary_op_helper.html     |   2 +-
 arrow_buffer/buffer/ops/fn.buffer_bin_and.html     |   2 +-
 arrow_buffer/buffer/ops/fn.buffer_bin_and_not.html |   2 +-
 arrow_buffer/buffer/ops/fn.buffer_bin_or.html      |   2 +-
 arrow_buffer/buffer/ops/fn.buffer_bin_xor.html     |   2 +-
 arrow_buffer/buffer/ops/fn.buffer_unary_not.html   |   2 +-
 arrow_buffer/buffer/ops/index.html                 |   2 +-
 arrow_buffer/buffer/run/index.html                 |   2 +-
 arrow_buffer/buffer/run/struct.RunEndBuffer.html   |   6 +-
 arrow_buffer/buffer/scalar/index.html              |   2 +-
 .../buffer/scalar/struct.ScalarBuffer.html         | 186 ++++-----
 arrow_buffer/buffer/struct.BooleanBuffer.html      |   8 +-
 arrow_buffer/buffer/struct.Buffer.html             | 178 ++++----
 arrow_buffer/buffer/struct.MutableBuffer.html      | 364 ++++++++---------
 arrow_buffer/buffer/struct.NullBuffer.html         |   8 +-
 arrow_buffer/buffer/struct.OffsetBuffer.html       | 172 ++++----
 arrow_buffer/buffer/struct.RunEndBuffer.html       |   6 +-
 arrow_buffer/buffer/struct.ScalarBuffer.html       | 186 ++++-----
 arrow_buffer/builder/boolean/index.html            |   2 +-
 .../boolean/struct.BooleanBufferBuilder.html       |   8 +-
 arrow_buffer/builder/index.html                    |   2 +-
 arrow_buffer/builder/null/index.html               |   2 +-
 .../builder/null/struct.NullBufferBuilder.html     |   6 +-
 .../builder/struct.BooleanBufferBuilder.html       |   8 +-
 arrow_buffer/builder/struct.BufferBuilder.html     |   8 +-
 arrow_buffer/builder/struct.NullBufferBuilder.html |   6 +-
 arrow_buffer/bytes/index.html                      |   2 +-
 arrow_buffer/bytes/struct.Bytes.html               | 172 ++++----
 arrow_buffer/index.html                            |   2 +-
 arrow_buffer/native/index.html                     |   2 +-
 arrow_buffer/native/macro.native_float.html        |   2 +-
 arrow_buffer/native/macro.native_integer.html      |   2 +-
 arrow_buffer/native/private/index.html             |   2 +-
 arrow_buffer/native/private/trait.Sealed.html      |   2 +-
 arrow_buffer/native/trait.ArrowNativeType.html     |   2 +-
 arrow_buffer/native/trait.ToByteSlice.html         |   2 +-
 arrow_buffer/struct.i256.html                      |  12 +-
 arrow_buffer/trait.ArrowNativeType.html            |   2 +-
 arrow_buffer/trait.ToByteSlice.html                |   2 +-
 .../bit_chunk_iterator/fn.compute_prefix_mask.html |   2 +-
 .../bit_chunk_iterator/fn.compute_suffix_mask.html |   2 +-
 .../util/bit_chunk_iterator/fn.read_u64.html       |   2 +-
 arrow_buffer/util/bit_chunk_iterator/index.html    |   2 +-
 .../struct.BitChunkIterator.html                   |   6 +-
 .../util/bit_chunk_iterator/struct.BitChunks.html  |   6 +-
 .../struct.UnalignedBitChunk.html                  |   6 +-
 .../type.UnalignedBitChunkIterator.html            |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 arrow_buffer/util/bit_iterator/index.html          |   2 +-
 .../util/bit_iterator/struct.BitIndexIterator.html |   6 +-
 .../util/bit_iterator/struct.BitIterator.html      |   6 +-
 .../util/bit_iterator/struct.BitSliceIterator.html |   6 +-
 arrow_buffer/util/bit_mask/fn.set_bits.html        |   2 +-
 arrow_buffer/util/bit_mask/index.html              |   2 +-
 arrow_buffer/util/bit_util/constant.BIT_MASK.html  |   2 +-
 .../util/bit_util/constant.UNSET_BIT_MASK.html     |   2 +-
 arrow_buffer/util/bit_util/fn.ceil.html            |   2 +-
 arrow_buffer/util/bit_util/fn.get_bit.html         |   2 +-
 arrow_buffer/util/bit_util/fn.get_bit_raw.html     |   2 +-
 .../bit_util/fn.round_upto_multiple_of_64.html     |   2 +-
 .../util/bit_util/fn.round_upto_power_of_2.html    |   2 +-
 arrow_buffer/util/bit_util/fn.set_bit.html         |   2 +-
 arrow_buffer/util/bit_util/fn.set_bit_raw.html     |   2 +-
 arrow_buffer/util/bit_util/fn.unset_bit.html       |   2 +-
 arrow_buffer/util/bit_util/fn.unset_bit_raw.html   |   2 +-
 arrow_buffer/util/bit_util/index.html              |   2 +-
 arrow_buffer/util/index.html                       |   2 +-
 arrow_cast/all.html                                |   2 +-
 arrow_cast/base64/constant.BASE64_STANDARD.html    |   2 +-
 .../base64/constant.BASE64_STANDARD_NO_PAD.html    |   2 +-
 arrow_cast/base64/constant.BASE64_URL_SAFE.html    |   2 +-
 .../base64/constant.BASE64_URL_SAFE_NO_PAD.html    |   2 +-
 arrow_cast/base64/fn.b64_decode.html               |   2 +-
 arrow_cast/base64/fn.b64_encode.html               |   2 +-
 arrow_cast/base64/index.html                       |   2 +-
 arrow_cast/base64/trait.Engine.html                |   2 +-
 .../cast/fn.adjust_timestamp_to_timezone.html      |   2 +-
 arrow_cast/cast/fn.as_time_res_with_timezone.html  |   2 +-
 arrow_cast/cast/fn.bool_to_numeric_cast.html       |   2 +-
 arrow_cast/cast/fn.can_cast_types.html             |   2 +-
 arrow_cast/cast/fn.cast.html                       |   2 +-
 .../cast/fn.cast_binary_to_fixed_size_binary.html  |   2 +-
 arrow_cast/cast/fn.cast_binary_to_string.html      |   2 +-
 arrow_cast/cast/fn.cast_bool_to_numeric.html       |   2 +-
 arrow_cast/cast/fn.cast_byte_container.html        |   2 +-
 arrow_cast/cast/fn.cast_decimal_to_decimal.html    |   2 +-
 .../cast/fn.cast_decimal_to_decimal_error.html     |   2 +-
 .../cast/fn.cast_decimal_to_decimal_same_type.html |   2 +-
 arrow_cast/cast/fn.cast_decimal_to_float.html      |   2 +-
 arrow_cast/cast/fn.cast_decimal_to_integer.html    |   2 +-
 arrow_cast/cast/fn.cast_duration_to_interval.html  |   2 +-
 .../cast/fn.cast_fixed_size_binary_to_binary.html  |   2 +-
 .../cast/fn.cast_fixed_size_list_to_list.html      |   2 +-
 .../cast/fn.cast_floating_point_to_decimal128.html |   2 +-
 .../cast/fn.cast_floating_point_to_decimal256.html |   2 +-
 arrow_cast/cast/fn.cast_integer_to_decimal.html    |   2 +-
 ...terval_day_time_to_interval_month_day_nano.html |   2 +-
 ...rval_year_month_to_interval_month_day_nano.html |   2 +-
 arrow_cast/cast/fn.cast_list.html                  |   2 +-
 .../cast/fn.cast_list_to_fixed_size_list.html      |   2 +-
 arrow_cast/cast/fn.cast_list_values.html           |   2 +-
 .../cast/fn.cast_month_day_nano_to_duration.html   |   2 +-
 arrow_cast/cast/fn.cast_numeric_arrays.html        |   2 +-
 arrow_cast/cast/fn.cast_numeric_to_binary.html     |   2 +-
 arrow_cast/cast/fn.cast_numeric_to_bool.html       |   2 +-
 arrow_cast/cast/fn.cast_reinterpret_arrays.html    |   2 +-
 .../cast/fn.cast_string_to_day_time_interval.html  |   2 +-
 arrow_cast/cast/fn.cast_string_to_decimal.html     |   2 +-
 arrow_cast/cast/fn.cast_string_to_interval.html    |   2 +-
 .../fn.cast_string_to_month_day_nano_interval.html |   2 +-
 arrow_cast/cast/fn.cast_string_to_timestamp.html   |   2 +-
 .../cast/fn.cast_string_to_timestamp_impl.html     |   2 +-
 .../fn.cast_string_to_year_month_interval.html     |   2 +-
 arrow_cast/cast/fn.cast_to_dictionary.html         |   2 +-
 arrow_cast/cast/fn.cast_utf8_to_boolean.html       |   2 +-
 .../cast/fn.cast_values_to_fixed_size_list.html    |   2 +-
 arrow_cast/cast/fn.cast_values_to_list.html        |   2 +-
 arrow_cast/cast/fn.cast_with_options.html          |   2 +-
 ...n.convert_to_bigger_or_equal_scale_decimal.html |   2 +-
 .../cast/fn.convert_to_smaller_scale_decimal.html  |   2 +-
 arrow_cast/cast/fn.dictionary_cast.html            |   2 +-
 arrow_cast/cast/fn.make_timestamp_array.html       |   2 +-
 arrow_cast/cast/fn.numeric_cast.html               |   2 +-
 arrow_cast/cast/fn.numeric_to_bool_cast.html       |   2 +-
 arrow_cast/cast/fn.pack_byte_to_dictionary.html    |   2 +-
 arrow_cast/cast/fn.pack_numeric_to_dictionary.html |   2 +-
 arrow_cast/cast/fn.parse_string.html               |   2 +-
 .../cast/fn.parse_string_to_decimal_native.html    |   2 +-
 arrow_cast/cast/fn.string_to_decimal_cast.html     |   2 +-
 arrow_cast/cast/fn.time_unit_multiple.html         |   2 +-
 arrow_cast/cast/fn.try_numeric_cast.html           |   2 +-
 arrow_cast/cast/fn.unpack_dictionary.html          |   2 +-
 arrow_cast/cast/fn.value_to_string.html            |   2 +-
 arrow_cast/cast/index.html                         |   2 +-
 arrow_cast/cast/struct.CastOptions.html            |   6 +-
 arrow_cast/cast/trait.DecimalCast.html             |   4 +-
 arrow_cast/display/enum.DurationFormat.html        |   6 +-
 arrow_cast/display/enum.FormatError.html           |   8 +-
 arrow_cast/display/fn.array_format.html            |   2 +-
 arrow_cast/display/fn.array_value_to_string.html   |   2 +-
 arrow_cast/display/fn.date32_to_date.html          |   2 +-
 arrow_cast/display/fn.lexical_to_string.html       |   2 +-
 arrow_cast/display/fn.make_formatter.html          |   2 +-
 arrow_cast/display/fn.write_list.html              |   2 +-
 arrow_cast/display/fn.write_timestamp.html         |   2 +-
 arrow_cast/display/index.html                      |   2 +-
 arrow_cast/display/macro.decimal_display.html      |   2 +-
 arrow_cast/display/macro.duration_display.html     |   2 +-
 arrow_cast/display/macro.duration_fmt.html         |   2 +-
 arrow_cast/display/macro.primitive_display.html    |   2 +-
 .../display/macro.primitive_display_float.html     |   2 +-
 arrow_cast/display/macro.temporal_display.html     |   2 +-
 arrow_cast/display/macro.timestamp_display.html    |   2 +-
 arrow_cast/display/struct.ArrayFormat.html         |   6 +-
 arrow_cast/display/struct.ArrayFormatter.html      |   6 +-
 arrow_cast/display/struct.FormatOptions.html       |   6 +-
 arrow_cast/display/struct.ValueFormatter.html      |   6 +-
 arrow_cast/display/trait.DisplayIndex.html         |   2 +-
 arrow_cast/display/trait.DisplayIndexState.html    |   2 +-
 arrow_cast/display/type.FieldDisplay.html          |   2 +-
 arrow_cast/display/type.FormatResult.html          |   2 +-
 arrow_cast/display/type.TimeFormat.html            |   2 +-
 arrow_cast/index.html                              |   2 +-
 arrow_cast/parse/constant.EPOCH_DAYS_FROM_CE.html  |   2 +-
 .../constant.ERR_NANOSECONDS_NOT_SUPPORTED.html    |   2 +-
 arrow_cast/parse/constant.INTERVAL_PRECISION.html  |   2 +-
 arrow_cast/parse/constant.NANOS_PER_HOUR.html      |   2 +-
 arrow_cast/parse/constant.NANOS_PER_MILLIS.html    |   2 +-
 arrow_cast/parse/constant.NANOS_PER_MINUTE.html    |   2 +-
 arrow_cast/parse/constant.NANOS_PER_SECOND.html    |   2 +-
 arrow_cast/parse/enum.IntervalUnit.html            |   6 +-
 arrow_cast/parse/fn.parse_date.html                |   2 +-
 arrow_cast/parse/fn.parse_decimal.html             |   2 +-
 arrow_cast/parse/fn.parse_interval_components.html |   2 +-
 arrow_cast/parse/fn.parse_interval_day_time.html   |   2 +-
 .../parse/fn.parse_interval_month_day_nano.html    |   2 +-
 arrow_cast/parse/fn.parse_interval_year_month.html |   2 +-
 arrow_cast/parse/fn.parse_nanos.html               |   2 +-
 arrow_cast/parse/fn.string_to_datetime.html        |   2 +-
 arrow_cast/parse/fn.string_to_time.html            |   2 +-
 .../parse/fn.string_to_time_nanoseconds.html       |   2 +-
 arrow_cast/parse/fn.string_to_timestamp_nanos.html |   2 +-
 arrow_cast/parse/fn.to_timestamp_nanos.html        |   2 +-
 arrow_cast/parse/index.html                        |   2 +-
 arrow_cast/parse/macro.parser_primitive.html       |   2 +-
 arrow_cast/parse/struct.Interval.html              |   6 +-
 arrow_cast/parse/struct.IntervalAmount.html        |   6 +-
 arrow_cast/parse/struct.IntervalParseConfig.html   |   6 +-
 arrow_cast/parse/struct.TimestampParser.html       |   6 +-
 arrow_cast/parse/trait.Parser.html                 |   2 +-
 arrow_cast/parse/type.MonthDayNano.html            |   2 +-
 arrow_cast/pretty/fn.create_column.html            |   2 +-
 arrow_cast/pretty/fn.create_table.html             |   2 +-
 arrow_cast/pretty/fn.pretty_format_batches.html    |   2 +-
 .../fn.pretty_format_batches_with_options.html     |   2 +-
 arrow_cast/pretty/fn.pretty_format_columns.html    |   2 +-
 .../fn.pretty_format_columns_with_options.html     |   2 +-
 arrow_cast/pretty/fn.print_batches.html            |   2 +-
 arrow_cast/pretty/fn.print_columns.html            |   2 +-
 arrow_cast/pretty/index.html                       |   2 +-
 arrow_csv/all.html                                 |   2 +-
 arrow_csv/fn.map_csv_error.html                    |   2 +-
 arrow_csv/index.html                               |   2 +-
 arrow_csv/reader/fn.build_boolean_array.html       |   2 +-
 arrow_csv/reader/fn.build_decimal_array.html       |   2 +-
 arrow_csv/reader/fn.build_primitive_array.html     |   2 +-
 arrow_csv/reader/fn.build_timestamp_array.html     |   2 +-
 .../reader/fn.build_timestamp_array_impl.html      |   2 +-
 arrow_csv/reader/fn.infer_file_schema.html         |   2 +-
 arrow_csv/reader/fn.infer_reader_schema.html       |   2 +-
 arrow_csv/reader/fn.infer_schema_from_files.html   |   2 +-
 arrow_csv/reader/fn.parse.html                     |   2 +-
 arrow_csv/reader/fn.parse_bool.html                |   2 +-
 arrow_csv/reader/index.html                        |   2 +-
 .../records/constant.AVERAGE_FIELD_SIZE.html       |   2 +-
 .../reader/records/constant.MIN_CAPACITY.html      |   2 +-
 arrow_csv/reader/records/index.html                |   2 +-
 arrow_csv/reader/records/struct.RecordDecoder.html |   6 +-
 arrow_csv/reader/records/struct.StringRecord.html  |   6 +-
 arrow_csv/reader/records/struct.StringRecords.html |   6 +-
 arrow_csv/reader/struct.BufReader.html             |   6 +-
 arrow_csv/reader/struct.Decoder.html               |   6 +-
 arrow_csv/reader/struct.Format.html                |   6 +-
 arrow_csv/reader/struct.InferredDataType.html      |   6 +-
 arrow_csv/reader/struct.NullRegex.html             |   6 +-
 arrow_csv/reader/struct.REGEX_SET.html             |   6 +-
 arrow_csv/reader/struct.ReaderBuilder.html         |   6 +-
 arrow_csv/reader/type.Bounds.html                  |   2 +-
 arrow_csv/reader/type.Reader.html                  |   2 +-
 arrow_csv/writer/constant.DEFAULT_NULL_VALUE.html  |   2 +-
 arrow_csv/writer/index.html                        |   2 +-
 arrow_csv/writer/struct.Writer.html                |   6 +-
 arrow_csv/writer/struct.WriterBuilder.html         |   6 +-
 arrow_data/all.html                                |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 arrow_data/bit_iterator/index.html                 |   2 +-
 .../bit_iterator/struct.BitIndexIterator.html      |   6 +-
 arrow_data/bit_iterator/struct.BitIterator.html    |   6 +-
 .../bit_iterator/struct.BitSliceIterator.html      |   6 +-
 arrow_data/bit_mask/fn.set_bits.html               |   2 +-
 arrow_data/bit_mask/index.html                     |   2 +-
 arrow_data/data/enum.BufferSpec.html               |   6 +-
 arrow_data/data/fn.contains_nulls.html             |   2 +-
 arrow_data/data/fn.count_nulls.html                |   2 +-
 arrow_data/data/fn.into_buffers.html               |   2 +-
 arrow_data/data/fn.layout.html                     |   2 +-
 arrow_data/data/fn.new_buffers.html                |   2 +-
 arrow_data/data/index.html                         |   2 +-
 arrow_data/data/struct.ArrayData.html              |   6 +-
 arrow_data/data/struct.ArrayDataBuilder.html       |   6 +-
 arrow_data/data/struct.DataTypeLayout.html         |   6 +-
 arrow_data/data/type.ArrayDataRef.html             |   2 +-
 .../decimal/constant.DECIMAL128_MAX_PRECISION.html |   2 +-
 .../decimal/constant.DECIMAL128_MAX_SCALE.html     |   2 +-
 .../decimal/constant.DECIMAL256_MAX_PRECISION.html |   2 +-
 .../decimal/constant.DECIMAL256_MAX_SCALE.html     |   2 +-
 .../decimal/constant.DECIMAL_DEFAULT_SCALE.html    |   2 +-
 ...AX_DECIMAL_BYTES_FOR_LARGER_EACH_PRECISION.html |   2 +-
 .../constant.MAX_DECIMAL_FOR_EACH_PRECISION.html   |   2 +-
 ...IN_DECIMAL_BYTES_FOR_LARGER_EACH_PRECISION.html |   2 +-
 .../constant.MIN_DECIMAL_FOR_EACH_PRECISION.html   |   2 +-
 .../decimal/fn.validate_decimal256_precision.html  |   2 +-
 .../decimal/fn.validate_decimal_precision.html     |   2 +-
 arrow_data/decimal/index.html                      |   2 +-
 arrow_data/enum.BufferSpec.html                    |   6 +-
 arrow_data/equal/boolean/fn.boolean_equal.html     |   2 +-
 arrow_data/equal/boolean/index.html                |   2 +-
 .../equal/dictionary/fn.dictionary_equal.html      |   2 +-
 arrow_data/equal/dictionary/index.html             |   2 +-
 .../equal/fixed_binary/fn.fixed_binary_equal.html  |   2 +-
 arrow_data/equal/fixed_binary/index.html           |   2 +-
 .../equal/fixed_list/fn.fixed_list_equal.html      |   2 +-
 arrow_data/equal/fixed_list/index.html             |   2 +-
 arrow_data/equal/fn.equal.html                     |   2 +-
 arrow_data/equal/fn.equal_range.html               |   2 +-
 arrow_data/equal/fn.equal_values.html              |   2 +-
 arrow_data/equal/index.html                        |   2 +-
 arrow_data/equal/list/fn.lengths_equal.html        |   2 +-
 arrow_data/equal/list/fn.list_equal.html           |   2 +-
 arrow_data/equal/list/index.html                   |   2 +-
 arrow_data/equal/null/fn.null_equal.html           |   2 +-
 arrow_data/equal/null/index.html                   |   2 +-
 ...constant.NULL_SLICES_SELECTIVITY_THRESHOLD.html |   2 +-
 arrow_data/equal/primitive/fn.primitive_equal.html |   2 +-
 arrow_data/equal/primitive/index.html              |   2 +-
 arrow_data/equal/run/fn.run_equal.html             |   2 +-
 arrow_data/equal/run/index.html                    |   2 +-
 .../equal/structure/fn.equal_child_values.html     |   2 +-
 arrow_data/equal/structure/fn.struct_equal.html    |   2 +-
 arrow_data/equal/structure/index.html              |   2 +-
 arrow_data/equal/union/fn.equal_dense.html         |   2 +-
 arrow_data/equal/union/fn.equal_sparse.html        |   2 +-
 arrow_data/equal/union/fn.union_equal.html         |   2 +-
 arrow_data/equal/union/index.html                  |   2 +-
 arrow_data/equal/utils/fn.base_equal.html          |   2 +-
 arrow_data/equal/utils/fn.equal_bits.html          |   2 +-
 arrow_data/equal/utils/fn.equal_len.html           |   2 +-
 arrow_data/equal/utils/fn.equal_nulls.html         |   2 +-
 arrow_data/equal/utils/index.html                  |   2 +-
 .../equal/variable_size/fn.offset_value_equal.html |   2 +-
 .../variable_size/fn.variable_sized_equal.html     |   2 +-
 arrow_data/equal/variable_size/index.html          |   2 +-
 arrow_data/ffi/fn.align_nulls.html                 |   2 +-
 arrow_data/ffi/fn.release_array.html               |   2 +-
 arrow_data/ffi/index.html                          |   2 +-
 arrow_data/ffi/struct.ArrayPrivateData.html        |   6 +-
 arrow_data/ffi/struct.FFI_ArrowArray.html          |   6 +-
 arrow_data/fn.layout.html                          |   2 +-
 arrow_data/index.html                              |   2 +-
 arrow_data/struct.ArrayData.html                   |   6 +-
 arrow_data/struct.ArrayDataBuilder.html            |   6 +-
 arrow_data/struct.DataTypeLayout.html              |   6 +-
 arrow_data/transform/boolean/fn.build_extend.html  |   2 +-
 arrow_data/transform/boolean/fn.extend_nulls.html  |   2 +-
 arrow_data/transform/boolean/index.html            |   2 +-
 arrow_data/transform/enum.Capacities.html          |   6 +-
 .../transform/fixed_binary/fn.build_extend.html    |   2 +-
 .../transform/fixed_binary/fn.extend_nulls.html    |   2 +-
 arrow_data/transform/fixed_binary/index.html       |   2 +-
 .../transform/fixed_size_list/fn.build_extend.html |   2 +-
 .../transform/fixed_size_list/fn.extend_nulls.html |   2 +-
 arrow_data/transform/fixed_size_list/index.html    |   2 +-
 arrow_data/transform/fn.build_extend.html          |   2 +-
 .../transform/fn.build_extend_dictionary.html      |   2 +-
 .../transform/fn.build_extend_null_bits.html       |   2 +-
 arrow_data/transform/fn.build_extend_nulls.html    |   2 +-
 .../fn.preallocate_offset_and_binary_buffer.html   |   2 +-
 arrow_data/transform/index.html                    |   2 +-
 arrow_data/transform/list/fn.build_extend.html     |   2 +-
 arrow_data/transform/list/fn.extend_nulls.html     |   2 +-
 arrow_data/transform/list/index.html               |   2 +-
 arrow_data/transform/null/fn.build_extend.html     |   2 +-
 arrow_data/transform/null/fn.extend_nulls.html     |   2 +-
 arrow_data/transform/null/index.html               |   2 +-
 .../transform/primitive/fn.build_extend.html       |   2 +-
 .../primitive/fn.build_extend_with_offset.html     |   2 +-
 .../transform/primitive/fn.extend_nulls.html       |   2 +-
 arrow_data/transform/primitive/index.html          |   2 +-
 arrow_data/transform/struct.MutableArrayData.html  |   6 +-
 arrow_data/transform/struct._MutableArrayData.html |   6 +-
 .../transform/structure/fn.build_extend.html       |   2 +-
 .../transform/structure/fn.extend_nulls.html       |   2 +-
 arrow_data/transform/structure/index.html          |   2 +-
 arrow_data/transform/type.Extend.html              |   2 +-
 arrow_data/transform/type.ExtendNullBits.html      |   2 +-
 arrow_data/transform/type.ExtendNulls.html         |   2 +-
 .../transform/union/fn.build_extend_dense.html     |   2 +-
 .../transform/union/fn.build_extend_sparse.html    |   2 +-
 .../transform/union/fn.extend_nulls_dense.html     |   2 +-
 .../transform/union/fn.extend_nulls_sparse.html    |   2 +-
 arrow_data/transform/union/index.html              |   2 +-
 arrow_data/transform/utils/fn.extend_offsets.html  |   2 +-
 arrow_data/transform/utils/fn.get_last_offset.html |   2 +-
 arrow_data/transform/utils/fn.resize_for_bits.html |   2 +-
 arrow_data/transform/utils/index.html              |   2 +-
 .../transform/variable_size/fn.build_extend.html   |   2 +-
 .../transform/variable_size/fn.extend_nulls.html   |   2 +-
 .../variable_size/fn.extend_offset_values.html     |   2 +-
 arrow_data/transform/variable_size/index.html      |   2 +-
 arrow_data/type.ArrayDataRef.html                  |   2 +-
 arrow_file_to_stream/all.html                      |   2 +-
 arrow_file_to_stream/fn.main.html                  |   4 +-
 arrow_file_to_stream/index.html                    |   2 +-
 arrow_file_to_stream/struct.Args.html              |   8 +-
 arrow_flight/all.html                              |   2 +-
 arrow_flight/client/index.html                     |   2 +-
 arrow_flight/client/struct.FlightClient.html       |  12 +-
 arrow_flight/decode/enum.DecodedPayload.html       |  14 +-
 arrow_flight/decode/index.html                     |  12 +-
 arrow_flight/decode/struct.DecodedFlightData.html  |   8 +-
 arrow_flight/decode/struct.FlightDataDecoder.html  |  12 +-
 .../decode/struct.FlightRecordBatchStream.html     |  14 +-
 arrow_flight/decode/struct.FlightStreamState.html  |  14 +-
 ...constant.GRPC_TARGET_MAX_FLIGHT_SIZE_BYTES.html |   2 +-
 arrow_flight/encode/enum.DictionaryHandling.html   |  12 +-
 arrow_flight/encode/fn.hydrate_dictionary.html     |   6 +-
 .../encode/fn.prepare_batch_for_flight.html        |   8 +-
 .../encode/fn.prepare_schema_for_flight.html       |   4 +-
 .../encode/fn.split_batch_for_grpc_response.html   |   6 +-
 arrow_flight/encode/index.html                     |  10 +-
 arrow_flight/encode/struct.FlightDataEncoder.html  |  24 +-
 .../encode/struct.FlightDataEncoderBuilder.html    |  32 +-
 arrow_flight/encode/struct.FlightIpcEncoder.html   |  18 +-
 arrow_flight/error/enum.FlightError.html           |  12 +-
 arrow_flight/error/index.html                      |   2 +-
 arrow_flight/error/type.Result.html                |   2 +-
 .../flight_descriptor/enum.DescriptorType.html     |   8 +-
 arrow_flight/flight_descriptor/index.html          |   2 +-
 arrow_flight/flight_service_client/index.html      |   2 +-
 .../struct.FlightServiceClient.html                |   8 +-
 arrow_flight/flight_service_server/index.html      |   2 +-
 .../struct.FlightServiceServer.html                |  14 +-
 .../flight_service_server/trait.FlightService.html |   2 +-
 arrow_flight/fn.flight_schema_as_encoded_data.html |   8 +-
 arrow_flight/fn.flight_schema_as_flatbuffer.html   |   6 +-
 arrow_flight/fn.limited_fmt.html                   |   2 +-
 arrow_flight/fn.schema_to_ipc_format.html          |   4 +-
 .../gen/flight_descriptor/enum.DescriptorType.html |   8 +-
 arrow_flight/gen/flight_descriptor/index.html      |   2 +-
 arrow_flight/gen/flight_service_client/index.html  |   2 +-
 .../struct.FlightServiceClient.html                |   8 +-
 arrow_flight/gen/flight_service_server/index.html  |   2 +-
 .../struct.FlightServiceServer.html                |  14 +-
 .../gen/flight_service_server/struct._Inner.html   |   8 +-
 .../flight_service_server/trait.FlightService.html |   2 +-
 arrow_flight/gen/index.html                        |   2 +-
 arrow_flight/gen/struct.Action.html                |   8 +-
 arrow_flight/gen/struct.ActionType.html            |   8 +-
 arrow_flight/gen/struct.BasicAuth.html             |   8 +-
 arrow_flight/gen/struct.Criteria.html              |   8 +-
 arrow_flight/gen/struct.Empty.html                 |   8 +-
 arrow_flight/gen/struct.FlightData.html            |  16 +-
 arrow_flight/gen/struct.FlightDescriptor.html      |  10 +-
 arrow_flight/gen/struct.FlightEndpoint.html        |  10 +-
 arrow_flight/gen/struct.FlightInfo.html            |  16 +-
 arrow_flight/gen/struct.HandshakeRequest.html      |   8 +-
 arrow_flight/gen/struct.HandshakeResponse.html     |   8 +-
 arrow_flight/gen/struct.Location.html              |  10 +-
 arrow_flight/gen/struct.PutResult.html             |   8 +-
 arrow_flight/gen/struct.Result.html                |   8 +-
 arrow_flight/gen/struct.SchemaResult.html          |  10 +-
 arrow_flight/gen/struct.Ticket.html                |   8 +-
 arrow_flight/index.html                            |   6 +-
 arrow_flight/sql/client/enum.ArrowFlightData.html  |  12 +-
 .../sql/client/fn.arrow_data_from_flight_data.html |   6 +-
 .../sql/client/fn.decode_error_to_arrow_error.html |   4 +-
 .../sql/client/fn.flight_error_to_arrow_error.html |   4 +-
 .../sql/client/fn.status_to_arrow_error.html       |   4 +-
 arrow_flight/sql/client/index.html                 |   2 +-
 .../sql/client/struct.FlightSqlServiceClient.html  |  48 +--
 .../sql/client/struct.PreparedStatement.html       |  34 +-
 ...nt.ACTION_BEGIN_SAVEPOINT_REQUEST_TYPE_URL.html |   2 +-
 ...ant.ACTION_BEGIN_SAVEPOINT_RESULT_TYPE_URL.html |   2 +-
 ....ACTION_BEGIN_TRANSACTION_REQUEST_TYPE_URL.html |   2 +-
 ...t.ACTION_BEGIN_TRANSACTION_RESULT_TYPE_URL.html |   2 +-
 ...stant.ACTION_CANCEL_QUERY_REQUEST_TYPE_URL.html |   2 +-
 ...nstant.ACTION_CANCEL_QUERY_RESULT_TYPE_URL.html |   2 +-
 ..._CLOSE_PREPARED_STATEMENT_REQUEST_TYPE_URL.html |   2 +-
 ...CREATE_PREPARED_STATEMENT_REQUEST_TYPE_URL.html |   2 +-
 ..._CREATE_PREPARED_STATEMENT_RESULT_TYPE_URL.html |   2 +-
 ...E_PREPARED_SUBSTRAIT_PLAN_REQUEST_TYPE_URL.html |   2 +-
 ...tant.ACTION_END_SAVEPOINT_REQUEST_TYPE_URL.html |   2 +-
 ...nt.ACTION_END_TRANSACTION_REQUEST_TYPE_URL.html |   2 +-
 .../constant.COMMAND_GET_CATALOGS_TYPE_URL.html    |   2 +-
 ...stant.COMMAND_GET_CROSS_REFERENCE_TYPE_URL.html |   2 +-
 .../constant.COMMAND_GET_DB_SCHEMAS_TYPE_URL.html  |   2 +-
 ...onstant.COMMAND_GET_EXPORTED_KEYS_TYPE_URL.html |   2 +-
 ...onstant.COMMAND_GET_IMPORTED_KEYS_TYPE_URL.html |   2 +-
 ...constant.COMMAND_GET_PRIMARY_KEYS_TYPE_URL.html |   2 +-
 .../constant.COMMAND_GET_SQL_INFO_TYPE_URL.html    |   2 +-
 .../sql/constant.COMMAND_GET_TABLES_TYPE_URL.html  |   2 +-
 .../constant.COMMAND_GET_TABLE_TYPES_TYPE_URL.html |   2 +-
 ...nstant.COMMAND_GET_XDBC_TYPE_INFO_TYPE_URL.html |   2 +-
 ....COMMAND_PREPARED_STATEMENT_QUERY_TYPE_URL.html |   2 +-
 ...COMMAND_PREPARED_STATEMENT_UPDATE_TYPE_URL.html |   2 +-
 .../constant.COMMAND_STATEMENT_QUERY_TYPE_URL.html |   2 +-
 ....COMMAND_STATEMENT_SUBSTRAIT_PLAN_TYPE_URL.html |   2 +-
 ...constant.COMMAND_STATEMENT_UPDATE_TYPE_URL.html |   2 +-
 .../constant.DO_PUT_UPDATE_RESULT_TYPE_URL.html    |   2 +-
 .../constant.TICKET_STATEMENT_QUERY_TYPE_URL.html  |   2 +-
 arrow_flight/sql/enum.Command.html                 |  10 +-
 arrow_flight/sql/enum.Nullable.html                |   8 +-
 arrow_flight/sql/enum.Searchable.html              |   8 +-
 arrow_flight/sql/enum.SqlInfo.html                 |   8 +-
 arrow_flight/sql/enum.SqlNullOrdering.html         |   8 +-
 .../sql/enum.SqlOuterJoinsSupportLevel.html        |   8 +-
 .../sql/enum.SqlSupportedCaseSensitivity.html      |   8 +-
 .../sql/enum.SqlSupportedElementActions.html       |   8 +-
 arrow_flight/sql/enum.SqlSupportedGroupBy.html     |   8 +-
 .../sql/enum.SqlSupportedPositionedCommands.html   |   8 +-
 .../sql/enum.SqlSupportedResultSetConcurrency.html |   8 +-
 .../sql/enum.SqlSupportedResultSetType.html        |   8 +-
 arrow_flight/sql/enum.SqlSupportedSubqueries.html  |   8 +-
 arrow_flight/sql/enum.SqlSupportedTransaction.html |   8 +-
 .../sql/enum.SqlSupportedTransactions.html         |   8 +-
 arrow_flight/sql/enum.SqlSupportedUnions.html      |   8 +-
 arrow_flight/sql/enum.SqlSupportsConvert.html      |   8 +-
 .../sql/enum.SqlTransactionIsolationLevel.html     |   8 +-
 arrow_flight/sql/enum.SupportedSqlGrammar.html     |   8 +-
 arrow_flight/sql/enum.UpdateDeleteRules.html       |   8 +-
 arrow_flight/sql/enum.XdbcDataType.html            |   8 +-
 arrow_flight/sql/enum.XdbcDatetimeSubcode.html     |   8 +-
 .../enum.CancelResult.html                         |   8 +-
 .../sql/gen/action_cancel_query_result/index.html  |   2 +-
 .../enum.EndSavepoint.html                         |   8 +-
 .../gen/action_end_savepoint_request/index.html    |   2 +-
 .../enum.EndTransaction.html                       |   8 +-
 .../gen/action_end_transaction_request/index.html  |   2 +-
 arrow_flight/sql/gen/enum.Nullable.html            |   8 +-
 arrow_flight/sql/gen/enum.Searchable.html          |   8 +-
 arrow_flight/sql/gen/enum.SqlInfo.html             |   8 +-
 arrow_flight/sql/gen/enum.SqlNullOrdering.html     |   8 +-
 .../sql/gen/enum.SqlOuterJoinsSupportLevel.html    |   8 +-
 .../sql/gen/enum.SqlSupportedCaseSensitivity.html  |   8 +-
 .../sql/gen/enum.SqlSupportedElementActions.html   |   8 +-
 arrow_flight/sql/gen/enum.SqlSupportedGroupBy.html |   8 +-
 .../gen/enum.SqlSupportedPositionedCommands.html   |   8 +-
 .../gen/enum.SqlSupportedResultSetConcurrency.html |   8 +-
 .../sql/gen/enum.SqlSupportedResultSetType.html    |   8 +-
 .../sql/gen/enum.SqlSupportedSubqueries.html       |   8 +-
 .../sql/gen/enum.SqlSupportedTransaction.html      |   8 +-
 .../sql/gen/enum.SqlSupportedTransactions.html     |   8 +-
 arrow_flight/sql/gen/enum.SqlSupportedUnions.html  |   8 +-
 arrow_flight/sql/gen/enum.SqlSupportsConvert.html  |   8 +-
 .../sql/gen/enum.SqlTransactionIsolationLevel.html |   8 +-
 .../gen/enum.SupportedAnsi92SqlGrammarLevel.html   |   8 +-
 arrow_flight/sql/gen/enum.SupportedSqlGrammar.html |   8 +-
 arrow_flight/sql/gen/enum.UpdateDeleteRules.html   |   8 +-
 arrow_flight/sql/gen/enum.XdbcDataType.html        |   8 +-
 arrow_flight/sql/gen/enum.XdbcDatetimeSubcode.html |   8 +-
 arrow_flight/sql/gen/index.html                    |   2 +-
 .../gen/struct.ActionBeginSavepointRequest.html    |   8 +-
 .../sql/gen/struct.ActionBeginSavepointResult.html |   8 +-
 .../gen/struct.ActionBeginTransactionRequest.html  |   8 +-
 .../gen/struct.ActionBeginTransactionResult.html   |   8 +-
 .../sql/gen/struct.ActionCancelQueryRequest.html   |   8 +-
 .../sql/gen/struct.ActionCancelQueryResult.html    |   8 +-
 ...struct.ActionClosePreparedStatementRequest.html |   8 +-
 ...truct.ActionCreatePreparedStatementRequest.html |   8 +-
 ...struct.ActionCreatePreparedStatementResult.html |   8 +-
 ...t.ActionCreatePreparedSubstraitPlanRequest.html |   8 +-
 .../sql/gen/struct.ActionEndSavepointRequest.html  |   8 +-
 .../gen/struct.ActionEndTransactionRequest.html    |   8 +-
 .../sql/gen/struct.CommandGetCatalogs.html         |   8 +-
 .../sql/gen/struct.CommandGetCrossReference.html   |   8 +-
 .../sql/gen/struct.CommandGetDbSchemas.html        |   8 +-
 .../sql/gen/struct.CommandGetExportedKeys.html     |   8 +-
 .../sql/gen/struct.CommandGetImportedKeys.html     |   8 +-
 .../sql/gen/struct.CommandGetPrimaryKeys.html      |   8 +-
 arrow_flight/sql/gen/struct.CommandGetSqlInfo.html |   8 +-
 .../sql/gen/struct.CommandGetTableTypes.html       |   8 +-
 arrow_flight/sql/gen/struct.CommandGetTables.html  |   8 +-
 .../sql/gen/struct.CommandGetXdbcTypeInfo.html     |   8 +-
 .../gen/struct.CommandPreparedStatementQuery.html  |   8 +-
 .../gen/struct.CommandPreparedStatementUpdate.html |   8 +-
 .../sql/gen/struct.CommandStatementQuery.html      |   8 +-
 .../gen/struct.CommandStatementSubstraitPlan.html  |   8 +-
 .../sql/gen/struct.CommandStatementUpdate.html     |   8 +-
 arrow_flight/sql/gen/struct.DoPutUpdateResult.html |   8 +-
 arrow_flight/sql/gen/struct.SubstraitPlan.html     |   8 +-
 .../sql/gen/struct.TicketStatementQuery.html       |   8 +-
 arrow_flight/sql/index.html                        |   2 +-
 arrow_flight/sql/macro.as_item.html                |   2 +-
 arrow_flight/sql/macro.prost_message_ext.html      |   2 +-
 .../metadata/catalogs/fn.get_catalogs_schema.html  |   4 +-
 arrow_flight/sql/metadata/catalogs/index.html      |   2 +-
 .../catalogs/static.GET_CATALOG_SCHEMA.html        |   4 +-
 .../catalogs/struct.GetCatalogsBuilder.html        |  12 +-
 .../db_schemas/fn.get_db_schemas_schema.html       |   4 +-
 arrow_flight/sql/metadata/db_schemas/index.html    |   2 +-
 .../db_schemas/static.GET_DB_SCHEMAS_SCHEMA.html   |   4 +-
 .../db_schemas/struct.GetDbSchemasBuilder.html     |  18 +-
 .../sql/metadata/fn.lexsort_to_indices.html        |   4 +-
 arrow_flight/sql/metadata/index.html               |   2 +-
 .../sql/metadata/sql_info/enum.SqlInfoValue.html   |  10 +-
 arrow_flight/sql/metadata/sql_info/index.html      |   4 +-
 .../metadata/sql_info/static.SQL_INFO_SCHEMA.html  |   4 +-
 .../sql/metadata/sql_info/static.UNION_TYPE.html   |   4 +-
 .../sql_info/struct.GetSqlInfoBuilder.html         |  10 +-
 .../sql/metadata/sql_info/struct.SqlInfoData.html  |  14 +-
 .../sql_info/struct.SqlInfoDataBuilder.html        |  10 +-
 .../sql_info/struct.SqlInfoUnionBuilder.html       |  30 +-
 .../sql/metadata/sql_info/trait.SqlInfoName.html   |   2 +-
 .../sql/metadata/struct.GetCatalogsBuilder.html    |  12 +-
 .../sql/metadata/struct.GetDbSchemasBuilder.html   |  18 +-
 .../sql/metadata/struct.GetTablesBuilder.html      |  26 +-
 arrow_flight/sql/metadata/struct.SqlInfoData.html  |  14 +-
 .../sql/metadata/struct.SqlInfoDataBuilder.html    |  10 +-
 arrow_flight/sql/metadata/struct.XdbcTypeInfo.html |   8 +-
 .../sql/metadata/struct.XdbcTypeInfoData.html      |  14 +-
 .../metadata/struct.XdbcTypeInfoDataBuilder.html   |  10 +-
 .../sql/metadata/tables/fn.get_tables_schema.html  |   4 +-
 arrow_flight/sql/metadata/tables/index.html        |   2 +-
 ...tic.GET_TABLES_SCHEMA_WITHOUT_TABLE_SCHEMA.html |   4 +-
 ...static.GET_TABLES_SCHEMA_WITH_TABLE_SCHEMA.html |   4 +-
 .../metadata/tables/struct.GetTablesBuilder.html   |  26 +-
 arrow_flight/sql/metadata/xdbc_info/index.html     |   2 +-
 .../xdbc_info/static.GET_XDBC_INFO_SCHEMA.html     |   4 +-
 .../xdbc_info/struct.GetXdbcTypeInfoBuilder.html   |  10 +-
 .../metadata/xdbc_info/struct.XdbcTypeInfo.html    |   8 +-
 .../xdbc_info/struct.XdbcTypeInfoData.html         |  14 +-
 .../xdbc_info/struct.XdbcTypeInfoDataBuilder.html  |  10 +-
 .../sql/server/fn.arrow_error_to_status.html       |   4 +-
 .../sql/server/fn.decode_error_to_status.html      |   2 +-
 arrow_flight/sql/server/index.html                 |   2 +-
 .../sql/server/static.BEGIN_SAVEPOINT.html         |   2 +-
 .../sql/server/static.BEGIN_TRANSACTION.html       |   2 +-
 arrow_flight/sql/server/static.CANCEL_QUERY.html   |   2 +-
 .../server/static.CLOSE_PREPARED_STATEMENT.html    |   2 +-
 .../server/static.CREATE_PREPARED_STATEMENT.html   |   2 +-
 .../static.CREATE_PREPARED_SUBSTRAIT_PLAN.html     |   2 +-
 arrow_flight/sql/server/static.END_SAVEPOINT.html  |   2 +-
 .../sql/server/static.END_TRANSACTION.html         |   2 +-
 .../server/struct.PeekableFlightDataStream.html    |   6 +-
 .../sql/server/trait.FlightSqlService.html         |   2 +-
 .../sql/struct.ActionBeginSavepointRequest.html    |   8 +-
 .../sql/struct.ActionBeginSavepointResult.html     |   8 +-
 .../sql/struct.ActionBeginTransactionRequest.html  |   8 +-
 .../sql/struct.ActionBeginTransactionResult.html   |   8 +-
 .../sql/struct.ActionCancelQueryRequest.html       |   8 +-
 .../sql/struct.ActionCancelQueryResult.html        |   8 +-
 ...struct.ActionClosePreparedStatementRequest.html |   8 +-
 ...truct.ActionCreatePreparedStatementRequest.html |   8 +-
 ...struct.ActionCreatePreparedStatementResult.html |   8 +-
 ...t.ActionCreatePreparedSubstraitPlanRequest.html |   8 +-
 .../sql/struct.ActionEndSavepointRequest.html      |   8 +-
 .../sql/struct.ActionEndTransactionRequest.html    |   8 +-
 arrow_flight/sql/struct.Any.html                   |  12 +-
 arrow_flight/sql/struct.CommandGetCatalogs.html    |   8 +-
 .../sql/struct.CommandGetCrossReference.html       |   8 +-
 arrow_flight/sql/struct.CommandGetDbSchemas.html   |   8 +-
 .../sql/struct.CommandGetExportedKeys.html         |   8 +-
 .../sql/struct.CommandGetImportedKeys.html         |   8 +-
 arrow_flight/sql/struct.CommandGetPrimaryKeys.html |   8 +-
 arrow_flight/sql/struct.CommandGetSqlInfo.html     |   8 +-
 arrow_flight/sql/struct.CommandGetTableTypes.html  |   8 +-
 arrow_flight/sql/struct.CommandGetTables.html      |   8 +-
 .../sql/struct.CommandGetXdbcTypeInfo.html         |   8 +-
 .../sql/struct.CommandPreparedStatementQuery.html  |   8 +-
 .../sql/struct.CommandPreparedStatementUpdate.html |   8 +-
 arrow_flight/sql/struct.CommandStatementQuery.html |   8 +-
 .../sql/struct.CommandStatementSubstraitPlan.html  |   8 +-
 .../sql/struct.CommandStatementUpdate.html         |   8 +-
 arrow_flight/sql/struct.DoPutUpdateResult.html     |   8 +-
 arrow_flight/sql/struct.SubstraitPlan.html         |   8 +-
 arrow_flight/sql/struct.TicketStatementQuery.html  |   8 +-
 arrow_flight/sql/trait.ProstMessageExt.html        |   2 +-
 arrow_flight/struct.Action.html                    |   8 +-
 arrow_flight/struct.ActionType.html                |   8 +-
 arrow_flight/struct.BasicAuth.html                 |   8 +-
 arrow_flight/struct.Criteria.html                  |   8 +-
 arrow_flight/struct.Empty.html                     |   8 +-
 arrow_flight/struct.FlightData.html                |  16 +-
 arrow_flight/struct.FlightDescriptor.html          |  10 +-
 arrow_flight/struct.FlightEndpoint.html            |  10 +-
 arrow_flight/struct.FlightInfo.html                |  16 +-
 arrow_flight/struct.HandshakeRequest.html          |   8 +-
 arrow_flight/struct.HandshakeResponse.html         |   8 +-
 arrow_flight/struct.IpcMessage.html                | 176 ++++----
 arrow_flight/struct.Location.html                  |  10 +-
 arrow_flight/struct.PutResult.html                 |   8 +-
 arrow_flight/struct.Result.html                    |   8 +-
 arrow_flight/struct.SchemaAsIpc.html               |  12 +-
 arrow_flight/struct.SchemaResult.html              |  10 +-
 arrow_flight/struct.Ticket.html                    |   8 +-
 .../trailers/fn.extract_lazy_trailers.html         |   2 +-
 arrow_flight/trailers/index.html                   |   2 +-
 .../trailers/struct.ExtractTrailersStream.html     |   6 +-
 arrow_flight/trailers/struct.LazyTrailers.html     |   8 +-
 arrow_flight/trailers/type.SharedTrailers.html     |   2 +-
 arrow_flight/type.ArrowResult.html                 |   8 +-
 arrow_flight/utils/fn.batches_to_flight_data.html  |   8 +-
 .../utils/fn.flight_data_from_arrow_batch.html     |   6 +-
 .../utils/fn.flight_data_from_arrow_schema.html    |   6 +-
 .../utils/fn.flight_data_to_arrow_batch.html       |   8 +-
 arrow_flight/utils/fn.flight_data_to_batches.html  |   4 +-
 .../utils/fn.flight_schema_from_arrow_schema.html  |   8 +-
 .../utils/fn.ipc_message_from_arrow_schema.html    |   8 +-
 arrow_flight/utils/index.html                      |   2 +-
 arrow_integration_test/all.html                    |   2 +-
 .../datatype/fn.data_type_from_json.html           |   4 +-
 .../datatype/fn.data_type_to_json.html             |   4 +-
 arrow_integration_test/datatype/index.html         |   2 +-
 .../field/fn.field_from_json.html                  |   4 +-
 arrow_integration_test/field/fn.field_to_json.html |   4 +-
 arrow_integration_test/field/index.html            |   2 +-
 arrow_integration_test/fn.array_from_json.html     |   6 +-
 arrow_integration_test/fn.create_null_buf.html     |   4 +-
 arrow_integration_test/fn.data_type_from_json.html |   4 +-
 arrow_integration_test/fn.data_type_to_json.html   |   4 +-
 .../fn.dictionary_array_from_json.html             |  10 +-
 arrow_integration_test/fn.field_from_json.html     |   4 +-
 arrow_integration_test/fn.field_to_json.html       |   4 +-
 .../fn.record_batch_from_json.html                 |   6 +-
 arrow_integration_test/fn.schema_from_json.html    |   4 +-
 arrow_integration_test/fn.schema_to_json.html      |   4 +-
 arrow_integration_test/index.html                  |   2 +-
 .../schema/fn.from_metadata.html                   |   2 +-
 .../schema/fn.schema_from_json.html                |   4 +-
 .../schema/fn.schema_to_json.html                  |   4 +-
 arrow_integration_test/schema/index.html           |   2 +-
 .../schema/struct.MetadataKeyValue.html            |   8 +-
 arrow_integration_test/struct.ArrowJson.html       |  12 +-
 arrow_integration_test/struct.ArrowJsonBatch.html  |  10 +-
 arrow_integration_test/struct.ArrowJsonColumn.html |   8 +-
 .../struct.ArrowJsonDictionaryBatch.html           |   8 +-
 arrow_integration_test/struct.ArrowJsonField.html  |  14 +-
 .../struct.ArrowJsonFieldDictionary.html           |   8 +-
 arrow_integration_test/struct.ArrowJsonSchema.html |  12 +-
 .../struct.DictionaryIndexType.html                |   8 +-
 arrow_integration_testing/all.html                 |   2 +-
 .../constant.AUTH_PASSWORD.html                    |   2 +-
 .../constant.AUTH_USERNAME.html                    |   2 +-
 .../auth_basic_proto/fn.authenticate.html          |   4 +-
 .../auth_basic_proto/fn.run_scenario.html          |   2 +-
 .../auth_basic_proto/index.html                    |   2 +-
 .../auth_basic_proto/type.Client.html              |   4 +-
 .../auth_basic_proto/type.Error.html               |   4 +-
 .../auth_basic_proto/type.Result.html              |   2 +-
 .../flight_client_scenarios/index.html             |   2 +-
 .../fn.consume_flight_location.html                |   8 +-
 .../fn.receive_batch_flight_data.html              |  10 +-
 .../fn.receive_schema_flight_data.html             |   6 +-
 .../integration_test/fn.run_scenario.html          |   2 +-
 .../integration_test/fn.send_batch.html            |   8 +-
 .../integration_test/fn.upload_data.html           |  10 +-
 .../integration_test/fn.verify_data.html           |   8 +-
 .../integration_test/index.html                    |   2 +-
 .../integration_test/type.Client.html              |   4 +-
 .../integration_test/type.Error.html               |   4 +-
 .../integration_test/type.Result.html              |   2 +-
 .../middleware/fn.middleware_interceptor.html      |   2 +-
 .../middleware/fn.run_scenario.html                |   2 +-
 .../flight_client_scenarios/middleware/index.html  |   2 +-
 .../middleware/type.Error.html                     |   4 +-
 .../middleware/type.Result.html                    |   2 +-
 .../auth_basic_proto/fn.scenario_setup.html        |   2 +-
 .../auth_basic_proto/index.html                    |   2 +-
 .../struct.AuthBasicProtoScenarioImpl.html         |  60 +--
 .../struct.GrpcServerCallContext.html              |   8 +-
 .../auth_basic_proto/type.Error.html               |   4 +-
 .../auth_basic_proto/type.Result.html              |   2 +-
 .../auth_basic_proto/type.TonicStream.html         |   2 +-
 .../flight_server_scenarios/fn.endpoint.html       |   4 +-
 .../flight_server_scenarios/fn.listen_on.html      |   2 +-
 .../flight_server_scenarios/index.html             |   2 +-
 .../fn.dictionary_from_message.html                |  10 +-
 .../fn.record_batch_from_message.html              |  12 +-
 .../integration_test/fn.save_uploaded_chunks.html  |  10 +-
 .../integration_test/fn.scenario_setup.html        |   2 +-
 .../integration_test/fn.send_app_metadata.html     |   4 +-
 .../integration_test/index.html                    |   2 +-
 .../integration_test/struct.FlightServiceImpl.html |  60 +--
 .../struct.IntegrationDataset.html                 |  12 +-
 .../integration_test/type.Error.html               |   4 +-
 .../integration_test/type.Result.html              |   2 +-
 .../integration_test/type.TonicStream.html         |   2 +-
 .../middleware/fn.scenario_setup.html              |   2 +-
 .../flight_server_scenarios/middleware/index.html  |   2 +-
 .../middleware/struct.MiddlewareScenarioImpl.html  |  62 +--
 .../middleware/type.Error.html                     |   4 +-
 .../middleware/type.Result.html                    |   2 +-
 .../middleware/type.TonicStream.html               |   2 +-
 .../flight_server_scenarios/type.Error.html        |   4 +-
 .../flight_server_scenarios/type.Result.html       |   2 +-
 ...s_cdata_integration_export_batch_from_json.html |   4 +-
 ..._cdata_integration_export_schema_from_json.html |   4 +-
 ...tegration_import_batch_and_compare_to_json.html |   4 +-
 ...egration_import_schema_and_compare_to_json.html |   4 +-
 .../fn.arrow_rs_free_error.html                    |   2 +-
 .../fn.canonicalize_schema.html                    |   4 +-
 ...n.cdata_integration_export_batch_from_json.html |   6 +-
 ....cdata_integration_export_schema_from_json.html |   6 +-
 ...tegration_import_batch_and_compare_to_json.html |   6 +-
 ...egration_import_schema_and_compare_to_json.html |   6 +-
 arrow_integration_testing/fn.compare_batches.html  |   4 +-
 arrow_integration_testing/fn.open_json_file.html   |   4 +-
 arrow_integration_testing/fn.read_gzip_json.html   |   4 +-
 .../fn.result_to_c_error.html                      |   2 +-
 arrow_integration_testing/index.html               |   2 +-
 arrow_integration_testing/struct.ArrowFile.html    |  14 +-
 arrow_ipc/all.html                                 |   2 +-
 .../constant.LENGTH_NO_COMPRESSED_DATA.html        |   2 +-
 .../constant.LENGTH_OF_PREFIX_DATA.html            |   2 +-
 arrow_ipc/compression/enum.CompressionCodec.html   |  18 +-
 arrow_ipc/compression/fn.compress_lz4.html         |   4 +-
 arrow_ipc/compression/fn.compress_zstd.html        |   4 +-
 arrow_ipc/compression/fn.decompress_lz4.html       |   4 +-
 arrow_ipc/compression/fn.decompress_zstd.html      |   4 +-
 .../compression/fn.read_uncompressed_size.html     |   2 +-
 arrow_ipc/compression/index.html                   |   2 +-
 arrow_ipc/constant.ARROW_MAGIC.html                |   2 +-
 arrow_ipc/constant.CONTINUATION_MARKER.html        |   2 +-
 arrow_ipc/convert/fn.build_field.html              |   4 +-
 arrow_ipc/convert/fn.fb_to_schema.html             |   4 +-
 arrow_ipc/convert/fn.get_data_type.html            |   4 +-
 arrow_ipc/convert/fn.get_fb_dictionary.html        |   4 +-
 arrow_ipc/convert/fn.get_fb_field_type.html        |   4 +-
 arrow_ipc/convert/fn.metadata_to_fb.html           |   2 +-
 arrow_ipc/convert/fn.schema_to_fb.html             |   4 +-
 arrow_ipc/convert/fn.schema_to_fb_offset.html      |   4 +-
 .../fn.try_schema_from_flatbuffer_bytes.html       |   4 +-
 .../convert/fn.try_schema_from_ipc_buffer.html     |   4 +-
 arrow_ipc/convert/index.html                       |   2 +-
 arrow_ipc/convert/struct.FBFieldType.html          |   6 +-
 arrow_ipc/gen/File/enum.FooterOffset.html          |   6 +-
 arrow_ipc/gen/File/fn.finish_footer_buffer.html    |   2 +-
 .../fn.finish_size_prefixed_footer_buffer.html     |   2 +-
 arrow_ipc/gen/File/fn.root_as_footer.html          |   2 +-
 .../gen/File/fn.root_as_footer_unchecked.html      |   2 +-
 .../gen/File/fn.root_as_footer_with_opts.html      |   2 +-
 .../gen/File/fn.size_prefixed_root_as_footer.html  |   2 +-
 .../fn.size_prefixed_root_as_footer_unchecked.html |   2 +-
 .../fn.size_prefixed_root_as_footer_with_opts.html |   2 +-
 arrow_ipc/gen/File/index.html                      |   2 +-
 arrow_ipc/gen/File/struct.Block.html               |   8 +-
 arrow_ipc/gen/File/struct.Footer.html              |   6 +-
 arrow_ipc/gen/File/struct.FooterArgs.html          |   6 +-
 arrow_ipc/gen/File/struct.FooterBuilder.html       |   6 +-
 .../constant.ENUM_MAX_BODY_COMPRESSION_METHOD.html |   2 +-
 .../constant.ENUM_MAX_COMPRESSION_TYPE.html        |   2 +-
 .../Message/constant.ENUM_MAX_MESSAGE_HEADER.html  |   2 +-
 .../constant.ENUM_MIN_BODY_COMPRESSION_METHOD.html |   2 +-
 .../constant.ENUM_MIN_COMPRESSION_TYPE.html        |   2 +-
 .../Message/constant.ENUM_MIN_MESSAGE_HEADER.html  |   2 +-
 ...nstant.ENUM_VALUES_BODY_COMPRESSION_METHOD.html |   2 +-
 .../constant.ENUM_VALUES_COMPRESSION_TYPE.html     |   2 +-
 .../constant.ENUM_VALUES_MESSAGE_HEADER.html       |   2 +-
 .../gen/Message/enum.BodyCompressionOffset.html    |   6 +-
 .../gen/Message/enum.DictionaryBatchOffset.html    |   6 +-
 arrow_ipc/gen/Message/enum.MessageOffset.html      |   6 +-
 arrow_ipc/gen/Message/enum.RecordBatchOffset.html  |   6 +-
 .../gen/Message/fn.finish_message_buffer.html      |   2 +-
 .../fn.finish_size_prefixed_message_buffer.html    |   2 +-
 arrow_ipc/gen/Message/fn.root_as_message.html      |   2 +-
 .../gen/Message/fn.root_as_message_unchecked.html  |   2 +-
 .../gen/Message/fn.root_as_message_with_opts.html  |   2 +-
 .../Message/fn.size_prefixed_root_as_message.html  |   2 +-
 ...fn.size_prefixed_root_as_message_unchecked.html |   2 +-
 ...fn.size_prefixed_root_as_message_with_opts.html |   2 +-
 arrow_ipc/gen/Message/index.html                   |   2 +-
 arrow_ipc/gen/Message/struct.BodyCompression.html  |   6 +-
 .../gen/Message/struct.BodyCompressionArgs.html    |   6 +-
 .../gen/Message/struct.BodyCompressionBuilder.html |   6 +-
 .../gen/Message/struct.BodyCompressionMethod.html  |   6 +-
 arrow_ipc/gen/Message/struct.CompressionType.html  |   8 +-
 arrow_ipc/gen/Message/struct.DictionaryBatch.html  |   6 +-
 .../gen/Message/struct.DictionaryBatchArgs.html    |   6 +-
 .../gen/Message/struct.DictionaryBatchBuilder.html |   6 +-
 arrow_ipc/gen/Message/struct.FieldNode.html        |   8 +-
 arrow_ipc/gen/Message/struct.Message.html          |   6 +-
 arrow_ipc/gen/Message/struct.MessageArgs.html      |   6 +-
 arrow_ipc/gen/Message/struct.MessageBuilder.html   |   6 +-
 arrow_ipc/gen/Message/struct.MessageHeader.html    |   6 +-
 .../struct.MessageHeaderUnionTableOffset.html      |   6 +-
 arrow_ipc/gen/Message/struct.RecordBatch.html      |   6 +-
 arrow_ipc/gen/Message/struct.RecordBatchArgs.html  |   6 +-
 .../gen/Message/struct.RecordBatchBuilder.html     |   6 +-
 .../gen/Schema/constant.ENUM_MAX_DATE_UNIT.html    |   2 +-
 .../Schema/constant.ENUM_MAX_DICTIONARY_KIND.html  |   2 +-
 .../gen/Schema/constant.ENUM_MAX_ENDIANNESS.html   |   2 +-
 .../gen/Schema/constant.ENUM_MAX_FEATURE.html      |   2 +-
 .../Schema/constant.ENUM_MAX_INTERVAL_UNIT.html    |   2 +-
 .../Schema/constant.ENUM_MAX_METADATA_VERSION.html |   2 +-
 .../gen/Schema/constant.ENUM_MAX_PRECISION.html    |   2 +-
 .../gen/Schema/constant.ENUM_MAX_TIME_UNIT.html    |   2 +-
 arrow_ipc/gen/Schema/constant.ENUM_MAX_TYPE.html   |   2 +-
 .../gen/Schema/constant.ENUM_MAX_UNION_MODE.html   |   2 +-
 .../gen/Schema/constant.ENUM_MIN_DATE_UNIT.html    |   2 +-
 .../Schema/constant.ENUM_MIN_DICTIONARY_KIND.html  |   2 +-
 .../gen/Schema/constant.ENUM_MIN_ENDIANNESS.html   |   2 +-
 .../gen/Schema/constant.ENUM_MIN_FEATURE.html      |   2 +-
 .../Schema/constant.ENUM_MIN_INTERVAL_UNIT.html    |   2 +-
 .../Schema/constant.ENUM_MIN_METADATA_VERSION.html |   2 +-
 .../gen/Schema/constant.ENUM_MIN_PRECISION.html    |   2 +-
 .../gen/Schema/constant.ENUM_MIN_TIME_UNIT.html    |   2 +-
 arrow_ipc/gen/Schema/constant.ENUM_MIN_TYPE.html   |   2 +-
 .../gen/Schema/constant.ENUM_MIN_UNION_MODE.html   |   2 +-
 .../gen/Schema/constant.ENUM_VALUES_DATE_UNIT.html |   2 +-
 .../constant.ENUM_VALUES_DICTIONARY_KIND.html      |   2 +-
 .../Schema/constant.ENUM_VALUES_ENDIANNESS.html    |   2 +-
 .../gen/Schema/constant.ENUM_VALUES_FEATURE.html   |   2 +-
 .../Schema/constant.ENUM_VALUES_INTERVAL_UNIT.html |   2 +-
 .../constant.ENUM_VALUES_METADATA_VERSION.html     |   2 +-
 .../gen/Schema/constant.ENUM_VALUES_PRECISION.html |   2 +-
 .../gen/Schema/constant.ENUM_VALUES_TIME_UNIT.html |   2 +-
 .../gen/Schema/constant.ENUM_VALUES_TYPE.html      |   2 +-
 .../Schema/constant.ENUM_VALUES_UNION_MODE.html    |   2 +-
 arrow_ipc/gen/Schema/enum.BinaryOffset.html        |   6 +-
 arrow_ipc/gen/Schema/enum.BoolOffset.html          |   6 +-
 arrow_ipc/gen/Schema/enum.DateOffset.html          |   6 +-
 arrow_ipc/gen/Schema/enum.DecimalOffset.html       |   6 +-
 .../gen/Schema/enum.DictionaryEncodingOffset.html  |   6 +-
 arrow_ipc/gen/Schema/enum.DurationOffset.html      |   6 +-
 arrow_ipc/gen/Schema/enum.FieldOffset.html         |   6 +-
 .../gen/Schema/enum.FixedSizeBinaryOffset.html     |   6 +-
 arrow_ipc/gen/Schema/enum.FixedSizeListOffset.html |   6 +-
 arrow_ipc/gen/Schema/enum.FloatingPointOffset.html |   6 +-
 arrow_ipc/gen/Schema/enum.IntOffset.html           |   6 +-
 arrow_ipc/gen/Schema/enum.IntervalOffset.html      |   6 +-
 arrow_ipc/gen/Schema/enum.KeyValueOffset.html      |   6 +-
 arrow_ipc/gen/Schema/enum.LargeBinaryOffset.html   |   6 +-
 arrow_ipc/gen/Schema/enum.LargeListOffset.html     |   6 +-
 arrow_ipc/gen/Schema/enum.LargeUtf8Offset.html     |   6 +-
 arrow_ipc/gen/Schema/enum.ListOffset.html          |   6 +-
 arrow_ipc/gen/Schema/enum.MapOffset.html           |   6 +-
 arrow_ipc/gen/Schema/enum.NullOffset.html          |   6 +-
 arrow_ipc/gen/Schema/enum.RunEndEncodedOffset.html |   6 +-
 arrow_ipc/gen/Schema/enum.SchemaOffset.html        |   6 +-
 arrow_ipc/gen/Schema/enum.Struct_Offset.html       |   6 +-
 arrow_ipc/gen/Schema/enum.TimeOffset.html          |   6 +-
 arrow_ipc/gen/Schema/enum.TimestampOffset.html     |   6 +-
 arrow_ipc/gen/Schema/enum.UnionOffset.html         |   6 +-
 arrow_ipc/gen/Schema/enum.Utf8Offset.html          |   6 +-
 arrow_ipc/gen/Schema/fn.finish_schema_buffer.html  |   2 +-
 .../fn.finish_size_prefixed_schema_buffer.html     |   2 +-
 arrow_ipc/gen/Schema/fn.root_as_schema.html        |   2 +-
 .../gen/Schema/fn.root_as_schema_unchecked.html    |   2 +-
 .../gen/Schema/fn.root_as_schema_with_opts.html    |   2 +-
 .../Schema/fn.size_prefixed_root_as_schema.html    |   2 +-
 .../fn.size_prefixed_root_as_schema_unchecked.html |   2 +-
 .../fn.size_prefixed_root_as_schema_with_opts.html |   2 +-
 arrow_ipc/gen/Schema/index.html                    |   2 +-
 arrow_ipc/gen/Schema/struct.Binary.html            |   6 +-
 arrow_ipc/gen/Schema/struct.BinaryArgs.html        |   6 +-
 arrow_ipc/gen/Schema/struct.BinaryBuilder.html     |   6 +-
 arrow_ipc/gen/Schema/struct.Bool.html              |   6 +-
 arrow_ipc/gen/Schema/struct.BoolArgs.html          |   6 +-
 arrow_ipc/gen/Schema/struct.BoolBuilder.html       |   6 +-
 arrow_ipc/gen/Schema/struct.Buffer.html            |   6 +-
 arrow_ipc/gen/Schema/struct.Date.html              |   6 +-
 arrow_ipc/gen/Schema/struct.DateArgs.html          |   6 +-
 arrow_ipc/gen/Schema/struct.DateBuilder.html       |   6 +-
 arrow_ipc/gen/Schema/struct.DateUnit.html          |   6 +-
 arrow_ipc/gen/Schema/struct.Decimal.html           |   6 +-
 arrow_ipc/gen/Schema/struct.DecimalArgs.html       |   6 +-
 arrow_ipc/gen/Schema/struct.DecimalBuilder.html    |   6 +-
 .../gen/Schema/struct.DictionaryEncoding.html      |   6 +-
 .../gen/Schema/struct.DictionaryEncodingArgs.html  |   6 +-
 .../Schema/struct.DictionaryEncodingBuilder.html   |   6 +-
 arrow_ipc/gen/Schema/struct.DictionaryKind.html    |   6 +-
 arrow_ipc/gen/Schema/struct.Duration.html          |   6 +-
 arrow_ipc/gen/Schema/struct.DurationArgs.html      |   6 +-
 arrow_ipc/gen/Schema/struct.DurationBuilder.html   |   6 +-
 arrow_ipc/gen/Schema/struct.Endianness.html        |   6 +-
 arrow_ipc/gen/Schema/struct.Feature.html           |   6 +-
 arrow_ipc/gen/Schema/struct.Field.html             |  10 +-
 arrow_ipc/gen/Schema/struct.FieldArgs.html         |   6 +-
 arrow_ipc/gen/Schema/struct.FieldBuilder.html      |   6 +-
 arrow_ipc/gen/Schema/struct.FixedSizeBinary.html   |   6 +-
 .../gen/Schema/struct.FixedSizeBinaryArgs.html     |   6 +-
 .../gen/Schema/struct.FixedSizeBinaryBuilder.html  |   6 +-
 arrow_ipc/gen/Schema/struct.FixedSizeList.html     |   6 +-
 arrow_ipc/gen/Schema/struct.FixedSizeListArgs.html |   6 +-
 .../gen/Schema/struct.FixedSizeListBuilder.html    |   6 +-
 arrow_ipc/gen/Schema/struct.FloatingPoint.html     |   6 +-
 arrow_ipc/gen/Schema/struct.FloatingPointArgs.html |   6 +-
 .../gen/Schema/struct.FloatingPointBuilder.html    |   6 +-
 arrow_ipc/gen/Schema/struct.Int.html               |   6 +-
 arrow_ipc/gen/Schema/struct.IntArgs.html           |   6 +-
 arrow_ipc/gen/Schema/struct.IntBuilder.html        |   6 +-
 arrow_ipc/gen/Schema/struct.Interval.html          |   6 +-
 arrow_ipc/gen/Schema/struct.IntervalArgs.html      |   6 +-
 arrow_ipc/gen/Schema/struct.IntervalBuilder.html   |   6 +-
 arrow_ipc/gen/Schema/struct.IntervalUnit.html      |   6 +-
 arrow_ipc/gen/Schema/struct.KeyValue.html          |   6 +-
 arrow_ipc/gen/Schema/struct.KeyValueArgs.html      |   6 +-
 arrow_ipc/gen/Schema/struct.KeyValueBuilder.html   |   6 +-
 arrow_ipc/gen/Schema/struct.LargeBinary.html       |   6 +-
 arrow_ipc/gen/Schema/struct.LargeBinaryArgs.html   |   6 +-
 .../gen/Schema/struct.LargeBinaryBuilder.html      |   6 +-
 arrow_ipc/gen/Schema/struct.LargeList.html         |   6 +-
 arrow_ipc/gen/Schema/struct.LargeListArgs.html     |   6 +-
 arrow_ipc/gen/Schema/struct.LargeListBuilder.html  |   6 +-
 arrow_ipc/gen/Schema/struct.LargeUtf8.html         |   6 +-
 arrow_ipc/gen/Schema/struct.LargeUtf8Args.html     |   6 +-
 arrow_ipc/gen/Schema/struct.LargeUtf8Builder.html  |   6 +-
 arrow_ipc/gen/Schema/struct.List.html              |   6 +-
 arrow_ipc/gen/Schema/struct.ListArgs.html          |   6 +-
 arrow_ipc/gen/Schema/struct.ListBuilder.html       |   6 +-
 arrow_ipc/gen/Schema/struct.Map.html               |   6 +-
 arrow_ipc/gen/Schema/struct.MapArgs.html           |   6 +-
 arrow_ipc/gen/Schema/struct.MapBuilder.html        |   6 +-
 arrow_ipc/gen/Schema/struct.MetadataVersion.html   |   6 +-
 arrow_ipc/gen/Schema/struct.Null.html              |   6 +-
 arrow_ipc/gen/Schema/struct.NullArgs.html          |   6 +-
 arrow_ipc/gen/Schema/struct.NullBuilder.html       |   6 +-
 arrow_ipc/gen/Schema/struct.Precision.html         |   6 +-
 arrow_ipc/gen/Schema/struct.RunEndEncoded.html     |   6 +-
 arrow_ipc/gen/Schema/struct.RunEndEncodedArgs.html |   6 +-
 .../gen/Schema/struct.RunEndEncodedBuilder.html    |   6 +-
 arrow_ipc/gen/Schema/struct.Schema.html            |   6 +-
 arrow_ipc/gen/Schema/struct.SchemaArgs.html        |   6 +-
 arrow_ipc/gen/Schema/struct.SchemaBuilder.html     |   6 +-
 arrow_ipc/gen/Schema/struct.Struct_.html           |   6 +-
 arrow_ipc/gen/Schema/struct.Struct_Args.html       |   6 +-
 arrow_ipc/gen/Schema/struct.Struct_Builder.html    |   6 +-
 arrow_ipc/gen/Schema/struct.Time.html              |   6 +-
 arrow_ipc/gen/Schema/struct.TimeArgs.html          |   6 +-
 arrow_ipc/gen/Schema/struct.TimeBuilder.html       |   6 +-
 arrow_ipc/gen/Schema/struct.TimeUnit.html          |   6 +-
 arrow_ipc/gen/Schema/struct.Timestamp.html         |   6 +-
 arrow_ipc/gen/Schema/struct.TimestampArgs.html     |   6 +-
 arrow_ipc/gen/Schema/struct.TimestampBuilder.html  |   6 +-
 arrow_ipc/gen/Schema/struct.Type.html              |   6 +-
 .../gen/Schema/struct.TypeUnionTableOffset.html    |   6 +-
 arrow_ipc/gen/Schema/struct.Union.html             |   6 +-
 arrow_ipc/gen/Schema/struct.UnionArgs.html         |   6 +-
 arrow_ipc/gen/Schema/struct.UnionBuilder.html      |   6 +-
 arrow_ipc/gen/Schema/struct.UnionMode.html         |   6 +-
 arrow_ipc/gen/Schema/struct.Utf8.html              |   6 +-
 arrow_ipc/gen/Schema/struct.Utf8Args.html          |   6 +-
 arrow_ipc/gen/Schema/struct.Utf8Builder.html       |   6 +-
 ...ant.ENUM_MAX_SPARSE_MATRIX_COMPRESSED_AXIS.html |   2 +-
 .../constant.ENUM_MAX_SPARSE_TENSOR_INDEX.html     |   2 +-
 ...ant.ENUM_MIN_SPARSE_MATRIX_COMPRESSED_AXIS.html |   2 +-
 .../constant.ENUM_MIN_SPARSE_TENSOR_INDEX.html     |   2 +-
 ....ENUM_VALUES_SPARSE_MATRIX_COMPRESSED_AXIS.html |   2 +-
 .../constant.ENUM_VALUES_SPARSE_TENSOR_INDEX.html  |   2 +-
 .../enum.SparseMatrixIndexCSXOffset.html           |   6 +-
 .../enum.SparseTensorIndexCOOOffset.html           |   6 +-
 .../enum.SparseTensorIndexCSFOffset.html           |   6 +-
 .../gen/SparseTensor/enum.SparseTensorOffset.html  |   6 +-
 ....finish_size_prefixed_sparse_tensor_buffer.html |   2 +-
 .../fn.finish_sparse_tensor_buffer.html            |   2 +-
 .../gen/SparseTensor/fn.root_as_sparse_tensor.html |   2 +-
 .../fn.root_as_sparse_tensor_unchecked.html        |   2 +-
 .../fn.root_as_sparse_tensor_with_opts.html        |   2 +-
 .../fn.size_prefixed_root_as_sparse_tensor.html    |   2 +-
 ...e_prefixed_root_as_sparse_tensor_unchecked.html |   2 +-
 ...e_prefixed_root_as_sparse_tensor_with_opts.html |   2 +-
 arrow_ipc/gen/SparseTensor/index.html              |   2 +-
 .../struct.SparseMatrixCompressedAxis.html         |   6 +-
 .../SparseTensor/struct.SparseMatrixIndexCSX.html  |   6 +-
 .../struct.SparseMatrixIndexCSXArgs.html           |   6 +-
 .../struct.SparseMatrixIndexCSXBuilder.html        |   6 +-
 .../gen/SparseTensor/struct.SparseTensor.html      |   6 +-
 .../gen/SparseTensor/struct.SparseTensorArgs.html  |   6 +-
 .../SparseTensor/struct.SparseTensorBuilder.html   |   6 +-
 .../gen/SparseTensor/struct.SparseTensorIndex.html |   6 +-
 .../SparseTensor/struct.SparseTensorIndexCOO.html  |   6 +-
 .../struct.SparseTensorIndexCOOArgs.html           |   6 +-
 .../struct.SparseTensorIndexCOOBuilder.html        |   6 +-
 .../SparseTensor/struct.SparseTensorIndexCSF.html  |   6 +-
 .../struct.SparseTensorIndexCSFArgs.html           |   6 +-
 .../struct.SparseTensorIndexCSFBuilder.html        |   6 +-
 .../struct.SparseTensorIndexUnionTableOffset.html  |   6 +-
 arrow_ipc/gen/Tensor/enum.TensorDimOffset.html     |   6 +-
 arrow_ipc/gen/Tensor/enum.TensorOffset.html        |   6 +-
 .../fn.finish_size_prefixed_tensor_buffer.html     |   2 +-
 arrow_ipc/gen/Tensor/fn.finish_tensor_buffer.html  |   2 +-
 arrow_ipc/gen/Tensor/fn.root_as_tensor.html        |   2 +-
 .../gen/Tensor/fn.root_as_tensor_unchecked.html    |   2 +-
 .../gen/Tensor/fn.root_as_tensor_with_opts.html    |   2 +-
 .../Tensor/fn.size_prefixed_root_as_tensor.html    |   2 +-
 .../fn.size_prefixed_root_as_tensor_unchecked.html |   2 +-
 .../fn.size_prefixed_root_as_tensor_with_opts.html |   2 +-
 arrow_ipc/gen/Tensor/index.html                    |   2 +-
 arrow_ipc/gen/Tensor/struct.Tensor.html            |   6 +-
 arrow_ipc/gen/Tensor/struct.TensorArgs.html        |   6 +-
 arrow_ipc/gen/Tensor/struct.TensorBuilder.html     |   6 +-
 arrow_ipc/gen/Tensor/struct.TensorDim.html         |   6 +-
 arrow_ipc/gen/Tensor/struct.TensorDimArgs.html     |   6 +-
 arrow_ipc/gen/Tensor/struct.TensorDimBuilder.html  |   6 +-
 arrow_ipc/gen/index.html                           |   2 +-
 arrow_ipc/index.html                               |   2 +-
 arrow_ipc/reader/fn.create_array.html              |   6 +-
 arrow_ipc/reader/fn.create_dictionary_array.html   |  10 +-
 arrow_ipc/reader/fn.create_list_array.html         |  10 +-
 arrow_ipc/reader/fn.create_primitive_array.html    |   8 +-
 arrow_ipc/reader/fn.parse_message.html             |   4 +-
 arrow_ipc/reader/fn.read_block.html                |   4 +-
 arrow_ipc/reader/fn.read_buffer.html               |   6 +-
 arrow_ipc/reader/fn.read_dictionary.html           |  10 +-
 arrow_ipc/reader/fn.read_footer_length.html        |   4 +-
 arrow_ipc/reader/fn.read_record_batch.html         |  10 +-
 arrow_ipc/reader/index.html                        |   4 +-
 arrow_ipc/reader/struct.ArrayReader.html           |  18 +-
 arrow_ipc/reader/struct.FileDecoder.html           |  22 +-
 arrow_ipc/reader/struct.FileReader.html            |  18 +-
 arrow_ipc/reader/struct.FileReaderBuilder.html     |   8 +-
 arrow_ipc/reader/struct.StreamReader.html          |  30 +-
 arrow_ipc/writer/fn.buffer_need_truncate.html      |   6 +-
 arrow_ipc/writer/fn.get_buffer_element_width.html  |   4 +-
 arrow_ipc/writer/fn.get_byte_array_buffers.html    |   8 +-
 arrow_ipc/writer/fn.get_list_array_buffers.html    |   8 +-
 arrow_ipc/writer/fn.has_validity_bitmap.html       |   4 +-
 .../writer/fn.into_zero_offset_run_array.html      |   8 +-
 arrow_ipc/writer/fn.pad_to_8.html                  |   2 +-
 arrow_ipc/writer/fn.reencode_offsets.html          |  10 +-
 arrow_ipc/writer/fn.unslice_run_array.html         |   4 +-
 arrow_ipc/writer/fn.write_array_data.html          |   6 +-
 arrow_ipc/writer/fn.write_body_buffers.html        |   4 +-
 arrow_ipc/writer/fn.write_buffer.html              |   4 +-
 arrow_ipc/writer/fn.write_continuation.html        |   4 +-
 arrow_ipc/writer/fn.write_message.html             |   4 +-
 arrow_ipc/writer/index.html                        |   6 +-
 arrow_ipc/writer/struct.DictionaryTracker.html     |  14 +-
 arrow_ipc/writer/struct.EncodedData.html           |   6 +-
 arrow_ipc/writer/struct.FileWriter.html            |  26 +-
 arrow_ipc/writer/struct.IpcDataGenerator.html      |  32 +-
 arrow_ipc/writer/struct.IpcWriteOptions.html       |  10 +-
 arrow_ipc/writer/struct.StreamWriter.html          |  18 +-
 arrow_json/all.html                                |   2 +-
 arrow_json/index.html                              |   2 +-
 arrow_json/macro.json_serializable.html            |   2 +-
 arrow_json/reader/boolean_array/index.html         |   2 +-
 .../boolean_array/struct.BooleanArrayDecoder.html  |   6 +-
 arrow_json/reader/decimal_array/index.html         |   2 +-
 .../decimal_array/struct.DecimalArrayDecoder.html  |   6 +-
 arrow_json/reader/fn.infer_json_schema.html        |   2 +-
 .../reader/fn.infer_json_schema_from_iterator.html |   2 +-
 .../reader/fn.infer_json_schema_from_seekable.html |   2 +-
 arrow_json/reader/fn.make_decoder.html             |   2 +-
 arrow_json/reader/index.html                       |   2 +-
 arrow_json/reader/list_array/index.html            |   2 +-
 .../reader/list_array/struct.ListArrayDecoder.html |   6 +-
 arrow_json/reader/macro.primitive_decoder.html     |   2 +-
 arrow_json/reader/map_array/index.html             |   2 +-
 .../reader/map_array/struct.MapArrayDecoder.html   |   6 +-
 arrow_json/reader/null_array/index.html            |   2 +-
 .../reader/null_array/struct.NullArrayDecoder.html |   6 +-
 arrow_json/reader/primitive_array/index.html       |   2 +-
 .../primitive_array/macro.primitive_parse.html     |   2 +-
 .../struct.PrimitiveArrayDecoder.html              |   6 +-
 .../primitive_array/trait.ParseJsonNumber.html     |   2 +-
 arrow_json/reader/schema/enum.InferredType.html    |   6 +-
 arrow_json/reader/schema/fn.coerce_data_type.html  |   2 +-
 .../schema/fn.collect_field_types_from_object.html |   2 +-
 arrow_json/reader/schema/fn.generate_datatype.html |   2 +-
 arrow_json/reader/schema/fn.generate_fields.html   |   2 +-
 arrow_json/reader/schema/fn.generate_schema.html   |   2 +-
 .../reader/schema/fn.infer_array_element_type.html |   2 +-
 arrow_json/reader/schema/fn.infer_json_schema.html |   2 +-
 .../schema/fn.infer_json_schema_from_iterator.html |   2 +-
 .../schema/fn.infer_json_schema_from_seekable.html |   2 +-
 .../reader/schema/fn.infer_nested_array_type.html  |   2 +-
 .../reader/schema/fn.infer_scalar_array_type.html  |   2 +-
 .../reader/schema/fn.infer_struct_array_type.html  |   2 +-
 arrow_json/reader/schema/fn.list_type_of.html      |   2 +-
 .../schema/fn.set_object_scalar_field_type.html    |   2 +-
 arrow_json/reader/schema/index.html                |   2 +-
 arrow_json/reader/schema/struct.ValueIter.html     |   6 +-
 arrow_json/reader/serializer/index.html            |   2 +-
 .../reader/serializer/struct.ListSerializer.html   |  12 +-
 .../reader/serializer/struct.ObjectSerializer.html |   6 +-
 .../reader/serializer/struct.SerializerError.html  |   8 +-
 .../reader/serializer/struct.TapeSerializer.html   |   6 +-
 arrow_json/reader/string_array/constant.FALSE.html |   2 +-
 arrow_json/reader/string_array/constant.TRUE.html  |   2 +-
 arrow_json/reader/string_array/index.html          |   2 +-
 .../string_array/struct.StringArrayDecoder.html    |   6 +-
 arrow_json/reader/struct.Decoder.html              |   6 +-
 arrow_json/reader/struct.Reader.html               |   6 +-
 arrow_json/reader/struct.ReaderBuilder.html        |   6 +-
 arrow_json/reader/struct.ValueIter.html            |   6 +-
 .../reader/struct_array/fn.struct_fields.html      |   2 +-
 arrow_json/reader/struct_array/index.html          |   2 +-
 .../struct_array/struct.StructArrayDecoder.html    |   6 +-
 arrow_json/reader/tape/enum.DecoderState.html      |   6 +-
 arrow_json/reader/tape/enum.Literal.html           |   6 +-
 arrow_json/reader/tape/enum.TapeElement.html       |   6 +-
 .../reader/tape/fn.char_from_surrogate_pair.html   |   2 +-
 arrow_json/reader/tape/fn.err.html                 |   2 +-
 arrow_json/reader/tape/fn.json_whitespace.html     |   2 +-
 arrow_json/reader/tape/fn.parse_hex.html           |   2 +-
 arrow_json/reader/tape/fn.write_char.html          |   2 +-
 arrow_json/reader/tape/index.html                  |   2 +-
 arrow_json/reader/tape/macro.next.html             |   2 +-
 arrow_json/reader/tape/struct.BufIter.html         |   6 +-
 arrow_json/reader/tape/struct.Tape.html            |   6 +-
 arrow_json/reader/tape/struct.TapeDecoder.html     |   6 +-
 arrow_json/reader/timestamp_array/index.html       |   2 +-
 .../struct.TimestampArrayDecoder.html              |   6 +-
 arrow_json/reader/trait.ArrayDecoder.html          |   2 +-
 arrow_json/trait.JsonSerializable.html             |   2 +-
 arrow_json/writer/encoder/fn.encode_string.html    |   2 +-
 arrow_json/writer/encoder/fn.make_encoder.html     |   2 +-
 .../writer/encoder/fn.make_encoder_impl.html       |   2 +-
 arrow_json/writer/encoder/index.html               |   2 +-
 arrow_json/writer/encoder/macro.float_encode.html  |   2 +-
 .../writer/encoder/macro.integer_encode.html       |   2 +-
 .../writer/encoder/struct.BooleanEncoder.html      |   6 +-
 .../writer/encoder/struct.DictionaryEncoder.html   |   6 +-
 .../writer/encoder/struct.EncoderOptions.html      |   6 +-
 arrow_json/writer/encoder/struct.FieldEncoder.html |   6 +-
 arrow_json/writer/encoder/struct.ListEncoder.html  |   6 +-
 arrow_json/writer/encoder/struct.MapEncoder.html   |   6 +-
 arrow_json/writer/encoder/struct.NullEncoder.html  |   6 +-
 .../writer/encoder/struct.PrimitiveEncoder.html    |   6 +-
 .../writer/encoder/struct.StringEncoder.html       |   6 +-
 .../writer/encoder/struct.StructArrayEncoder.html  |   6 +-
 arrow_json/writer/encoder/trait.Encoder.html       |   2 +-
 .../writer/encoder/trait.PrimitiveEncode.html      |   2 +-
 arrow_json/writer/fn.array_to_json_array.html      |   2 +-
 .../writer/fn.array_to_json_array_internal.html    |   2 +-
 arrow_json/writer/fn.primitive_array_to_json.html  |   2 +-
 .../writer/fn.record_batches_to_json_rows.html     |   2 +-
 .../fn.record_batches_to_json_rows_internal.html   |   2 +-
 .../writer/fn.set_column_by_primitive_type.html    |   2 +-
 arrow_json/writer/fn.set_column_for_json_rows.html |   2 +-
 .../writer/fn.struct_array_to_jsonmap_array.html   |   2 +-
 arrow_json/writer/index.html                       |   2 +-
 .../writer/macro.set_column_by_array_type.html     |   2 +-
 arrow_json/writer/struct.JsonArray.html            |   6 +-
 arrow_json/writer/struct.LineDelimited.html        |   6 +-
 arrow_json/writer/struct.Writer.html               |   6 +-
 arrow_json/writer/struct.WriterBuilder.html        |   6 +-
 arrow_json/writer/trait.JsonFormat.html            |   2 +-
 arrow_json/writer/type.ArrayWriter.html            |   2 +-
 arrow_json/writer/type.LineDelimitedWriter.html    |   2 +-
 arrow_json_integration_test/all.html               |   2 +-
 arrow_json_integration_test/enum.Mode.html         |   8 +-
 arrow_json_integration_test/fn.arrow_to_json.html  |   4 +-
 arrow_json_integration_test/fn.json_to_arrow.html  |   4 +-
 arrow_json_integration_test/fn.main.html           |   4 +-
 arrow_json_integration_test/fn.validate.html       |   4 +-
 arrow_json_integration_test/index.html             |   2 +-
 arrow_json_integration_test/struct.Args.html       |   8 +-
 arrow_ord/all.html                                 |   2 +-
 arrow_ord/cmp/enum.Op.html                         |   6 +-
 arrow_ord/cmp/fn.apply.html                        |   2 +-
 arrow_ord/cmp/fn.apply_op.html                     |   2 +-
 arrow_ord/cmp/fn.apply_op_vectored.html            |   2 +-
 arrow_ord/cmp/fn.collect_bool.html                 |   2 +-
 arrow_ord/cmp/fn.compare_op.html                   |   2 +-
 arrow_ord/cmp/fn.distinct.html                     |   2 +-
 arrow_ord/cmp/fn.eq.html                           |   2 +-
 arrow_ord/cmp/fn.gt.html                           |   2 +-
 arrow_ord/cmp/fn.gt_eq.html                        |   2 +-
 arrow_ord/cmp/fn.lt.html                           |   2 +-
 arrow_ord/cmp/fn.lt_eq.html                        |   2 +-
 arrow_ord/cmp/fn.neq.html                          |   2 +-
 arrow_ord/cmp/fn.not_distinct.html                 |   2 +-
 arrow_ord/cmp/fn.take_bits.html                    |   2 +-
 arrow_ord/cmp/index.html                           |   2 +-
 arrow_ord/cmp/trait.ArrayOrd.html                  |   2 +-
 arrow_ord/index.html                               |   2 +-
 arrow_ord/ord/fn.build_compare.html                |   2 +-
 arrow_ord/ord/fn.compare_boolean.html              |   2 +-
 arrow_ord/ord/fn.compare_bytes.html                |   2 +-
 arrow_ord/ord/fn.compare_dict.html                 |   2 +-
 arrow_ord/ord/fn.compare_primitive.html            |   2 +-
 arrow_ord/ord/index.html                           |   2 +-
 arrow_ord/ord/type.DynComparator.html              |   4 +-
 arrow_ord/partition/fn.find_boundaries.html        |   2 +-
 .../fn.lexicographical_partition_ranges.html       |   2 +-
 arrow_ord/partition/fn.partition.html              |   2 +-
 arrow_ord/partition/index.html                     |   2 +-
 arrow_ord/partition/struct.Partitions.html         |   6 +-
 arrow_ord/rank/fn.bytes_rank.html                  |   2 +-
 arrow_ord/rank/fn.primitive_rank.html              |   2 +-
 arrow_ord/rank/fn.rank.html                        |   2 +-
 arrow_ord/rank/fn.rank_impl.html                   |   2 +-
 arrow_ord/rank/index.html                          |   2 +-
 arrow_ord/sort/fn.child_rank.html                  |   2 +-
 arrow_ord/sort/fn.lexsort.html                     |   2 +-
 arrow_ord/sort/fn.lexsort_to_indices.html          |   2 +-
 arrow_ord/sort/fn.partial_sort.html                |   2 +-
 arrow_ord/sort/fn.partition_validity.html          |   2 +-
 arrow_ord/sort/fn.sort.html                        |   2 +-
 arrow_ord/sort/fn.sort_boolean.html                |   2 +-
 arrow_ord/sort/fn.sort_bytes.html                  |   2 +-
 arrow_ord/sort/fn.sort_dictionary.html             |   2 +-
 arrow_ord/sort/fn.sort_fixed_size_binary.html      |   2 +-
 arrow_ord/sort/fn.sort_fixed_size_list.html        |   2 +-
 arrow_ord/sort/fn.sort_impl.html                   |   2 +-
 arrow_ord/sort/fn.sort_limit.html                  |   2 +-
 arrow_ord/sort/fn.sort_list.html                   |   2 +-
 arrow_ord/sort/fn.sort_native_type.html            |   2 +-
 arrow_ord/sort/fn.sort_primitive.html              |   2 +-
 arrow_ord/sort/fn.sort_run.html                    |   2 +-
 arrow_ord/sort/fn.sort_run_downcasted.html         |   2 +-
 arrow_ord/sort/fn.sort_run_inner.html              |   2 +-
 arrow_ord/sort/fn.sort_run_to_indices.html         |   2 +-
 arrow_ord/sort/fn.sort_to_indices.html             |   2 +-
 arrow_ord/sort/fn.sort_unstable_by.html            |   2 +-
 arrow_ord/sort/index.html                          |   2 +-
 .../sort/struct.LexicographicalComparator.html     |   6 +-
 arrow_ord/sort/struct.SortColumn.html              |   6 +-
 arrow_ord/sort/struct.SortOptions.html             |   6 +-
 .../sort/type.LexicographicalCompareItem.html      |   2 +-
 arrow_row/all.html                                 |   2 +-
 arrow_row/enum.Codec.html                          |   6 +-
 arrow_row/enum.Encoder.html                        |   6 +-
 arrow_row/fixed/fn.decode_bool.html                |   2 +-
 arrow_row/fixed/fn.decode_fixed.html               |   2 +-
 arrow_row/fixed/fn.decode_fixed_size_binary.html   |   2 +-
 arrow_row/fixed/fn.decode_nulls.html               |   2 +-
 arrow_row/fixed/fn.decode_primitive.html           |   2 +-
 arrow_row/fixed/fn.encode.html                     |   2 +-
 arrow_row/fixed/fn.encode_fixed_size_binary.html   |   2 +-
 arrow_row/fixed/fn.encoded_len.html                |   2 +-
 arrow_row/fixed/fn.split_off.html                  |   2 +-
 arrow_row/fixed/index.html                         |   2 +-
 arrow_row/fixed/macro.encode_signed.html           |   2 +-
 arrow_row/fixed/macro.encode_unsigned.html         |   2 +-
 arrow_row/fixed/trait.FixedLengthEncoding.html     |   4 +-
 arrow_row/fixed/trait.FromSlice.html               |   2 +-
 arrow_row/fn.decode_column.html                    |   2 +-
 arrow_row/fn.encode_column.html                    |   2 +-
 arrow_row/fn.encode_dictionary_values.html         |   2 +-
 arrow_row/fn.null_sentinel.html                    |   2 +-
 arrow_row/fn.row_lengths.html                      |   2 +-
 arrow_row/index.html                               |   2 +-
 arrow_row/list/fn.compute_lengths.html             |   2 +-
 arrow_row/list/fn.decode.html                      |   2 +-
 arrow_row/list/fn.encode.html                      |   2 +-
 arrow_row/list/fn.encode_one.html                  |   2 +-
 arrow_row/list/fn.encoded_len.html                 |   2 +-
 arrow_row/list/index.html                          |   2 +-
 arrow_row/macro.decode_primitive_helper.html       |   2 +-
 arrow_row/struct.OwnedRow.html                     |   6 +-
 arrow_row/struct.Row.html                          |   6 +-
 arrow_row/struct.RowConfig.html                    |   6 +-
 arrow_row/struct.RowConverter.html                 |   6 +-
 arrow_row/struct.RowParser.html                    |   6 +-
 arrow_row/struct.Rows.html                         |   6 +-
 arrow_row/struct.RowsIter.html                     |   6 +-
 arrow_row/struct.SortField.html                    |   6 +-
 .../variable/constant.BLOCK_CONTINUATION.html      |   2 +-
 arrow_row/variable/constant.BLOCK_SIZE.html        |   2 +-
 arrow_row/variable/constant.EMPTY_SENTINEL.html    |   2 +-
 arrow_row/variable/constant.MINI_BLOCK_COUNT.html  |   2 +-
 arrow_row/variable/constant.MINI_BLOCK_SIZE.html   |   2 +-
 .../variable/constant.NON_EMPTY_SENTINEL.html      |   2 +-
 arrow_row/variable/fn.decode_binary.html           |   2 +-
 arrow_row/variable/fn.decode_blocks.html           |   2 +-
 arrow_row/variable/fn.decode_string.html           |   2 +-
 arrow_row/variable/fn.decoded_len.html             |   2 +-
 arrow_row/variable/fn.encode.html                  |   2 +-
 arrow_row/variable/fn.encode_blocks.html           |   2 +-
 arrow_row/variable/fn.encode_one.html              |   2 +-
 arrow_row/variable/fn.encoded_len.html             |   2 +-
 arrow_row/variable/fn.padded_length.html           |   2 +-
 arrow_row/variable/index.html                      |   2 +-
 arrow_schema/all.html                              |   2 +-
 .../constant.DECIMAL128_MAX_PRECISION.html         |   2 +-
 arrow_schema/constant.DECIMAL128_MAX_SCALE.html    |   2 +-
 .../constant.DECIMAL256_MAX_PRECISION.html         |   2 +-
 arrow_schema/constant.DECIMAL256_MAX_SCALE.html    |   2 +-
 arrow_schema/constant.DECIMAL_DEFAULT_SCALE.html   |   2 +-
 .../constant.DECIMAL128_MAX_PRECISION.html         |   2 +-
 .../datatype/constant.DECIMAL128_MAX_SCALE.html    |   2 +-
 .../constant.DECIMAL256_MAX_PRECISION.html         |   2 +-
 .../datatype/constant.DECIMAL256_MAX_SCALE.html    |   2 +-
 .../datatype/constant.DECIMAL_DEFAULT_SCALE.html   |   2 +-
 arrow_schema/datatype/enum.DataType.html           |  16 +-
 arrow_schema/datatype/enum.IntervalUnit.html       |   6 +-
 arrow_schema/datatype/enum.TimeUnit.html           |   6 +-
 arrow_schema/datatype/enum.UnionMode.html          |   6 +-
 arrow_schema/datatype/index.html                   |   2 +-
 arrow_schema/enum.ArrowError.html                  |   8 +-
 arrow_schema/enum.DataType.html                    |  16 +-
 arrow_schema/enum.IntervalUnit.html                |   6 +-
 arrow_schema/enum.TimeUnit.html                    |   6 +-
 arrow_schema/enum.UnionMode.html                   |   6 +-
 arrow_schema/error/enum.ArrowError.html            |   8 +-
 arrow_schema/error/index.html                      |   2 +-
 arrow_schema/ffi/flags/index.html                  |   2 +-
 arrow_schema/ffi/flags/struct.Flags.html           |  20 +-
 arrow_schema/ffi/fn.get_format_string.html         |   2 +-
 arrow_schema/ffi/fn.release_schema.html            |   2 +-
 arrow_schema/ffi/index.html                        |   2 +-
 arrow_schema/ffi/struct.FFI_ArrowSchema.html       |  12 +-
 arrow_schema/ffi/struct.Flags.html                 |  20 +-
 arrow_schema/ffi/struct.SchemaPrivateData.html     |   6 +-
 arrow_schema/field/index.html                      |   2 +-
 arrow_schema/field/struct.Field.html               |   8 +-
 arrow_schema/field/type.FieldRef.html              |   2 +-
 arrow_schema/fields/index.html                     |   2 +-
 arrow_schema/fields/struct.Fields.html             | 174 ++++----
 arrow_schema/fields/struct.UnionFields.html        |   6 +-
 arrow_schema/index.html                            |   2 +-
 arrow_schema/schema/index.html                     |   2 +-
 arrow_schema/schema/struct.Schema.html             |   8 +-
 arrow_schema/schema/struct.SchemaBuilder.html      |   8 +-
 arrow_schema/schema/type.SchemaRef.html            |   2 +-
 arrow_schema/struct.Field.html                     |   8 +-
 arrow_schema/struct.Fields.html                    | 174 ++++----
 arrow_schema/struct.Schema.html                    |   8 +-
 arrow_schema/struct.SchemaBuilder.html             |   8 +-
 arrow_schema/struct.SortOptions.html               |   6 +-
 arrow_schema/struct.UnionFields.html               |   6 +-
 arrow_schema/type.FieldRef.html                    |   2 +-
 arrow_schema/type.SchemaRef.html                   |   2 +-
 arrow_select/all.html                              |   2 +-
 arrow_select/concat/fn.binary_capacity.html        |   2 +-
 arrow_select/concat/fn.concat.html                 |   2 +-
 arrow_select/concat/fn.concat_batches.html         |   2 +-
 arrow_select/concat/fn.concat_dictionaries.html    |   2 +-
 arrow_select/concat/fn.concat_fallback.html        |   2 +-
 arrow_select/concat/index.html                     |   2 +-
 arrow_select/concat/macro.dict_helper.html         |   2 +-
 arrow_select/dictionary/fn.bytes_ptr_eq.html       |   2 +-
 .../dictionary/fn.compute_values_mask.html         |   2 +-
 arrow_select/dictionary/fn.get_masked_values.html  |   2 +-
 arrow_select/dictionary/fn.masked_bytes.html       |   2 +-
 .../dictionary/fn.merge_dictionary_values.html     |   2 +-
 .../fn.should_merge_dictionary_values.html         |   2 +-
 arrow_select/dictionary/index.html                 |   2 +-
 arrow_select/dictionary/struct.Interner.html       |   6 +-
 .../dictionary/struct.MergedDictionaries.html      |   6 +-
 arrow_select/dictionary/type.PtrEq.html            |   2 +-
 ...nstant.FILTER_SLICES_SELECTIVITY_THRESHOLD.html |   2 +-
 arrow_select/filter/enum.IterationStrategy.html    |   6 +-
 arrow_select/filter/fn.build_filter.html           |   2 +-
 arrow_select/filter/fn.filter.html                 |   2 +-
 arrow_select/filter/fn.filter_array.html           |   2 +-
 arrow_select/filter/fn.filter_bits.html            |   2 +-
 arrow_select/filter/fn.filter_boolean.html         |   2 +-
 arrow_select/filter/fn.filter_bytes.html           |   2 +-
 arrow_select/filter/fn.filter_count.html           |   2 +-
 arrow_select/filter/fn.filter_dict.html            |   2 +-
 arrow_select/filter/fn.filter_null_mask.html       |   2 +-
 arrow_select/filter/fn.filter_primitive.html       |   2 +-
 arrow_select/filter/fn.filter_record_batch.html    |   2 +-
 arrow_select/filter/fn.prep_null_mask_filter.html  |   2 +-
 arrow_select/filter/index.html                     |   2 +-
 arrow_select/filter/struct.FilterBuilder.html      |   6 +-
 arrow_select/filter/struct.FilterBytes.html        |   6 +-
 arrow_select/filter/struct.FilterPredicate.html    |   6 +-
 arrow_select/filter/struct.IndexIterator.html      |   6 +-
 arrow_select/filter/struct.SlicesIterator.html     |   6 +-
 arrow_select/filter/type.Filter.html               |   2 +-
 arrow_select/index.html                            |   2 +-
 arrow_select/interleave/fn.interleave.html         |   2 +-
 arrow_select/interleave/fn.interleave_bytes.html   |   2 +-
 .../interleave/fn.interleave_dictionaries.html     |   2 +-
 .../interleave/fn.interleave_fallback.html         |   2 +-
 .../interleave/fn.interleave_primitive.html        |   2 +-
 arrow_select/interleave/index.html                 |   2 +-
 arrow_select/interleave/macro.dict_helper.html     |   2 +-
 .../interleave/macro.primitive_helper.html         |   2 +-
 arrow_select/interleave/struct.Interleave.html     |   6 +-
 arrow_select/nullif/fn.nullif.html                 |   2 +-
 arrow_select/nullif/index.html                     |   2 +-
 arrow_select/take/fn.check_bounds.html             |   2 +-
 arrow_select/take/fn.maybe_usize.html              |   2 +-
 arrow_select/take/fn.take.html                     |   2 +-
 arrow_select/take/fn.take_bits.html                |   2 +-
 arrow_select/take/fn.take_boolean.html             |   2 +-
 arrow_select/take/fn.take_bytes.html               |   2 +-
 arrow_select/take/fn.take_dict.html                |   2 +-
 arrow_select/take/fn.take_fixed_size_binary.html   |   2 +-
 arrow_select/take/fn.take_fixed_size_list.html     |   2 +-
 arrow_select/take/fn.take_impl.html                |   2 +-
 arrow_select/take/fn.take_list.html                |   2 +-
 arrow_select/take/fn.take_native.html              |   2 +-
 arrow_select/take/fn.take_nulls.html               |   2 +-
 arrow_select/take/fn.take_primitive.html           |   2 +-
 arrow_select/take/fn.take_record_batch.html        |   2 +-
 arrow_select/take/fn.take_run.html                 |   2 +-
 ...fn.take_value_indices_from_fixed_size_list.html |   2 +-
 .../take/fn.take_value_indices_from_list.html      |   2 +-
 arrow_select/take/index.html                       |   2 +-
 arrow_select/take/macro.to_indices_identity.html   |   2 +-
 .../take/macro.to_indices_reinterpret.html         |   2 +-
 arrow_select/take/macro.to_indices_widening.html   |   2 +-
 arrow_select/take/struct.TakeOptions.html          |   6 +-
 arrow_select/take/trait.ToIndices.html             |   2 +-
 arrow_select/window/fn.shift.html                  |   2 +-
 arrow_select/window/index.html                     |   2 +-
 arrow_select/zip/fn.zip.html                       |   2 +-
 arrow_select/zip/index.html                        |   2 +-
 arrow_stream_to_file/all.html                      |   2 +-
 arrow_stream_to_file/fn.main.html                  |   4 +-
 arrow_stream_to_file/index.html                    |   2 +-
 arrow_string/all.html                              |   2 +-
 .../concat_elements/fn.concat_element_binary.html  |   2 +-
 .../concat_elements/fn.concat_elements_bytes.html  |   2 +-
 .../concat_elements/fn.concat_elements_dyn.html    |   2 +-
 .../concat_elements/fn.concat_elements_utf8.html   |   2 +-
 .../fn.concat_elements_utf8_many.html              |   2 +-
 arrow_string/concat_elements/index.html            |   2 +-
 arrow_string/index.html                            |   2 +-
 arrow_string/length/fn.bit_length.html             |   2 +-
 arrow_string/length/fn.bit_length_impl.html        |   2 +-
 arrow_string/length/fn.length.html                 |   2 +-
 arrow_string/length/fn.length_impl.html            |   2 +-
 arrow_string/length/index.html                     |   2 +-
 arrow_string/like/enum.Op.html                     |   6 +-
 arrow_string/like/fn.apply.html                    |   2 +-
 arrow_string/like/fn.binary_predicate.html         |   2 +-
 arrow_string/like/fn.contains.html                 |   2 +-
 arrow_string/like/fn.ends_with.html                |   2 +-
 arrow_string/like/fn.ilike.html                    |   2 +-
 arrow_string/like/fn.like.html                     |   2 +-
 arrow_string/like/fn.like_op.html                  |   2 +-
 arrow_string/like/fn.make_scalar.html              |   2 +-
 arrow_string/like/fn.nilike.html                   |   2 +-
 arrow_string/like/fn.nlike.html                    |   2 +-
 arrow_string/like/fn.op_binary.html                |   2 +-
 arrow_string/like/fn.op_scalar.html                |   2 +-
 arrow_string/like/fn.starts_with.html              |   2 +-
 arrow_string/like/fn.vectored_iter.html            |   2 +-
 arrow_string/like/index.html                       |   2 +-
 arrow_string/like/macro.legacy_kernels.html        |   2 +-
 arrow_string/predicate/enum.Predicate.html         |   6 +-
 .../predicate/fn.contains_like_pattern.html        |   2 +-
 .../predicate/fn.ends_with_ignore_ascii_case.html  |   2 +-
 arrow_string/predicate/fn.is_like_pattern.html     |   2 +-
 arrow_string/predicate/fn.regex_like.html          |   2 +-
 .../fn.starts_with_ignore_ascii_case.html          |   2 +-
 arrow_string/predicate/index.html                  |   2 +-
 .../regexp/fn.get_scalar_pattern_flag.html         |   2 +-
 arrow_string/regexp/fn.regexp_array_match.html     |   2 +-
 arrow_string/regexp/fn.regexp_is_match_utf8.html   |   2 +-
 .../regexp/fn.regexp_is_match_utf8_scalar.html     |   2 +-
 arrow_string/regexp/fn.regexp_match.html           |   2 +-
 arrow_string/regexp/fn.regexp_scalar_match.html    |   2 +-
 arrow_string/regexp/index.html                     |   2 +-
 arrow_string/substring/fn.byte_substring.html      |   2 +-
 .../substring/fn.fixed_size_binary_substring.html  |   2 +-
 .../substring/fn.get_start_end_offset.html         |   2 +-
 arrow_string/substring/fn.substring.html           |   2 +-
 arrow_string/substring/fn.substring_by_char.html   |   2 +-
 arrow_string/substring/index.html                  |   2 +-
 flight_sql_client/all.html                         |   2 +-
 flight_sql_client/enum.Command.html                |   8 +-
 .../fn.construct_record_batch_from_params.html     |   6 +-
 flight_sql_client/fn.execute_flight.html           |   4 +-
 flight_sql_client/fn.log_metadata.html             |   2 +-
 flight_sql_client/fn.main.html                     |   2 +-
 flight_sql_client/fn.parse_key_val.html            |   2 +-
 flight_sql_client/fn.setup_client.html             |   2 +-
 flight_sql_client/fn.setup_logging.html            |   2 +-
 flight_sql_client/index.html                       |   2 +-
 flight_sql_client/struct.Args.html                 |   8 +-
 flight_sql_client/struct.ClientArgs.html           |   8 +-
 flight_sql_client/struct.LoggingArgs.html          |   8 +-
 flight_test_integration_client/all.html            |   2 +-
 flight_test_integration_client/enum.Scenario.html  |   8 +-
 flight_test_integration_client/fn.main.html        |   2 +-
 flight_test_integration_client/index.html          |   2 +-
 flight_test_integration_client/struct.Args.html    |   8 +-
 flight_test_integration_client/type.Error.html     |   4 +-
 flight_test_integration_client/type.Result.html    |   2 +-
 flight_test_integration_server/all.html            |   2 +-
 flight_test_integration_server/enum.Scenario.html  |   8 +-
 flight_test_integration_server/fn.main.html        |   2 +-
 flight_test_integration_server/index.html          |   2 +-
 flight_test_integration_server/struct.Args.html    |   8 +-
 flight_test_integration_server/type.Error.html     |   4 +-
 flight_test_integration_server/type.Result.html    |   2 +-
 gen/all.html                                       |   2 +-
 gen/fn.main.html                                   |   2 +-
 gen/fn.prost_config.html                           |   2 +-
 gen/index.html                                     |   2 +-
 help.html                                          |   4 +-
 index.html                                         |   4 +-
 parquet/all.html                                   |   2 +-
 parquet/arrow/arrow_reader/filter/index.html       |   4 +-
 .../filter/struct.ArrowPredicateFn.html            |  14 +-
 .../arrow_reader/filter/struct.RowFilter.html      |   8 +-
 .../arrow_reader/filter/trait.ArrowPredicate.html  |  14 +-
 parquet/arrow/arrow_reader/fn.apply_range.html     |   2 +-
 .../arrow/arrow_reader/fn.evaluate_predicate.html  |   2 +-
 parquet/arrow/arrow_reader/fn.selects_any.html     |   2 +-
 parquet/arrow/arrow_reader/index.html              |   8 +-
 .../selection/fn.intersect_row_selections.html     |   2 +-
 parquet/arrow/arrow_reader/selection/index.html    |   2 +-
 .../selection/struct.RowSelection.html             |  12 +-
 .../arrow_reader/selection/struct.RowSelector.html |   6 +-
 .../arrow_reader/struct.ArrowPredicateFn.html      |  14 +-
 .../arrow_reader/struct.ArrowReaderBuilder.html    |  14 +-
 .../arrow_reader/struct.ArrowReaderMetadata.html   |  12 +-
 .../arrow_reader/struct.ArrowReaderOptions.html    |   6 +-
 .../struct.ParquetRecordBatchReader.html           |  18 +-
 .../arrow_reader/struct.ReaderPageIterator.html    |   6 +-
 .../arrow/arrow_reader/struct.ReaderRowGroups.html |   6 +-
 parquet/arrow/arrow_reader/struct.RowFilter.html   |   8 +-
 .../arrow/arrow_reader/struct.RowSelection.html    |  12 +-
 parquet/arrow/arrow_reader/struct.RowSelector.html |   6 +-
 .../arrow/arrow_reader/trait.ArrowPredicate.html   |  14 +-
 parquet/arrow/arrow_reader/trait.RowGroups.html    |   2 +-
 .../type.ParquetRecordBatchReaderBuilder.html      |   6 +-
 .../byte_array/enum.FallbackEncoderImpl.html       |   6 +-
 .../byte_array/fn.compute_min_max.html             |   6 +-
 .../arrow/arrow_writer/byte_array/fn.encode.html   |   6 +-
 parquet/arrow/arrow_writer/byte_array/index.html   |   2 +-
 .../byte_array/macro.downcast_dict_impl.html       |   2 +-
 .../byte_array/macro.downcast_dict_op.html         |   2 +-
 .../arrow_writer/byte_array/macro.downcast_op.html |   2 +-
 .../byte_array/struct.ByteArrayEncoder.html        |   8 +-
 .../byte_array/struct.ByteArrayStorage.html        |   6 +-
 .../byte_array/struct.DictEncoder.html             |  10 +-
 .../byte_array/struct.FallbackEncoder.html         |  10 +-
 .../arrow_writer/enum.ArrowColumnWriterImpl.html   |   6 +-
 parquet/arrow/arrow_writer/fn.compute_leaves.html  |   8 +-
 .../arrow_writer/fn.get_arrow_column_writer.html   |   4 +-
 .../arrow_writer/fn.get_bool_array_slice.html      |   4 +-
 .../arrow/arrow_writer/fn.get_column_writers.html  |   4 +-
 .../fn.get_decimal_128_array_slice.html            |   4 +-
 .../fn.get_decimal_256_array_slice.html            |   4 +-
 .../arrow_writer/fn.get_float_16_array_slice.html  |   4 +-
 .../arrow/arrow_writer/fn.get_fsb_array_slice.html |   4 +-
 .../fn.get_interval_dt_array_slice.html            |   4 +-
 .../fn.get_interval_ym_array_slice.html            |   4 +-
 parquet/arrow/arrow_writer/fn.write_leaf.html      |   2 +-
 parquet/arrow/arrow_writer/fn.write_primitive.html |   2 +-
 parquet/arrow/arrow_writer/index.html              |   4 +-
 .../arrow_writer/levels/enum.LevelInfoBuilder.html |  38 +-
 .../levels/fn.calculate_array_levels.html          |   6 +-
 parquet/arrow/arrow_writer/levels/fn.is_leaf.html  |   4 +-
 parquet/arrow/arrow_writer/levels/index.html       |   4 +-
 .../arrow_writer/levels/struct.ArrayLevels.html    |  12 +-
 .../arrow_writer/levels/struct.LevelContext.html   |   6 +-
 .../arrow_writer/struct.ArrowColumnChunk.html      |   6 +-
 .../arrow_writer/struct.ArrowColumnChunkData.html  |   6 +-
 .../struct.ArrowColumnChunkReader.html             |   8 +-
 .../arrow_writer/struct.ArrowColumnWriter.html     |   6 +-
 .../arrow/arrow_writer/struct.ArrowLeafColumn.html |   6 +-
 .../arrow/arrow_writer/struct.ArrowPageWriter.html |   6 +-
 .../arrow_writer/struct.ArrowRowGroupWriter.html   |  16 +-
 parquet/arrow/arrow_writer/struct.ArrowWriter.html |  22 +-
 .../arrow_writer/struct.ArrowWriterOptions.html    |   6 +-
 .../arrow/arrow_writer/type.SharedColumnChunk.html |   2 +-
 .../arrow/async_reader/enum.ColumnChunkData.html   |   6 +-
 parquet/arrow/async_reader/enum.StreamState.html   |   6 +-
 .../async_reader/fn.fetch_parquet_metadata.html    |   2 +-
 parquet/arrow/async_reader/index.html              |   6 +-
 .../metadata/fn.fetch_parquet_metadata.html        |   2 +-
 parquet/arrow/async_reader/metadata/index.html     |   2 +-
 .../metadata/struct.MetadataFetchFn.html           |   6 +-
 .../metadata/struct.MetadataLoader.html            |   6 +-
 .../async_reader/metadata/trait.MetadataFetch.html |   2 +-
 parquet/arrow/async_reader/store/index.html        |   2 +-
 .../store/struct.ParquetObjectReader.html          |   6 +-
 .../async_reader/struct.ColumnChunkIterator.html   |   6 +-
 .../async_reader/struct.InMemoryRowGroup.html      |   6 +-
 .../arrow/async_reader/struct.MetadataLoader.html  |   6 +-
 .../async_reader/struct.ParquetObjectReader.html   |   6 +-
 .../struct.ParquetRecordBatchStream.html           |  16 +-
 .../arrow/async_reader/struct.ReaderFactory.html   |   6 +-
 .../arrow/async_reader/trait.AsyncFileReader.html  |   2 +-
 .../arrow/async_reader/trait.MetadataFetch.html    |   2 +-
 .../type.ParquetRecordBatchStreamBuilder.html      |   6 +-
 parquet/arrow/async_reader/type.ReadResult.html    |   2 +-
 parquet/arrow/async_writer/index.html              |   4 +-
 .../async_writer/struct.AsyncArrowWriter.html      |  14 +-
 .../arrow/async_writer/struct.SharedBuffer.html    |   6 +-
 .../arrow/buffer/bit_util/fn.count_set_bits.html   |   2 +-
 .../buffer/bit_util/fn.iter_set_bits_rev.html      |   2 +-
 .../arrow/buffer/bit_util/fn.sign_extend_be.html   |   2 +-
 parquet/arrow/buffer/bit_util/index.html           |   2 +-
 .../dictionary_buffer/enum.DictionaryBuffer.html   |  22 +-
 parquet/arrow/buffer/dictionary_buffer/index.html  |   4 +-
 parquet/arrow/buffer/index.html                    |   2 +-
 parquet/arrow/buffer/offset_buffer/index.html      |   4 +-
 .../buffer/offset_buffer/struct.OffsetBuffer.html  |  22 +-
 parquet/arrow/constant.ARROW_SCHEMA_META_KEY.html  |   2 +-
 .../arrow/constant.PARQUET_FIELD_ID_META_KEY.html  |   4 +-
 parquet/arrow/decoder/delta_byte_array/index.html  |   2 +-
 .../struct.DeltaByteArrayDecoder.html              |   6 +-
 parquet/arrow/decoder/dictionary_index/index.html  |   2 +-
 .../dictionary_index/struct.DictIndexDecoder.html  |   6 +-
 parquet/arrow/decoder/index.html                   |   2 +-
 parquet/arrow/fn.arrow_to_parquet_schema.html      |   4 +-
 .../arrow/fn.parquet_to_arrow_field_levels.html    |   4 +-
 parquet/arrow/fn.parquet_to_arrow_schema.html      |   4 +-
 .../fn.parquet_to_arrow_schema_by_columns.html     |   4 +-
 parquet/arrow/index.html                           |  10 +-
 parquet/arrow/record_reader/buffer/index.html      |   2 +-
 .../record_reader/buffer/trait.ValuesBuffer.html   |   4 +-
 .../definition_levels/enum.BufferInner.html        |  14 +-
 .../definition_levels/enum.MaybePacked.html        |   6 +-
 .../record_reader/definition_levels/index.html     |   2 +-
 .../struct.DefinitionLevelBuffer.html              |  10 +-
 .../struct.DefinitionLevelBufferDecoder.html       |   6 +-
 .../definition_levels/struct.PackedDecoder.html    |   8 +-
 .../arrow/record_reader/fn.packed_null_mask.html   |   2 +-
 parquet/arrow/record_reader/index.html             |   2 +-
 .../record_reader/struct.GenericRecordReader.html  |  10 +-
 parquet/arrow/record_reader/type.ColumnReader.html |   2 +-
 parquet/arrow/record_reader/type.RecordReader.html |   2 +-
 parquet/arrow/struct.FieldLevels.html              |  12 +-
 parquet/arrow/struct.ProjectionMask.html           |   6 +-
 parquet/basic/enum.ColumnOrder.html                |   8 +-
 parquet/basic/enum.Compression.html                |   6 +-
 parquet/basic/enum.ConvertedType.html              |   8 +-
 parquet/basic/enum.Encoding.html                   |   6 +-
 parquet/basic/enum.LogicalType.html                |   6 +-
 parquet/basic/enum.PageType.html                   |   8 +-
 parquet/basic/enum.Repetition.html                 |   8 +-
 parquet/basic/enum.SortOrder.html                  |   8 +-
 parquet/basic/enum.Type.html                       |   8 +-
 parquet/basic/fn.check_level_is_none.html          |   2 +-
 parquet/basic/fn.require_level.html                |   2 +-
 parquet/basic/fn.split_compression_string.html     |   2 +-
 parquet/basic/index.html                           |   2 +-
 parquet/basic/struct.BrotliLevel.html              |   6 +-
 parquet/basic/struct.GzipLevel.html                |   6 +-
 parquet/basic/struct.ZstdLevel.html                |   6 +-
 .../bloom_filter/constant.BITSET_MAX_LENGTH.html   |   2 +-
 .../bloom_filter/constant.BITSET_MIN_LENGTH.html   |   2 +-
 parquet/bloom_filter/constant.SALT.html            |   2 +-
 .../constant.SBBF_HEADER_SIZE_ESTIMATE.html        |   2 +-
 parquet/bloom_filter/constant.SEED.html            |   2 +-
 ....chunk_read_bloom_filter_header_and_offset.html |   2 +-
 parquet/bloom_filter/fn.hash_as_bytes.html         |   2 +-
 .../bloom_filter/fn.num_of_bits_from_ndv_fpp.html  |   2 +-
 parquet/bloom_filter/fn.optimal_num_of_bytes.html  |   2 +-
 .../fn.read_bloom_filter_header_and_length.html    |   2 +-
 parquet/bloom_filter/index.html                    |   2 +-
 parquet/bloom_filter/struct.Block.html             |   6 +-
 parquet/bloom_filter/struct.Sbbf.html              |   6 +-
 parquet/column/index.html                          |   2 +-
 parquet/column/page/enum.Page.html                 |   6 +-
 parquet/column/page/index.html                     |   2 +-
 parquet/column/page/struct.CompressedPage.html     |   6 +-
 parquet/column/page/struct.PageMetadata.html       |   6 +-
 parquet/column/page/struct.PageWriteSpec.html      |   6 +-
 parquet/column/page/trait.PageIterator.html        |   2 +-
 parquet/column/page/trait.PageReader.html          |   2 +-
 parquet/column/page/trait.PageWriter.html          |   2 +-
 .../constant.REPETITION_LEVELS_BATCH_SIZE.html     |   2 +-
 .../reader/decoder/constant.SKIP_BUFFER_SIZE.html  |   2 +-
 .../column/reader/decoder/enum.LevelDecoder.html   |   6 +-
 parquet/column/reader/decoder/index.html           |   2 +-
 .../decoder/struct.ColumnValueDecoderImpl.html     |   6 +-
 .../decoder/struct.DefinitionLevelDecoderImpl.html |   6 +-
 .../decoder/struct.RepetitionLevelDecoderImpl.html |   6 +-
 .../reader/decoder/trait.ColumnLevelDecoder.html   |   2 +-
 .../reader/decoder/trait.ColumnValueDecoder.html   |   2 +-
 .../decoder/trait.DefinitionLevelDecoder.html      |   2 +-
 .../decoder/trait.RepetitionLevelDecoder.html      |   2 +-
 parquet/column/reader/enum.ColumnReader.html       |   6 +-
 parquet/column/reader/fn.get_column_reader.html    |   2 +-
 .../column/reader/fn.get_typed_column_reader.html  |   2 +-
 parquet/column/reader/fn.parse_v1_level.html       |   2 +-
 parquet/column/reader/index.html                   |   2 +-
 .../column/reader/struct.GenericColumnReader.html  |   6 +-
 parquet/column/reader/type.ColumnReaderImpl.html   |   2 +-
 parquet/column/writer/encoder/fn.get_min_max.html  |   2 +-
 parquet/column/writer/encoder/fn.replace_zero.html |   2 +-
 parquet/column/writer/encoder/index.html           |   2 +-
 .../encoder/struct.ColumnValueEncoderImpl.html     |   6 +-
 .../writer/encoder/struct.DataPageValues.html      |   6 +-
 .../writer/encoder/struct.DictionaryPage.html      |   6 +-
 .../writer/encoder/trait.ColumnValueEncoder.html   |   4 +-
 .../column/writer/encoder/trait.ColumnValues.html  |   4 +-
 parquet/column/writer/enum.ColumnWriter.html       |   6 +-
 parquet/column/writer/enum.Level.html              |   6 +-
 parquet/column/writer/fn.compare_greater.html      |   2 +-
 .../fn.compare_greater_byte_array_decimals.html    |   2 +-
 parquet/column/writer/fn.fallback_encoding.html    |   2 +-
 parquet/column/writer/fn.get_column_writer.html    |   2 +-
 .../column/writer/fn.get_typed_column_writer.html  |   2 +-
 .../writer/fn.get_typed_column_writer_mut.html     |   2 +-
 .../writer/fn.get_typed_column_writer_ref.html     |   2 +-
 .../column/writer/fn.has_dictionary_support.html   |   2 +-
 parquet/column/writer/fn.increment.html            |   2 +-
 parquet/column/writer/fn.increment_utf8.html       |   2 +-
 parquet/column/writer/fn.is_nan.html               |   2 +-
 parquet/column/writer/fn.truncate_utf8.html        |   2 +-
 parquet/column/writer/fn.update_max.html           |   2 +-
 parquet/column/writer/fn.update_min.html           |   2 +-
 parquet/column/writer/fn.update_stat.html          |   2 +-
 parquet/column/writer/index.html                   |   2 +-
 parquet/column/writer/macro.downcast_writer.html   |   2 +-
 .../column/writer/struct.ColumnCloseResult.html    |   6 +-
 parquet/column/writer/struct.ColumnMetrics.html    |   6 +-
 .../column/writer/struct.GenericColumnWriter.html  |   6 +-
 parquet/column/writer/struct.PageMetrics.html      |   6 +-
 .../column/writer/trait.EncodingWriteSupport.html  |   2 +-
 parquet/column/writer/type.ColumnWriterImpl.html   |   2 +-
 parquet/data_type/enum.Decimal.html                |   6 +-
 parquet/data_type/index.html                       |   2 +-
 parquet/data_type/macro.ensure_phys_ty.html        |   2 +-
 parquet/data_type/macro.gen_as_bytes.html          |   2 +-
 parquet/data_type/macro.make_type.html             |   2 +-
 .../macro.unimplemented_slice_as_bytes.html        |   2 +-
 parquet/data_type/private/index.html               |   2 +-
 parquet/data_type/private/macro.impl_from_raw.html |   2 +-
 .../data_type/private/trait.ParquetValueType.html  |   2 +-
 parquet/data_type/struct.BoolType.html             |   6 +-
 parquet/data_type/struct.ByteArray.html            |  24 +-
 parquet/data_type/struct.ByteArrayType.html        |   6 +-
 parquet/data_type/struct.DoubleType.html           |   6 +-
 parquet/data_type/struct.FixedLenByteArray.html    |  16 +-
 .../data_type/struct.FixedLenByteArrayType.html    |   6 +-
 parquet/data_type/struct.FloatType.html            |   6 +-
 parquet/data_type/struct.Int32Type.html            |   6 +-
 parquet/data_type/struct.Int64Type.html            |   6 +-
 parquet/data_type/struct.Int96.html                |   6 +-
 parquet/data_type/struct.Int96Type.html            |   6 +-
 parquet/data_type/trait.AsBytes.html               |   2 +-
 parquet/data_type/trait.DataType.html              |   2 +-
 parquet/data_type/trait.SliceAsBytes.html          |   2 +-
 parquet/data_type/trait.SliceAsBytesDataType.html  |   2 +-
 parquet/errors/enum.ParquetError.html              |   8 +-
 parquet/errors/index.html                          |   2 +-
 parquet/errors/macro.arrow_err.html                |   2 +-
 parquet/errors/macro.eof_err.html                  |   2 +-
 parquet/errors/macro.general_err.html              |   2 +-
 parquet/errors/macro.nyi_err.html                  |   2 +-
 parquet/errors/type.Result.html                    |   2 +-
 parquet/file/constant.FOOTER_SIZE.html             |   2 +-
 parquet/file/constant.PARQUET_MAGIC.html           |   2 +-
 parquet/file/footer/fn.decode_footer.html          |   2 +-
 parquet/file/footer/fn.decode_metadata.html        |   2 +-
 parquet/file/footer/fn.parse_column_orders.html    |   2 +-
 parquet/file/footer/fn.parse_metadata.html         |   2 +-
 parquet/file/footer/index.html                     |   2 +-
 parquet/file/index.html                            |   2 +-
 parquet/file/metadata/index.html                   |   2 +-
 .../file/metadata/struct.ColumnChunkMetaData.html  |   6 +-
 .../struct.ColumnChunkMetaDataBuilder.html         |   6 +-
 .../file/metadata/struct.ColumnIndexBuilder.html   |   6 +-
 parquet/file/metadata/struct.FileMetaData.html     |   6 +-
 .../file/metadata/struct.OffsetIndexBuilder.html   |   6 +-
 parquet/file/metadata/struct.ParquetMetaData.html  |   6 +-
 parquet/file/metadata/struct.RowGroupMetaData.html |   6 +-
 .../metadata/struct.RowGroupMetaDataBuilder.html   |   6 +-
 parquet/file/metadata/type.FileMetaDataPtr.html    |   2 +-
 parquet/file/metadata/type.KeyValue.html           |   2 +-
 parquet/file/metadata/type.ParquetColumnIndex.html |   2 +-
 parquet/file/metadata/type.ParquetOffsetIndex.html |   2 +-
 .../file/metadata/type.RowGroupMetaDataPtr.html    |   2 +-
 parquet/file/page_encoding_stats/fn.to_thrift.html |   2 +-
 .../page_encoding_stats/fn.try_from_thrift.html    |   2 +-
 parquet/file/page_encoding_stats/index.html        |   2 +-
 .../struct.PageEncodingStats.html                  |   6 +-
 parquet/file/page_index/index.html                 |   2 +-
 parquet/file/page_index/index/enum.Index.html      |   6 +-
 parquet/file/page_index/index/index.html           |   2 +-
 .../file/page_index/index/struct.NativeIndex.html  |   6 +-
 .../file/page_index/index/struct.PageIndex.html    |   6 +-
 .../file/page_index/index_reader/fn.acc_range.html |   2 +-
 .../index_reader/fn.decode_column_index.html       |   2 +-
 .../index_reader/fn.decode_offset_index.html       |   2 +-
 .../index_reader/fn.read_columns_indexes.html      |   2 +-
 .../index_reader/fn.read_pages_locations.html      |   2 +-
 parquet/file/page_index/index_reader/index.html    |   2 +-
 .../constant.DEFAULT_BLOOM_FILTER_FPP.html         |   2 +-
 .../constant.DEFAULT_BLOOM_FILTER_NDV.html         |   2 +-
 ...stant.DEFAULT_COLUMN_INDEX_TRUNCATE_LENGTH.html |   2 +-
 .../properties/constant.DEFAULT_COMPRESSION.html   |   2 +-
 .../properties/constant.DEFAULT_CREATED_BY.html    |   2 +-
 .../constant.DEFAULT_DICTIONARY_ENABLED.html       |   2 +-
 ...onstant.DEFAULT_DICTIONARY_PAGE_SIZE_LIMIT.html |   2 +-
 .../constant.DEFAULT_MAX_ROW_GROUP_SIZE.html       |   2 +-
 .../constant.DEFAULT_MAX_STATISTICS_SIZE.html      |   2 +-
 .../properties/constant.DEFAULT_PAGE_SIZE.html     |   2 +-
 .../constant.DEFAULT_READ_BLOOM_FILTER.html        |   2 +-
 .../constant.DEFAULT_STATISTICS_ENABLED.html       |   2 +-
 ...onstant.DEFAULT_STATISTICS_TRUNCATE_LENGTH.html |   2 +-
 .../constant.DEFAULT_WRITER_VERSION.html           |   2 +-
 .../constant.DEFAULT_WRITE_BATCH_SIZE.html         |   2 +-
 .../file/properties/enum.EnabledStatistics.html    |   6 +-
 parquet/file/properties/enum.WriterVersion.html    |   6 +-
 parquet/file/properties/index.html                 |   2 +-
 .../properties/struct.BloomFilterProperties.html   |   6 +-
 .../file/properties/struct.ColumnProperties.html   |   6 +-
 .../file/properties/struct.ReaderProperties.html   |   6 +-
 .../properties/struct.ReaderPropertiesBuilder.html |   6 +-
 .../file/properties/struct.WriterProperties.html   |   6 +-
 .../properties/struct.WriterPropertiesBuilder.html |   6 +-
 .../file/properties/type.ReaderPropertiesPtr.html  |   2 +-
 .../file/properties/type.WriterPropertiesPtr.html  |   2 +-
 parquet/file/reader/index.html                     |   2 +-
 parquet/file/reader/struct.FilePageIterator.html   |   6 +-
 parquet/file/reader/trait.ChunkReader.html         |   2 +-
 parquet/file/reader/trait.FileReader.html          |   2 +-
 parquet/file/reader/trait.Length.html              |   2 +-
 parquet/file/reader/trait.RowGroupReader.html      |   2 +-
 .../enum.SerializedPageReaderState.html            |   6 +-
 parquet/file/serialized_reader/fn.decode_page.html |   2 +-
 .../serialized_reader/fn.get_midpoint_offset.html  |   2 +-
 .../serialized_reader/fn.read_page_header.html     |   2 +-
 .../serialized_reader/fn.read_page_header_len.html |   2 +-
 parquet/file/serialized_reader/index.html          |   2 +-
 .../file/serialized_reader/struct.ReadOptions.html |   6 +-
 .../struct.ReadOptionsBuilder.html                 |   6 +-
 .../struct.SerializedFileReader.html               |   8 +-
 .../struct.SerializedPageReader.html               |   6 +-
 .../struct.SerializedRowGroupReader.html           |   6 +-
 .../serialized_reader/type.ReadGroupPredicate.html |   2 +-
 parquet/file/statistics/enum.Statistics.html       |   6 +-
 parquet/file/statistics/fn.from_thrift.html        |   2 +-
 parquet/file/statistics/fn.to_thrift.html          |   2 +-
 parquet/file/statistics/index.html                 |   2 +-
 .../statistics/macro.statistics_enum_func.html     |   2 +-
 .../file/statistics/macro.statistics_new_func.html |   2 +-
 parquet/file/statistics/private/index.html         |   2 +-
 .../private/macro.gen_make_statistics.html         |   2 +-
 .../statistics/private/trait.MakeStatistics.html   |   2 +-
 .../file/statistics/struct.ValueStatistics.html    |   6 +-
 parquet/file/statistics/type.TypedStatistics.html  |   2 +-
 parquet/file/writer/index.html                     |   2 +-
 .../file/writer/struct.SerializedColumnWriter.html |   6 +-
 .../file/writer/struct.SerializedFileWriter.html   |   6 +-
 .../file/writer/struct.SerializedPageWriter.html   |   6 +-
 .../writer/struct.SerializedRowGroupWriter.html    |   6 +-
 parquet/file/writer/struct.TrackedWrite.html       |   8 +-
 parquet/file/writer/type.OnCloseColumnChunk.html   |   2 +-
 parquet/file/writer/type.OnCloseRowGroup.html      |   2 +-
 parquet/format/enum.BloomFilterAlgorithm.html      |   6 +-
 parquet/format/enum.BloomFilterCompression.html    |   6 +-
 parquet/format/enum.BloomFilterHash.html           |   6 +-
 parquet/format/enum.ColumnCryptoMetaData.html      |   6 +-
 parquet/format/enum.ColumnOrder.html               |   6 +-
 parquet/format/enum.EncryptionAlgorithm.html       |   6 +-
 parquet/format/enum.LogicalType.html               |   6 +-
 parquet/format/enum.TimeUnit.html                  |   6 +-
 parquet/format/index.html                          |   2 +-
 parquet/format/struct.AesGcmCtrV1.html             |   6 +-
 parquet/format/struct.AesGcmV1.html                |   6 +-
 parquet/format/struct.BloomFilterHeader.html       |   6 +-
 parquet/format/struct.BoundaryOrder.html           |   8 +-
 parquet/format/struct.BsonType.html                |   6 +-
 parquet/format/struct.ColumnChunk.html             |   6 +-
 parquet/format/struct.ColumnIndex.html             |   6 +-
 parquet/format/struct.ColumnMetaData.html          |   6 +-
 parquet/format/struct.CompressionCodec.html        |   8 +-
 parquet/format/struct.ConvertedType.html           |   8 +-
 parquet/format/struct.DataPageHeader.html          |   6 +-
 parquet/format/struct.DataPageHeaderV2.html        |   6 +-
 parquet/format/struct.DateType.html                |   6 +-
 parquet/format/struct.DecimalType.html             |   6 +-
 parquet/format/struct.DictionaryPageHeader.html    |   6 +-
 parquet/format/struct.Encoding.html                |   8 +-
 parquet/format/struct.EncryptionWithColumnKey.html |   6 +-
 parquet/format/struct.EncryptionWithFooterKey.html |   6 +-
 parquet/format/struct.EnumType.html                |   6 +-
 parquet/format/struct.FieldRepetitionType.html     |   8 +-
 parquet/format/struct.FileCryptoMetaData.html      |   6 +-
 parquet/format/struct.FileMetaData.html            |   6 +-
 parquet/format/struct.Float16Type.html             |   6 +-
 parquet/format/struct.IndexPageHeader.html         |   6 +-
 parquet/format/struct.IntType.html                 |   6 +-
 parquet/format/struct.JsonType.html                |   6 +-
 parquet/format/struct.KeyValue.html                |   6 +-
 parquet/format/struct.ListType.html                |   6 +-
 parquet/format/struct.MapType.html                 |   6 +-
 parquet/format/struct.MicroSeconds.html            |   6 +-
 parquet/format/struct.MilliSeconds.html            |   6 +-
 parquet/format/struct.NanoSeconds.html             |   6 +-
 parquet/format/struct.NullType.html                |   6 +-
 parquet/format/struct.OffsetIndex.html             |   6 +-
 parquet/format/struct.PageEncodingStats.html       |   6 +-
 parquet/format/struct.PageHeader.html              |   6 +-
 parquet/format/struct.PageLocation.html            |   6 +-
 parquet/format/struct.PageType.html                |   8 +-
 parquet/format/struct.RowGroup.html                |   6 +-
 parquet/format/struct.SchemaElement.html           |   6 +-
 parquet/format/struct.SortingColumn.html           |   6 +-
 parquet/format/struct.SplitBlockAlgorithm.html     |   6 +-
 parquet/format/struct.Statistics.html              |   6 +-
 parquet/format/struct.StringType.html              |   6 +-
 parquet/format/struct.TimeType.html                |   6 +-
 parquet/format/struct.TimestampType.html           |   6 +-
 parquet/format/struct.Type.html                    |   8 +-
 parquet/format/struct.TypeDefinedOrder.html        |   6 +-
 parquet/format/struct.UUIDType.html                |   6 +-
 parquet/format/struct.Uncompressed.html            |   6 +-
 parquet/format/struct.XxHash.html                  |   6 +-
 parquet/index.html                                 |   6 +-
 parquet/macro.experimental.html                    |   2 +-
 parquet/record/api/enum.Field.html                 |   6 +-
 parquet/record/api/fn.convert_date_to_string.html  |   2 +-
 .../record/api/fn.convert_decimal_to_string.html   |   2 +-
 .../api/fn.convert_timestamp_micros_to_string.html |   2 +-
 .../api/fn.convert_timestamp_millis_to_string.html |   2 +-
 .../api/fn.convert_timestamp_secs_to_string.html   |   2 +-
 parquet/record/api/fn.make_list.html               |   2 +-
 parquet/record/api/fn.make_map.html                |   2 +-
 parquet/record/api/fn.make_row.html                |   2 +-
 parquet/record/api/index.html                      |   2 +-
 .../record/api/macro.list_complex_accessor.html    |   2 +-
 .../record/api/macro.list_primitive_accessor.html  |   2 +-
 .../api/macro.map_list_primitive_accessor.html     |   2 +-
 parquet/record/api/macro.nyi.html                  |   2 +-
 parquet/record/api/macro.row_complex_accessor.html |   2 +-
 .../record/api/macro.row_primitive_accessor.html   |   2 +-
 parquet/record/api/struct.List.html                |   6 +-
 parquet/record/api/struct.Map.html                 |   6 +-
 parquet/record/api/struct.MapList.html             |   6 +-
 parquet/record/api/struct.Row.html                 |  10 +-
 parquet/record/api/struct.RowColumnIter.html       |  10 +-
 parquet/record/api/trait.ListAccessor.html         |   2 +-
 parquet/record/api/trait.MapAccessor.html          |   2 +-
 parquet/record/api/trait.RowAccessor.html          |   2 +-
 parquet/record/api/trait.RowFormatter.html         |   2 +-
 parquet/record/enum.Field.html                     |   6 +-
 parquet/record/index.html                          |   2 +-
 .../record/reader/constant.DEFAULT_BATCH_SIZE.html |   2 +-
 parquet/record/reader/enum.Either.html             |   6 +-
 parquet/record/reader/enum.Reader.html             |   6 +-
 parquet/record/reader/index.html                   |   2 +-
 parquet/record/reader/struct.ReaderIter.html       |   6 +-
 parquet/record/reader/struct.RowIter.html          |   6 +-
 parquet/record/reader/struct.TreeBuilder.html      |   6 +-
 parquet/record/record_reader/index.html            |   2 +-
 .../record/record_reader/trait.RecordReader.html   |   2 +-
 parquet/record/record_writer/index.html            |   2 +-
 .../record/record_writer/trait.RecordWriter.html   |   2 +-
 parquet/record/struct.List.html                    |   6 +-
 parquet/record/struct.Map.html                     |   6 +-
 parquet/record/struct.Row.html                     |  10 +-
 parquet/record/struct.RowColumnIter.html           |  10 +-
 parquet/record/trait.ListAccessor.html             |   2 +-
 parquet/record/trait.MapAccessor.html              |   2 +-
 parquet/record/trait.RecordReader.html             |   2 +-
 parquet/record/trait.RecordWriter.html             |   2 +-
 parquet/record/trait.RowAccessor.html              |   2 +-
 parquet/record/trait.RowFormatter.html             |   2 +-
 parquet/record/triplet/enum.TripletIter.html       |   6 +-
 parquet/record/triplet/index.html                  |   2 +-
 .../record/triplet/macro.triplet_enum_func.html    |   2 +-
 .../record/triplet/struct.TypedTripletIter.html    |   6 +-
 parquet/schema/index.html                          |   2 +-
 parquet/schema/parser/fn.assert_token.html         |   2 +-
 parquet/schema/parser/fn.parse_bool.html           |   2 +-
 parquet/schema/parser/fn.parse_i32.html            |   2 +-
 parquet/schema/parser/fn.parse_message_type.html   |   2 +-
 parquet/schema/parser/fn.parse_timeunit.html       |   2 +-
 parquet/schema/parser/index.html                   |   2 +-
 parquet/schema/parser/struct.Parser.html           |   6 +-
 parquet/schema/parser/struct.Tokenizer.html        |   6 +-
 parquet/schema/printer/constant.INDENT_WIDTH.html  |   2 +-
 .../printer/fn.print_column_chunk_metadata.html    |   2 +-
 parquet/schema/printer/fn.print_dashes.html        |   2 +-
 parquet/schema/printer/fn.print_file_metadata.html |   2 +-
 .../printer/fn.print_logical_and_converted.html    |   2 +-
 .../schema/printer/fn.print_parquet_metadata.html  |   2 +-
 .../printer/fn.print_row_group_metadata.html       |   2 +-
 parquet/schema/printer/fn.print_schema.html        |   2 +-
 parquet/schema/printer/fn.print_timeunit.html      |   2 +-
 parquet/schema/printer/index.html                  |   2 +-
 parquet/schema/printer/struct.Printer.html         |   6 +-
 parquet/schema/types/enum.Type.html                |   6 +-
 parquet/schema/types/fn.build_tree.html            |   2 +-
 parquet/schema/types/fn.from_thrift.html           |   2 +-
 parquet/schema/types/fn.from_thrift_helper.html    |   2 +-
 parquet/schema/types/fn.to_thrift.html             |   2 +-
 parquet/schema/types/fn.to_thrift_helper.html      |   2 +-
 parquet/schema/types/index.html                    |   2 +-
 parquet/schema/types/struct.BasicTypeInfo.html     |   6 +-
 parquet/schema/types/struct.ColumnDescriptor.html  |   6 +-
 parquet/schema/types/struct.ColumnPath.html        |   8 +-
 parquet/schema/types/struct.GroupTypeBuilder.html  |   6 +-
 .../schema/types/struct.PrimitiveTypeBuilder.html  |   6 +-
 parquet/schema/types/struct.SchemaDescriptor.html  |   6 +-
 parquet/schema/types/type.ColumnDescPtr.html       |   2 +-
 parquet/schema/types/type.SchemaDescPtr.html       |   2 +-
 parquet/schema/types/type.TypePtr.html             |   2 +-
 parquet/schema/visitor/index.html                  |   2 +-
 parquet/schema/visitor/trait.TypeVisitor.html      |   2 +-
 parquet/thrift/fn.collection_u8_to_type.html       |   2 +-
 parquet/thrift/fn.eof_error.html                   |   2 +-
 parquet/thrift/fn.u8_to_type.html                  |   2 +-
 parquet/thrift/index.html                          |   2 +-
 .../thrift/struct.TCompactSliceInputProtocol.html  |   6 +-
 parquet/thrift/trait.TSerializable.html            |   2 +-
 parquet_concat/all.html                            |   2 +-
 parquet_concat/fn.main.html                        |   2 +-
 parquet_concat/index.html                          |   2 +-
 parquet_concat/struct.Args.html                    |   6 +-
 parquet_derive/all.html                            |   2 +-
 parquet_derive/derive.ParquetRecordReader.html     |   2 +-
 parquet_derive/derive.ParquetRecordWriter.html     |   2 +-
 parquet_derive/index.html                          |   2 +-
 .../parquet_field/enum.ThirdPartyType.html         |   6 +-
 parquet_derive/parquet_field/enum.Type.html        |   8 +-
 parquet_derive/parquet_field/index.html            |   2 +-
 parquet_derive/parquet_field/struct.Field.html     |   6 +-
 parquet_derive_test/all.html                       |   2 +-
 parquet_derive_test/index.html                     |   2 +-
 parquet_derive_test/struct.ACompleteRecord.html    |   6 +-
 .../struct.APartiallyCompleteRecord.html           |   6 +-
 parquet_fromcsv/all.html                           |   2 +-
 parquet_fromcsv/enum.CsvDialect.html               |   6 +-
 parquet_fromcsv/enum.ParquetFromCsvError.html      |  12 +-
 parquet_fromcsv/enum.RecordTerminator.html         |   6 +-
 parquet_fromcsv/fn.arrow_schema_from_string.html   |   4 +-
 parquet_fromcsv/fn.compression_from_str.html       |   2 +-
 parquet_fromcsv/fn.configure_reader_builder.html   |   6 +-
 .../fn.configure_writer_properties.html            |   2 +-
 parquet_fromcsv/fn.convert_csv_to_parquet.html     |   2 +-
 parquet_fromcsv/fn.main.html                       |   2 +-
 parquet_fromcsv/fn.writer_version_from_str.html    |   2 +-
 parquet_fromcsv/index.html                         |   2 +-
 parquet_fromcsv/struct.Args.html                   |   6 +-
 parquet_index/all.html                             |   2 +-
 parquet_index/fn.compute_row_counts.html           |   2 +-
 parquet_index/fn.main.html                         |   2 +-
 parquet_index/fn.print_index.html                  |   2 +-
 parquet_index/index.html                           |   2 +-
 parquet_index/struct.Args.html                     |   6 +-
 parquet_layout/all.html                            |   2 +-
 parquet_layout/fn.compression.html                 |   2 +-
 parquet_layout/fn.do_layout.html                   |   2 +-
 parquet_layout/fn.encoding.html                    |   2 +-
 parquet_layout/fn.main.html                        |   2 +-
 parquet_layout/fn.read_page_header.html            |   2 +-
 parquet_layout/index.html                          |   2 +-
 parquet_layout/struct.Args.html                    |   6 +-
 parquet_layout/struct.ColumnChunk.html             |   6 +-
 parquet_layout/struct.Page.html                    |   6 +-
 parquet_layout/struct.ParquetFile.html             |   6 +-
 parquet_layout/struct.RowGroup.html                |   6 +-
 parquet_read/all.html                              |   2 +-
 parquet_read/fn.main.html                          |   2 +-
 parquet_read/fn.print_row.html                     |   2 +-
 parquet_read/index.html                            |   2 +-
 parquet_read/struct.Args.html                      |   6 +-
 parquet_rewrite/all.html                           |   2 +-
 parquet_rewrite/enum.CompressionArgs.html          |   6 +-
 parquet_rewrite/enum.EnabledStatisticsArgs.html    |   6 +-
 parquet_rewrite/enum.WriterVersionArgs.html        |   6 +-
 parquet_rewrite/fn.main.html                       |   2 +-
 parquet_rewrite/index.html                         |   2 +-
 parquet_rewrite/struct.Args.html                   |   6 +-
 parquet_rowcount/all.html                          |   2 +-
 parquet_rowcount/fn.main.html                      |   2 +-
 parquet_rowcount/index.html                        |   2 +-
 parquet_rowcount/struct.Args.html                  |   6 +-
 parquet_schema/all.html                            |   2 +-
 parquet_schema/fn.main.html                        |   2 +-
 parquet_schema/index.html                          |   2 +-
 parquet_schema/struct.Args.html                    |   6 +-
 parquet_show_bloom_filter/all.html                 |   2 +-
 parquet_show_bloom_filter/fn.main.html             |   2 +-
 parquet_show_bloom_filter/index.html               |   2 +-
 parquet_show_bloom_filter/struct.Args.html         |   6 +-
 search-index.js                                    |  32 +-
 settings.html                                      |   4 +-
 src/arrow/array/ffi.rs.html                        |   2 +-
 src/arrow/array/mod.rs.html                        |   2 +-
 src/arrow/compute/kernels.rs.html                  |   2 +-
 src/arrow/compute/mod.rs.html                      |   2 +-
 src/arrow/datatypes/mod.rs.html                    |   2 +-
 src/arrow/error.rs.html                            |   2 +-
 src/arrow/ffi.rs.html                              |   2 +-
 src/arrow/ffi_stream.rs.html                       |   2 +-
 src/arrow/lib.rs.html                              |   2 +-
 src/arrow/pyarrow.rs.html                          |   2 +-
 src/arrow/tensor.rs.html                           |   2 +-
 src/arrow/util/bench_util.rs.html                  |   2 +-
 src/arrow/util/data_gen.rs.html                    |   2 +-
 src/arrow/util/mod.rs.html                         |   2 +-
 src/arrow/util/string_writer.rs.html               |   2 +-
 src/arrow/util/test_util.rs.html                   |   2 +-
 src/arrow_arith/aggregate.rs.html                  |   2 +-
 src/arrow_arith/arithmetic.rs.html                 |   2 +-
 src/arrow_arith/arity.rs.html                      |   2 +-
 src/arrow_arith/bitwise.rs.html                    |   2 +-
 src/arrow_arith/boolean.rs.html                    |   2 +-
 src/arrow_arith/lib.rs.html                        |   2 +-
 src/arrow_arith/numeric.rs.html                    |   2 +-
 src/arrow_arith/temporal.rs.html                   |   2 +-
 src/arrow_array/arithmetic.rs.html                 |   2 +-
 src/arrow_array/array/binary_array.rs.html         |   2 +-
 src/arrow_array/array/boolean_array.rs.html        |   2 +-
 src/arrow_array/array/byte_array.rs.html           |   2 +-
 src/arrow_array/array/dictionary_array.rs.html     |   2 +-
 .../array/fixed_size_binary_array.rs.html          |   2 +-
 .../array/fixed_size_list_array.rs.html            |   2 +-
 src/arrow_array/array/list_array.rs.html           |   2 +-
 src/arrow_array/array/map_array.rs.html            |   2 +-
 src/arrow_array/array/mod.rs.html                  |   2 +-
 src/arrow_array/array/null_array.rs.html           |   2 +-
 src/arrow_array/array/primitive_array.rs.html      |   2 +-
 src/arrow_array/array/run_array.rs.html            |   2 +-
 src/arrow_array/array/string_array.rs.html         |   2 +-
 src/arrow_array/array/struct_array.rs.html         |   2 +-
 src/arrow_array/array/union_array.rs.html          |   2 +-
 src/arrow_array/builder/boolean_builder.rs.html    |   2 +-
 src/arrow_array/builder/buffer_builder.rs.html     |   2 +-
 .../builder/fixed_size_binary_builder.rs.html      |   2 +-
 .../builder/fixed_size_list_builder.rs.html        |   2 +-
 .../builder/generic_byte_run_builder.rs.html       |   2 +-
 .../builder/generic_bytes_builder.rs.html          |   2 +-
 .../generic_bytes_dictionary_builder.rs.html       |   2 +-
 .../builder/generic_list_builder.rs.html           |   2 +-
 src/arrow_array/builder/map_builder.rs.html        |   2 +-
 src/arrow_array/builder/mod.rs.html                |   2 +-
 src/arrow_array/builder/null_builder.rs.html       |   2 +-
 src/arrow_array/builder/primitive_builder.rs.html  |   2 +-
 .../builder/primitive_dictionary_builder.rs.html   |   2 +-
 .../builder/primitive_run_builder.rs.html          |   2 +-
 src/arrow_array/builder/struct_builder.rs.html     |   2 +-
 src/arrow_array/builder/union_builder.rs.html      |   2 +-
 src/arrow_array/cast.rs.html                       |   2 +-
 src/arrow_array/delta.rs.html                      |   2 +-
 src/arrow_array/iterator.rs.html                   |   2 +-
 src/arrow_array/lib.rs.html                        |   2 +-
 src/arrow_array/numeric.rs.html                    |   2 +-
 src/arrow_array/record_batch.rs.html               |   2 +-
 src/arrow_array/run_iterator.rs.html               |   2 +-
 src/arrow_array/scalar.rs.html                     |   2 +-
 src/arrow_array/temporal_conversions.rs.html       |   2 +-
 src/arrow_array/timezone.rs.html                   |   2 +-
 src/arrow_array/trusted_len.rs.html                |   2 +-
 src/arrow_array/types.rs.html                      |   2 +-
 src/arrow_avro/codec.rs.html                       |   2 +-
 src/arrow_avro/compression.rs.html                 |   2 +-
 src/arrow_avro/lib.rs.html                         |   2 +-
 src/arrow_avro/reader/block.rs.html                |   2 +-
 src/arrow_avro/reader/header.rs.html               |   2 +-
 src/arrow_avro/reader/mod.rs.html                  |   2 +-
 src/arrow_avro/reader/vlq.rs.html                  |   2 +-
 src/arrow_avro/schema.rs.html                      |   2 +-
 src/arrow_buffer/alloc/alignment.rs.html           |   2 +-
 src/arrow_buffer/alloc/mod.rs.html                 |   2 +-
 src/arrow_buffer/bigint/div.rs.html                |   2 +-
 src/arrow_buffer/bigint/mod.rs.html                |   2 +-
 src/arrow_buffer/buffer/boolean.rs.html            |   2 +-
 src/arrow_buffer/buffer/immutable.rs.html          |   2 +-
 src/arrow_buffer/buffer/mod.rs.html                |   2 +-
 src/arrow_buffer/buffer/mutable.rs.html            |   2 +-
 src/arrow_buffer/buffer/null.rs.html               |   2 +-
 src/arrow_buffer/buffer/offset.rs.html             |   2 +-
 src/arrow_buffer/buffer/ops.rs.html                |   2 +-
 src/arrow_buffer/buffer/run.rs.html                |   2 +-
 src/arrow_buffer/buffer/scalar.rs.html             |   2 +-
 src/arrow_buffer/builder/boolean.rs.html           |   2 +-
 src/arrow_buffer/builder/mod.rs.html               |   2 +-
 src/arrow_buffer/builder/null.rs.html              |   2 +-
 src/arrow_buffer/bytes.rs.html                     |   2 +-
 src/arrow_buffer/lib.rs.html                       |   2 +-
 src/arrow_buffer/native.rs.html                    |   2 +-
 src/arrow_buffer/util/bit_chunk_iterator.rs.html   |   2 +-
 src/arrow_buffer/util/bit_iterator.rs.html         |   2 +-
 src/arrow_buffer/util/bit_mask.rs.html             |   2 +-
 src/arrow_buffer/util/bit_util.rs.html             |   2 +-
 src/arrow_buffer/util/mod.rs.html                  |   2 +-
 src/arrow_cast/base64.rs.html                      |   2 +-
 src/arrow_cast/cast.rs.html                        |   2 +-
 src/arrow_cast/display.rs.html                     |   2 +-
 src/arrow_cast/lib.rs.html                         |   2 +-
 src/arrow_cast/parse.rs.html                       |   2 +-
 src/arrow_cast/pretty.rs.html                      |   2 +-
 src/arrow_csv/lib.rs.html                          |   2 +-
 src/arrow_csv/reader/mod.rs.html                   |   2 +-
 src/arrow_csv/reader/records.rs.html               |   2 +-
 src/arrow_csv/writer.rs.html                       |   2 +-
 src/arrow_data/data.rs.html                        |   2 +-
 src/arrow_data/decimal.rs.html                     |   2 +-
 src/arrow_data/equal/boolean.rs.html               |   2 +-
 src/arrow_data/equal/dictionary.rs.html            |   2 +-
 src/arrow_data/equal/fixed_binary.rs.html          |   2 +-
 src/arrow_data/equal/fixed_list.rs.html            |   2 +-
 src/arrow_data/equal/list.rs.html                  |   2 +-
 src/arrow_data/equal/mod.rs.html                   |   2 +-
 src/arrow_data/equal/null.rs.html                  |   2 +-
 src/arrow_data/equal/primitive.rs.html             |   2 +-
 src/arrow_data/equal/run.rs.html                   |   2 +-
 src/arrow_data/equal/structure.rs.html             |   2 +-
 src/arrow_data/equal/union.rs.html                 |   2 +-
 src/arrow_data/equal/utils.rs.html                 |   2 +-
 src/arrow_data/equal/variable_size.rs.html         |   2 +-
 src/arrow_data/ffi.rs.html                         |   2 +-
 src/arrow_data/lib.rs.html                         |   2 +-
 src/arrow_data/transform/boolean.rs.html           |   2 +-
 src/arrow_data/transform/fixed_binary.rs.html      |   2 +-
 src/arrow_data/transform/fixed_size_list.rs.html   |   2 +-
 src/arrow_data/transform/list.rs.html              |   2 +-
 src/arrow_data/transform/mod.rs.html               |   2 +-
 src/arrow_data/transform/null.rs.html              |   2 +-
 src/arrow_data/transform/primitive.rs.html         |   2 +-
 src/arrow_data/transform/structure.rs.html         |   2 +-
 src/arrow_data/transform/union.rs.html             |   2 +-
 src/arrow_data/transform/utils.rs.html             |   2 +-
 src/arrow_data/transform/variable_size.rs.html     |   2 +-
 .../arrow-file-to-stream.rs.html                   |   2 +-
 src/arrow_flight/arrow.flight.protocol.rs.html     |   2 +-
 src/arrow_flight/client.rs.html                    |   2 +-
 src/arrow_flight/decode.rs.html                    |   2 +-
 src/arrow_flight/encode.rs.html                    |   2 +-
 src/arrow_flight/error.rs.html                     |   2 +-
 src/arrow_flight/lib.rs.html                       |   2 +-
 .../sql/arrow.flight.protocol.sql.rs.html          |   2 +-
 src/arrow_flight/sql/client.rs.html                |   2 +-
 src/arrow_flight/sql/metadata/catalogs.rs.html     |   2 +-
 src/arrow_flight/sql/metadata/db_schemas.rs.html   |   2 +-
 src/arrow_flight/sql/metadata/mod.rs.html          |   2 +-
 src/arrow_flight/sql/metadata/sql_info.rs.html     |   2 +-
 src/arrow_flight/sql/metadata/tables.rs.html       |   2 +-
 src/arrow_flight/sql/metadata/xdbc_info.rs.html    |   2 +-
 src/arrow_flight/sql/mod.rs.html                   |   2 +-
 src/arrow_flight/sql/server.rs.html                |   2 +-
 src/arrow_flight/trailers.rs.html                  |   2 +-
 src/arrow_flight/utils.rs.html                     |   2 +-
 src/arrow_integration_test/datatype.rs.html        |   2 +-
 src/arrow_integration_test/field.rs.html           |   2 +-
 src/arrow_integration_test/lib.rs.html             |   2 +-
 src/arrow_integration_test/schema.rs.html          |   2 +-
 .../flight_client_scenarios.rs.html                |   2 +-
 .../auth_basic_proto.rs.html                       |   2 +-
 .../integration_test.rs.html                       |   2 +-
 .../flight_client_scenarios/middleware.rs.html     |   2 +-
 .../flight_server_scenarios.rs.html                |   2 +-
 .../auth_basic_proto.rs.html                       |   2 +-
 .../integration_test.rs.html                       |   2 +-
 .../flight_server_scenarios/middleware.rs.html     |   2 +-
 src/arrow_integration_testing/lib.rs.html          |   2 +-
 src/arrow_ipc/compression.rs.html                  |   2 +-
 src/arrow_ipc/convert.rs.html                      |   2 +-
 src/arrow_ipc/gen/File.rs.html                     |   2 +-
 src/arrow_ipc/gen/Message.rs.html                  |   2 +-
 src/arrow_ipc/gen/Schema.rs.html                   |   2 +-
 src/arrow_ipc/gen/SparseTensor.rs.html             |   2 +-
 src/arrow_ipc/gen/Tensor.rs.html                   |   2 +-
 src/arrow_ipc/gen/mod.rs.html                      |   2 +-
 src/arrow_ipc/lib.rs.html                          |   2 +-
 src/arrow_ipc/reader.rs.html                       |   2 +-
 src/arrow_ipc/writer.rs.html                       |   2 +-
 src/arrow_json/lib.rs.html                         |   2 +-
 src/arrow_json/reader/boolean_array.rs.html        |   2 +-
 src/arrow_json/reader/decimal_array.rs.html        |   2 +-
 src/arrow_json/reader/list_array.rs.html           |   2 +-
 src/arrow_json/reader/map_array.rs.html            |   2 +-
 src/arrow_json/reader/mod.rs.html                  |   2 +-
 src/arrow_json/reader/null_array.rs.html           |   2 +-
 src/arrow_json/reader/primitive_array.rs.html      |   2 +-
 src/arrow_json/reader/schema.rs.html               |   2 +-
 src/arrow_json/reader/serializer.rs.html           |   2 +-
 src/arrow_json/reader/string_array.rs.html         |   2 +-
 src/arrow_json/reader/struct_array.rs.html         |   2 +-
 src/arrow_json/reader/tape.rs.html                 |   2 +-
 src/arrow_json/reader/timestamp_array.rs.html      |   2 +-
 src/arrow_json/writer.rs.html                      |   2 +-
 src/arrow_json/writer/encoder.rs.html              |   2 +-
 .../arrow-json-integration-test.rs.html            |   2 +-
 src/arrow_ord/cmp.rs.html                          |   2 +-
 src/arrow_ord/comparison.rs.html                   |   2 +-
 src/arrow_ord/lib.rs.html                          |   2 +-
 src/arrow_ord/ord.rs.html                          |   2 +-
 src/arrow_ord/partition.rs.html                    |   2 +-
 src/arrow_ord/rank.rs.html                         |   2 +-
 src/arrow_ord/sort.rs.html                         |   2 +-
 src/arrow_row/fixed.rs.html                        |   2 +-
 src/arrow_row/lib.rs.html                          |   2 +-
 src/arrow_row/list.rs.html                         |   2 +-
 src/arrow_row/variable.rs.html                     |   2 +-
 src/arrow_schema/datatype.rs.html                  |   2 +-
 src/arrow_schema/error.rs.html                     |   2 +-
 src/arrow_schema/ffi.rs.html                       |   2 +-
 src/arrow_schema/field.rs.html                     |   2 +-
 src/arrow_schema/fields.rs.html                    |   2 +-
 src/arrow_schema/lib.rs.html                       |   2 +-
 src/arrow_schema/schema.rs.html                    |   2 +-
 src/arrow_select/concat.rs.html                    |   2 +-
 src/arrow_select/dictionary.rs.html                |   2 +-
 src/arrow_select/filter.rs.html                    |   2 +-
 src/arrow_select/interleave.rs.html                |   2 +-
 src/arrow_select/lib.rs.html                       |   2 +-
 src/arrow_select/nullif.rs.html                    |   2 +-
 src/arrow_select/take.rs.html                      |   2 +-
 src/arrow_select/window.rs.html                    |   2 +-
 src/arrow_select/zip.rs.html                       |   2 +-
 .../arrow-stream-to-file.rs.html                   |   2 +-
 src/arrow_string/concat_elements.rs.html           |   2 +-
 src/arrow_string/length.rs.html                    |   2 +-
 src/arrow_string/lib.rs.html                       |   2 +-
 src/arrow_string/like.rs.html                      |   2 +-
 src/arrow_string/predicate.rs.html                 |   2 +-
 src/arrow_string/regexp.rs.html                    |   2 +-
 src/arrow_string/substring.rs.html                 |   2 +-
 src/flight_sql_client/flight_sql_client.rs.html    |   2 +-
 .../flight-test-integration-client.rs.html         |   2 +-
 .../flight-test-integration-server.rs.html         |   2 +-
 src/gen/main.rs.html                               |   2 +-
 src/parquet/arrow/array_reader/builder.rs.html     |   2 +-
 src/parquet/arrow/array_reader/byte_array.rs.html  |   2 +-
 .../array_reader/byte_array_dictionary.rs.html     |   2 +-
 src/parquet/arrow/array_reader/empty_array.rs.html |   2 +-
 .../array_reader/fixed_len_byte_array.rs.html      |   2 +-
 .../array_reader/fixed_size_list_array.rs.html     |   2 +-
 src/parquet/arrow/array_reader/list_array.rs.html  |   2 +-
 src/parquet/arrow/array_reader/map_array.rs.html   |   2 +-
 src/parquet/arrow/array_reader/mod.rs.html         |   2 +-
 src/parquet/arrow/array_reader/null_array.rs.html  |   2 +-
 .../arrow/array_reader/primitive_array.rs.html     |   2 +-
 .../arrow/array_reader/struct_array.rs.html        |   2 +-
 src/parquet/arrow/arrow_reader/filter.rs.html      |   2 +-
 src/parquet/arrow/arrow_reader/mod.rs.html         |   2 +-
 src/parquet/arrow/arrow_reader/selection.rs.html   |   2 +-
 src/parquet/arrow/arrow_writer/byte_array.rs.html  |   2 +-
 src/parquet/arrow/arrow_writer/levels.rs.html      |   2 +-
 src/parquet/arrow/arrow_writer/mod.rs.html         |   2 +-
 src/parquet/arrow/async_reader/metadata.rs.html    |   2 +-
 src/parquet/arrow/async_reader/mod.rs.html         |   2 +-
 src/parquet/arrow/async_reader/store.rs.html       |   2 +-
 src/parquet/arrow/async_writer/mod.rs.html         |   2 +-
 src/parquet/arrow/buffer/bit_util.rs.html          |   2 +-
 src/parquet/arrow/buffer/dictionary_buffer.rs.html |   2 +-
 src/parquet/arrow/buffer/mod.rs.html               |   2 +-
 src/parquet/arrow/buffer/offset_buffer.rs.html     |   2 +-
 src/parquet/arrow/decoder/delta_byte_array.rs.html |   2 +-
 src/parquet/arrow/decoder/dictionary_index.rs.html |   2 +-
 src/parquet/arrow/decoder/mod.rs.html              |   2 +-
 src/parquet/arrow/mod.rs.html                      |   2 +-
 src/parquet/arrow/record_reader/buffer.rs.html     |   2 +-
 .../arrow/record_reader/definition_levels.rs.html  |   2 +-
 src/parquet/arrow/record_reader/mod.rs.html        |   2 +-
 src/parquet/arrow/schema/complex.rs.html           |   2 +-
 src/parquet/arrow/schema/mod.rs.html               |   2 +-
 src/parquet/arrow/schema/primitive.rs.html         |   2 +-
 src/parquet/basic.rs.html                          |   2 +-
 src/parquet/bloom_filter/mod.rs.html               |   2 +-
 src/parquet/column/mod.rs.html                     |   2 +-
 src/parquet/column/page.rs.html                    |   2 +-
 src/parquet/column/reader.rs.html                  |   2 +-
 src/parquet/column/reader/decoder.rs.html          |   2 +-
 src/parquet/column/writer/encoder.rs.html          |   2 +-
 src/parquet/column/writer/mod.rs.html              |   2 +-
 src/parquet/compression.rs.html                    |   2 +-
 src/parquet/data_type.rs.html                      |   2 +-
 src/parquet/encodings/decoding.rs.html             |   2 +-
 .../decoding/byte_stream_split_decoder.rs.html     |   2 +-
 .../encoding/byte_stream_split_encoder.rs.html     |   2 +-
 .../encodings/encoding/dict_encoder.rs.html        |   2 +-
 src/parquet/encodings/encoding/mod.rs.html         |   2 +-
 src/parquet/encodings/levels.rs.html               |   2 +-
 src/parquet/encodings/mod.rs.html                  |   2 +-
 src/parquet/encodings/rle.rs.html                  |   2 +-
 src/parquet/errors.rs.html                         |   2 +-
 src/parquet/file/footer.rs.html                    |   2 +-
 src/parquet/file/metadata.rs.html                  |   2 +-
 src/parquet/file/mod.rs.html                       |   2 +-
 src/parquet/file/page_encoding_stats.rs.html       |   2 +-
 src/parquet/file/page_index/index.rs.html          |   2 +-
 src/parquet/file/page_index/index_reader.rs.html   |   2 +-
 src/parquet/file/page_index/mod.rs.html            |   2 +-
 src/parquet/file/properties.rs.html                |   2 +-
 src/parquet/file/reader.rs.html                    |   2 +-
 src/parquet/file/serialized_reader.rs.html         |   2 +-
 src/parquet/file/statistics.rs.html                |   2 +-
 src/parquet/file/writer.rs.html                    |   2 +-
 src/parquet/format.rs.html                         |   2 +-
 src/parquet/lib.rs.html                            |   2 +-
 src/parquet/record/api.rs.html                     |   2 +-
 src/parquet/record/mod.rs.html                     |   2 +-
 src/parquet/record/reader.rs.html                  |   2 +-
 src/parquet/record/record_reader.rs.html           |   2 +-
 src/parquet/record/record_writer.rs.html           |   2 +-
 src/parquet/record/triplet.rs.html                 |   2 +-
 src/parquet/schema/mod.rs.html                     |   2 +-
 src/parquet/schema/parser.rs.html                  |   2 +-
 src/parquet/schema/printer.rs.html                 |   2 +-
 src/parquet/schema/types.rs.html                   |   2 +-
 src/parquet/schema/visitor.rs.html                 |   2 +-
 src/parquet/thrift.rs.html                         |   2 +-
 src/parquet/util/bit_pack.rs.html                  |   2 +-
 src/parquet/util/bit_util.rs.html                  |   2 +-
 src/parquet/util/interner.rs.html                  |   2 +-
 src/parquet/util/mod.rs.html                       |   2 +-
 src/parquet/util/test_common/mod.rs.html           |   2 +-
 src/parquet/util/test_common/page_util.rs.html     |   2 +-
 src/parquet_concat/parquet-concat.rs.html          |   2 +-
 src/parquet_derive/lib.rs.html                     |   2 +-
 src/parquet_derive/parquet_field.rs.html           |   2 +-
 src/parquet_derive_test/lib.rs.html                |   2 +-
 src/parquet_fromcsv/parquet-fromcsv.rs.html        |   2 +-
 src/parquet_index/parquet-index.rs.html            |   2 +-
 src/parquet_layout/parquet-layout.rs.html          |   2 +-
 src/parquet_read/parquet-read.rs.html              |   2 +-
 src/parquet_rewrite/parquet-rewrite.rs.html        |   2 +-
 src/parquet_rowcount/parquet-rowcount.rs.html      |   2 +-
 src/parquet_schema/parquet-schema.rs.html          |   2 +-
 .../parquet-show-bloom-filter.rs.html              |   2 +-
 .../record_batch/trait.RecordBatchReader.js        |   4 +-
 .../record_batch/trait.RecordBatchWriter.js        |   4 +-
 .../flight_service_server/trait.FlightService.js   |   2 +-
 trait.impl/core/convert/trait.From.js              |  10 +-
 trait.impl/core/convert/trait.TryFrom.js           |   2 +-
 trait.impl/core/default/trait.Default.js           |   2 +-
 trait.impl/core/fmt/trait.Debug.js                 |   2 +-
 type.impl/alloc/boxed/struct.Box.js                |  10 +-
 type.impl/alloc/sync/struct.Arc.js                 |   2 +-
 type.impl/alloc/vec/struct.Vec.js                  |   2 +-
 .../arrow/array/builder/struct.BufferBuilder.js    |   2 +-
 .../array/builder/struct.GenericByteBuilder.js     |   2 +-
 .../builder/struct.GenericByteDictionaryBuilder.js |   2 +-
 .../array/builder/struct.GenericByteRunBuilder.js  |   2 +-
 .../array/builder/struct.GenericListBuilder.js     |   2 +-
 .../arrow/array/builder/struct.PrimitiveBuilder.js |   2 +-
 type.impl/arrow/array/iterator/struct.ArrayIter.js |   2 +-
 type.impl/arrow/array/struct.DictionaryArray.js    |   2 +-
 type.impl/arrow/array/struct.GenericByteArray.js   |   2 +-
 type.impl/arrow/array/struct.GenericListArray.js   |   2 +-
 type.impl/arrow/array/struct.PrimitiveArray.js     |   2 +-
 type.impl/arrow/array/struct.RunArray.js           |   2 +-
 .../arrow/datatypes/struct.GenericBinaryType.js    |   2 +-
 .../arrow/datatypes/struct.GenericStringType.js    |   2 +-
 .../struct.FlightServiceClient.js                  |   2 +-
 .../arrow_reader/struct.ArrowReaderBuilder.js      |   2 +-
 .../record_reader/struct.GenericRecordReader.js    |   2 +-
 4429 files changed, 14239 insertions(+), 14239 deletions(-)

diff --git a/arrow/all.html b/arrow/all.html
index 4d11141b92a..bc953c3b6b6 100644
--- a/arrow/all.html
+++ b/arrow/all.html
@@ -1,2 +1,2 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="List of all items in this crate"><title>List of all items in this crate</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.fi [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="List of all items in this crate"><title>List of all items in this crate</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.fi [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../help.html" title="help">?</a></div><div id="sett [...]
\ No newline at end of file
diff --git a/arrow/alloc/constant.ALIGNMENT.html b/arrow/alloc/constant.ALIGNMENT.html
index 9e9d5448294..0232c7f9429 100644
--- a/arrow/alloc/constant.ALIGNMENT.html
+++ b/arrow/alloc/constant.ALIGNMENT.html
@@ -1,3 +1,3 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Cache and allocation multiple alignment size"><title>ALIGNMENT in arrow::alloc - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin h [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../help.html" title="help">?</a></div><div id [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Cache and allocation multiple alignment size"><title>ALIGNMENT in arrow::alloc - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin h [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../help.html" title="help">?</a></div><div id [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/alloc/index.html b/arrow/alloc/index.html
index 9c257525790..219634c8cd3 100644
--- a/arrow/alloc/index.html
+++ b/arrow/alloc/index.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Defines the low-level `Allocation` API for shared memory regions"><title>arrow::alloc - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../help.html" title="help">?</a></div><div id [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Defines the low-level `Allocation` API for shared memory regions"><title>arrow::alloc - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../help.html" title="help">?</a></div><div id [...]
 </div></details><h2 id="constants" class="section-header">Constants<a href="#constants" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="constant" href="constant.ALIGNMENT.html" title="constant arrow::alloc::ALIGNMENT">ALIGNMENT</a></div><div class="desc docblock-short">Cache and allocation multiple alignment size</div></li></ul><h2 id="traits" class="section-header">Traits<a href="#traits" class="anchor">§</a></h2><ul class="item-table"><li><div class [...]
 The trait implementation is responsible for dropping the allocations once no more references exist.</div></li></ul></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/alloc/trait.Allocation.html b/arrow/alloc/trait.Allocation.html
index 7d8796bf86a..6469f0ab31c 100644
--- a/arrow/alloc/trait.Allocation.html
+++ b/arrow/alloc/trait.Allocation.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The owner of an allocation. The trait implementation is responsible for dropping the allocations once no more references exist."><title>Allocation in arrow::alloc - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98 [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../help.html" title="help">?</a></div><div id [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The owner of an allocation. The trait implementation is responsible for dropping the allocations once no more references exist."><title>Allocation in arrow::alloc - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98 [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../help.html" title="help">?</a></div><div id [...]
 The trait implementation is responsible for dropping the allocations once no more references exist.</p>
-</div></details><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.Allocation.html" title="trait arrow::alloc::Allocation">Allocation</a> for T<div class= [...]
+</div></details><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.Allocation.html" title="trait arrow::alloc::Allocation">Allocation</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section></div><script src="../../t [...]
\ No newline at end of file
diff --git a/arrow/array/array/fn.make_array.html b/arrow/array/array/fn.make_array.html
index 6944d8ea1e0..034e0ac8fed 100644
--- a/arrow/array/array/fn.make_array.html
+++ b/arrow/array/array/fn.make_array.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Constructs an array using the input `data`. Returns a reference-counted `Array` instance."><title>make_array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Constructs an array using the input `data`. Returns a reference-counted `Array` instance."><title>make_array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 Returns a reference-counted <code>Array</code> instance.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/fn.new_empty_array.html b/arrow/array/array/fn.new_empty_array.html
index ca1a0790ede..e98c2a0ae8a 100644
--- a/arrow/array/array/fn.new_empty_array.html
+++ b/arrow/array/array/fn.new_empty_array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Creates a new empty array"><title>new_empty_array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Creates a new empty array"><title>new_empty_array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>std::sync::Arc;
 <span class="kw">use </span>arrow_schema::DataType;
diff --git a/arrow/array/array/fn.new_null_array.html b/arrow/array/array/fn.new_null_array.html
index 7f0b3b00f30..eda6c29e1eb 100644
--- a/arrow/array/array/fn.new_null_array.html
+++ b/arrow/array/array/fn.new_null_array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Creates a new array of `data_type` of length `length` filled entirely of `NULL` values"><title>new_null_array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><lin [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Creates a new array of `data_type` of length `length` filled entirely of `NULL` values"><title>new_null_array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><lin [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 entirely of <code>NULL</code> values</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>std::sync::Arc;
diff --git a/arrow/array/array/index.html b/arrow/array/array/index.html
index 5e378a0c386..09a25dbe8dc 100644
--- a/arrow/array/array/index.html
+++ b/arrow/array/array/index.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The concrete array definitions"><title>arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../sta [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The concrete array definitions"><title>arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../sta [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="structs" class="section-header">Structs<a href="#structs" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="struct" href="struct.BooleanArray.html" title="struct arrow::array::array::BooleanArray">BooleanArray</a></div><div class="desc docblock-short">An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#fixed-size-primitive-layout">boolean values</a></div></li><li><div class="item-name"><a class="struct" href=" [...]
 (e.g. <code>[&quot;A&quot;, &quot;B&quot;]</code>).</div></li><li><div class="item-name"><a class="struct" href="struct.GenericByteArray.html" title="struct arrow::array::array::GenericByteArray">GenericByteArray</a></div><div class="desc docblock-short">An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#variable-size-binary-layout">variable length byte arrays</a></div></li><li><div class="item-name"><a class="struct" href="struct.GenericListArray.html" title="struct [...]
 (e.g. <code>[&quot;A&quot;, &quot;B&quot;, &quot;C&quot;]</code>).</div></li><li><div class="item-name"><a class="struct" href="struct.MapArray.html" title="struct arrow::array::array::MapArray">MapArray</a></div><div class="desc docblock-short">An array of key-value maps</div></li><li><div class="item-name"><a class="struct" href="struct.NativeAdapter.html" title="struct arrow::array::array::NativeAdapter">NativeAdapter</a></div><div class="desc docblock-short">An optional primitive val [...]
diff --git a/arrow/array/array/struct.BooleanArray.html b/arrow/array/array/struct.BooleanArray.html
index e7409fddca3..abe158ad4ad 100644
--- a/arrow/array/array/struct.BooleanArray.html
+++ b/arrow/array/array/struct.BooleanArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of boolean values"><title>BooleanArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of boolean values"><title>BooleanArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     values: <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#fixed-size-primitive-layout">boolean values</a></p>
@@ -19,35 +19,35 @@ builder.append_value(<span class="bool-val">false</span>);
 <span class="kw">let </span>array = builder.finish();
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = array.iter().collect();
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>values, <span class="kw-2">&amp;</span>[<span class="prelude-val">Some</span>(<span class="bool-val">true</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="bool-val">false</span>)])</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="anchor field">§</a><code>values: <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></code></span><span id="structfield.nulls" class="structfield section-header"><a href="#structfield.nulls" class="anchor  [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="anchor field">§</a><code>values: <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></code></span><span id="structfield.nulls" class="structfield section-header"><a href="#structfield.nulls" class="anchor  [...]
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <code>values.len() != nulls.len()</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#97">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanAr [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_scalar" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#105">source</a><h4 class="code-header">pub fn <a href="#method.new_scalar" class="fn">new_scalar</a>(value: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>) -&gt; <a class="struct" href="../struct.Scalar.html" title="struct arrow::array::Scalar"> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#114">source</a><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of this array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#119">source</a><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether this array is empty.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#124">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.h [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.builder" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#132">source</a><h4 class="code-header">pub fn <a href="#method.builder" class="fn">builder</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../builder/struct.BooleanBuilder.html" title="struct arrow::arr [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#137">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Returns [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.true_count" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#142">source</a><h4 class="code-header">pub fn <a href="#method.true_count" class="fn">true_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of non nul [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.false_count" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.false_count" class="fn">false_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of non  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#165">source</a><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h4></section></summary><div class="docblock"><p>Create a new <a href="../st [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_scalar" class="method"><h4 class="code-header">pub fn <a href="#method.new_scalar" class="fn">new_scalar</a>(value: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>) -&gt; <a class="struct" href="../struct.Scalar.html" title="struct arrow::array::Scalar">Scalar</a>&lt;<a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::Bool [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of this array.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether this array is empty.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::arr [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.builder" class="method"><h4 class="code-header">pub fn <a href="#method.builder" class="fn">builder</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../builder/struct.BooleanBuilder.html" title="struct arrow::array::builder::BooleanBuilder">BooleanBuilder</a></h4></section></summary><div class="docblock"><p>Re [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Returns the underlying <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::Boole [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.true_count" class="method"><h4 class="code-header">pub fn <a href="#method.true_count" class="fn">true_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of non null, true values within this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.false_count" class="method"><h4 class="code-header">pub fn <a href="#method.false_count" class="fn">false_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of non null, false values within this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns [...]
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>This doesn’t check bounds, the caller must ensure that index &lt; self.len()</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#172">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">boo [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns the boolean value at index <code>i</ [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if index <code>i</code> is out of bounds</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#185-188">source</a><h4 class="code-header">pub fn <a href="#method.take_iter" class="fn">take_iter</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter" class="method"><h4 class="code-header">pub fn <a href="#method.take_iter" class="fn">take_iter</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Returns  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#196-199">source</a><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Returns  [...]
 <h5 id="safety-1"><a class="doc-anchor" href="#safety-1">§</a>Safety</h5>
 <p>caller must ensure that the offsets in the iterator are less than the array len()</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_unary" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#213-215">source</a><h4 class="code-header">pub fn <a href="#method.from_unary" class="fn">from_unary</a>&lt;T, F&gt;(left: T, op: F) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a><div class="where">where
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_unary" class="method"><h4 class="code-header">pub fn <a href="#method.from_unary" class="fn">from_unary</a>&lt;T, F&gt;(left: T, op: F) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a><div class="where">where
     T: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(&lt;T as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primit [...]
 each element of the provided array</p>
@@ -56,7 +56,7 @@ each element of the provided array</p>
 <span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);
 <span class="kw">let </span>r = BooleanArray::from_unary(<span class="kw-2">&amp;</span>array, |x| x &gt; <span class="number">2</span>);
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>r, <span class="kw-2">&amp;</span>BooleanArray::from(<span class="macro">vec!</span>[<span class="bool-val">false</span>, <span class="bool-val">false</span>, <span class="bool-val">true</span>, <span class="bool-val">true</span>, <span class="bool-val">true</span>]));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_binary" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#241-243">source</a><h4 class="code-header">pub fn <a href="#method.from_binary" class="fn">from_binary</a>&lt;T, S, F&gt;(left: T, right: S, op: F) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a><div class="where">where
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_binary" class="method"><h4 class="code-header">pub fn <a href="#method.from_binary" class="fn">from_binary</a>&lt;T, S, F&gt;(left: T, right: S, op: F) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a><div class="where">where
     T: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
     S: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(&lt;T as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>, &lt;S as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arr [...]
@@ -69,37 +69,37 @@ each element of the provided arrays</p>
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>r, <span class="kw-2">&amp;</span>BooleanArray::from(<span class="macro">vec!</span>[<span class="bool-val">true</span>, <span class="bool-val">true</span>, <span class="bool-val">false</span>, <span class="bool-val">false</span>, <span class="bool-val">true</span>]));</code></pre></div>
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>This function panics if left and right are not the same length</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#259">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>, <a class="enum" href="https://doc.rust-lang.org/nigh [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BooleanArray-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#396">source</a><a href="#impl-BooleanArray-1" class="anchor">§</a><h3 class="code-header">impl&lt;'a&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h3></section></summary><div class="impl-items"><detai [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-BooleanArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#264">source</a><a href="#impl-Array-for-BooleanArray" class="anchor">§</a><h3 class="co [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#269">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class=" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>, <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BooleanArray-1" class="impl"><a href="#impl-BooleanArray-1" class="anchor">§</a><h3 class="code-header">impl&lt;'a&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="c [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-BooleanArray" class="impl"><a href="#impl-Array-for-BooleanArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#297">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="http [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#309">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a href="../t [...]
-    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/borrow/trait.Borrow.html" title="trait core::borrow::Borrow">Borrow</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><s [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = Ptr&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter">Read more</a></div></details></div></details><details class="toggle implementors-toggle" [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a href="../t [...]
+    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/borrow/trait.Borrow.html" title="trait core::borrow::Borrow">Borrow</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><s [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = Ptr&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter">Read more</a></div></details></div></details><details class="toggle implementors-toggle" [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-BooleanArray" class="impl"><a href="#impl-RefUnwindSafe-for-BooleanArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-la [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"ArrayIter<&'a BooleanArray>":"<h3>Notable traits for <code><a class=\"struct\" href=\"../iterator/struct.ArrayIter.html\" title=\"struct arrow::array::iterator::ArrayIter\">ArrayIter</a>&lt;T&gt;</code></h3><pre><code><div class=\"where\">impl&lt;T&gt; <a class=\"trait\" href=\ [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.DictionaryArray.html b/arrow/array/array/struct.DictionaryArray.html
index fd2525d15b0..7dcf7b03b1f 100644
--- a/arrow/array/array/struct.DictionaryArray.html
+++ b/arrow/array/array/struct.DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of dictionary encoded values"><title>DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of dictionary encoded values"><title>DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div>{
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     keys: <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;,
@@ -58,8 +58,8 @@ builder.append_value(<span class="string">"b"</span>);
 
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = array.downcast_dict::&lt;StringArray&gt;().unwrap().into_iter().collect();
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>values, <span class="kw-2">&amp;</span>[<span class="prelude-val">Some</span>(<span class="string">"a"</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="string">"a"</span>), <span class="prelude-val">Some</span>(<span class="string">"b"</span>)]);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.keys" class="structfield section-header"><a href="#structfield.keys" class="anchor field">§ [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#278">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.keys" class="structfield section-header"><a href="#structfield.keys" class="anchor field">§ [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
     keys: <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;
 ) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Attempt to create a new DictionaryArray with a specified keys
@@ -67,7 +67,7 @@ builder.append_value(<span class="string">"b"</span>);
 array.</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.DictionaryArray.html#method.try_new" title="associated function arrow::array::DictionaryArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#289">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     keys: <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Attempt to create a new DictionaryArray with a specified keys
@@ -75,31 +75,31 @@ array.</p>
 array.</p>
 <h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <p>Returns an error if any <code>keys[i] &gt;= values.len() || keys[i] &lt; 0</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#321">source</a><h4 class="code-header">pub unsafe fn <a href="#method.new_unchecked" class="fn">new_unchecked</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.new_unchecked" class="fn">new_unchecked</a>(
     keys: <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;
 ) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> without performing validation</p>
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>Safe provided <a href="../struct.DictionaryArray.html#method.try_new" title="associated function arrow::array::DictionaryArray::try_new"><code>Self::try_new</code></a> would not return an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#336">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;, <a class="struct" href="https://doc.rust-lang.or [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#341">source</a><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Return an [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.lookup_key" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#350">source</a><h4 class="code-header">pub fn <a href="#method.lookup_key" class="fn">lookup_key</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Return an array view of the keys of this dictionary as a PrimitiveArray.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.lookup_key" class="method"><h4 class="code-header">pub fn <a href="#method.lookup_key" class="fn">lookup_key</a>(
     &amp;self,
     value: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;K as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;</h4></section></su [...]
 returns the corresponding key (index into the <code>values</code>
 array). Otherwise returns <code>None</code>.</p>
 <p>Panics if <code>values</code> is not a <a href="../type.StringArray.html" title="type arrow::array::StringArray"><code>StringArray</code></a>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#359">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" ti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#364">source</a><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a cl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#369">source</a><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>The length of the dictionary is the length of t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#374">source</a><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Whether this dictionary is empty</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ordered" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#379">source</a><h4 class="code-header">pub fn <a href="#method.is_ordered" class="fn">is_ordered</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Currently exists for compati [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.keys_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#384">source</a><h4 class="code-header">pub fn <a href="#method.keys_iter" class="fn">keys_iter</a>(&amp;self) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>& [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.key" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#390">source</a><h4 class="code-header">pub fn <a href="#method.key" class="fn">key</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a clone of the value type of this list.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>The length of the dictionary is the length of the keys array.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Whether this dictionary is empty</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ordered" class="method"><h4 class="code-header">pub fn <a href="#method.is_ordered" class="fn">is_ordered</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Currently exists for compatibility purposes with Arrow IPC.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.keys_iter" class="method"><h4 class="code-header">pub fn <a href="#method.keys_iter" class="fn">keys_iter</a>(&amp;self) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.key" class="method"><h4 class="code-header">pub fn <a href="#method.key" class="fn">key</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly [...]
 cast to <code>usize</code>, <code>None</code> if the value at <code>i</code> is <code>NULL</code>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#395">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usiz [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.downcast_dict" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#417">source</a><h4 class="code-header">pub fn <a href="#method.downcast_dict" class="fn">downcast_dict</a>&lt;V&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" hr [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow:: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.downcast_dict" class="method"><h4 class="code-header">pub fn <a href="#method.downcast_dict" class="fn">downcast_dict</a>&lt;V&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictio [...]
     V: 'static,</div></h4></section></summary><div class="docblock"><p>Downcast this dictionary to a <a href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray"><code>TypedDictionaryArray</code></a></p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, ArrayAccessor, DictionaryArray, StringArray, types::Int32Type};
@@ -110,7 +110,7 @@ cast to <code>usize</code>, <code>None</code> if the value at <code>i</code> is
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">0</span>), <span class="string">"a"</span>);
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">1</span>), <span class="string">"b"</span>);
 <span class="macro">assert!</span>(typed.is_null(<span class="number">2</span>));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#462">source</a><h4 class="code-header">pub fn <a href="#method.with_values" class="fn">with_values</a>(&amp;self, values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Ar [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_values" class="method"><h4 class="code-header">pub fn <a href="#method.with_values" class="fn">with_values</a>(&amp;self, values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;) -&gt; <a class="struct" href="../struct.Dic [...]
 but with a different set of dictionary values</p>
 <p>This can be used to perform an operation on the values of a dictionary</p>
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
@@ -137,12 +137,12 @@ but with a different set of dictionary values</p>
 <span class="kw">for </span>i <span class="kw">in </span><span class="number">0</span>..<span class="number">100 </span>{
     <span class="macro">assert_eq!</span>(new_typed.value(i), (i % <span class="number">2</span>) <span class="kw">as </span>i64)
 }</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_primitive_dict_builder" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#476-478">source</a><h4 class="code-header">pub fn <a href="#method.into_primitive_dict_builder" class="fn">into_primitive_dict_builder</a>&lt;V&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_primitive_dict_builder" class="method"><h4 class="code-header">pub fn <a href="#method.into_primitive_dict_builder" class="fn">into_primitive_dict_builder</a>&lt;V&gt;(
     self
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../builder/struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::builder::PrimitiveDictionaryBuilder">PrimitiveDictionaryBuilder</a>&lt;K, V&gt;, <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;&gt;<div class="where">where
     V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class="docblock"><p>Returns <code>PrimitiveDictionaryBuilder</code> of this dictionary array for mutating
 its keys and values if the underlying data buffer is not shared by others.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.unary_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#532-535">source</a><h4 class="code-header">pub fn <a href="#method.unary_mut" class="fn">unary_mut</a>&lt;F, V&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.unary_mut" class="method"><h4 class="code-header">pub fn <a href="#method.unary_mut" class="fn">unary_mut</a>&lt;F, V&gt;(
     self,
     op: F
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;, <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;&gt;<div class="where">where
@@ -163,28 +163,28 @@ or this function may panic.</p>
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">0</span>), <span class="number">11</span>);
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">1</span>), <span class="number">11</span>);
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">2</span>), <span class="number">21</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.occupancy" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#549">source</a><h4 class="code-header">pub fn <a href="#method.occupancy" class="fn">occupancy</a>(&amp;self) -&gt; <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p> [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.occupancy" class="method"><h4 class="code-header">pub fn <a href="#method.occupancy" class="fn">occupancy</a>(&amp;self) -&gt; <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Computes an occupancy mask for this dictionary’s values</p>
 <p>For each value in <a href="../struct.DictionaryArray.html#method.values" title="method arrow::array::DictionaryArray::values"><code>Self::values</code></a> the corresponding bit will be set in the
 returned mask if it is referenced by a key in this <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a></p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#986">source</a><a href="#impl-AnyDictionaryArray-for-Dictiona [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.keys-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#987">source</a><a href="#method.keys-1" class="anchor">§</a><h4 class="code-heade [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#687">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-heade [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#691">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a clas [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="impl"><a href="#impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K&gt; <a class="trait" href="../tr [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.keys-1" class="method trait-impl"><a href="#method.keys-1" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.AnyDictionaryArray.html#tymethod.keys" class="fn">keys</a>(&amp;self) -&gt; &a [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn < [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#719">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="h [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#752">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(& [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#220">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href=" [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#260">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header" [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#760">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn  [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="pr [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn"> [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>( [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an array data reference.</p>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#571">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="../struct.ArrayData.html" title="struct arrow::ar [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#619">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-heade [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="st [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of strings.</p>
-<h4 id="example-1"><a class="doc-anchor" href="#example-1">§</a>Example:</h4>
+<h4 id="example-2"><a class="doc-anchor" href="#example-2">§</a>Example:</h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{DictionaryArray, PrimitiveArray, StringArray, types::Int8Type};
 
 <span class="kw">let </span>test = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>];
@@ -193,10 +193,10 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  1,\n  2,\n] values: StringArray\n[\n  \"a\",\n  \"b\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#672">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struc [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.fr [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryAr [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.fr [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of optional strings.</p>
-<h4 id="example-2"><a class="doc-anchor" href="#example-2">§</a>Example:</h4>
+<h4 id="example-1"><a class="doc-anchor" href="#example-1">§</a>Example:</h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{DictionaryArray, PrimitiveArray, StringArray, types::Int8Type};
 
 <span class="kw">let </span>test = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>];
@@ -208,23 +208,23 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  null,\n  1,\n] values: StringArray\n[\n  \"a\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#648">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="s [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#470">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https: [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray< [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymethod.eq" class="fn">eq</a>( [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-DictionaryArray%3CK%3E" class="impl"><a href="#impl-RefUnwindSafe-for-DictionaryArray%3CK%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K&gt; !<a class="tr [...]
     &lt;K as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><sectio [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.FixedSizeBinaryArray.html b/arrow/array/array/struct.FixedSizeBinaryArray.html
index b471319528b..acf130e2507 100644
--- a/arrow/array/array/struct.FixedSizeBinaryArray.html
+++ b/arrow/array/array/struct.FixedSizeBinaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of fixed size binary arrays"><title>FixedSizeBinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of fixed size binary arrays"><title>FixedSizeBinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     value_data: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -23,14 +23,14 @@ Sparsity means that the input argument can contain <code>None</code> items.</p>
    <span class="kw">let </span>arr = FixedSizeBinaryArray::try_from_sparse_iter_with_size(input_arg.into_iter(), <span class="number">2</span>).unwrap();
    <span class="macro">assert_eq!</span>(<span class="number">5</span>, arr.len())
 </code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.value_data" class="structfield section-header"><a href="#structfield.value_data" class="anc [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.value_data" class="structfield section-header"><a href="#structfield.value_data" class="anc [...]
     size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
     values: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a></h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray"><code>FixedSizeBinaryArray</code></a> with <code>size</code> element size, panicking on failure</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.FixedSizeBinaryArray.html#method.try_new" title="associated function arrow::array::FixedSizeBinaryArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#77-81">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
     values: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
@@ -40,30 +40,30 @@ Sparsity means that the input argument can contain <code>None</code> items.</p>
 <li><code>size &lt; 0</code></li>
 <li><code>values.len() / size != nulls.len()</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#115">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.ht [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array: [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if</p>
 <ul>
 <li><code>size &lt; 0</code></li>
 <li><code>size * len</code> would overflow <code>usize</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#127">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>, <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arro [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#134">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitiv [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>, <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>, <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Optio [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div [...]
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>Panics if index <code>i</code> is out of bounds.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#154">source</a><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;[<a class="primitive" href="https://d [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8 [...]
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>Caller is responsible for ensuring that the index is within the bounds of the array</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offset" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#167">source</a><h4 class="code-header">pub fn <a href="#method.value_offset" class="fn">value_offset</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/night [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offset" class="method"><h4 class="code-header">pub fn <a href="#method.value_offset" class="fn">value_offset</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the offset for th [...]
 <p>Note this doesn’t do any bound checking, for performance reason.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#175">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the lengt [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the length for an element.</p>
 <p>All elements have the same length as the array is a fixed size.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#184">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the values [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the values of this array.</p>
 <p>Unlike <a href="../struct.FixedSizeBinaryArray.html#method.value_data" title="method arrow::array::FixedSizeBinaryArray::value_data"><code>Self::value_data</code></a> this returns the <a href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer"><code>Buffer</code></a>
 allowing for zero-copy cloning.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_data" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#189">source</a><h4 class="code-header">pub fn <a href="#method.value_data" class="fn">value_data</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#194">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_sparse_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#236-239">source</a><h4 class="code-header">pub fn <a href="#method.try_from_sparse_iter" class="fn">try_from_sparse_iter</a>&lt;T, U&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_data" class="method"><h4 class="code-header">pub fn <a href="#method.value_data" class="fn">value_data</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div class="docblock"><p>Returns the raw value data.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_sparse_iter" class="method"><h4 class="code-header">pub fn <a href="#method.try_from_sparse_iter" class="fn">try_from_sparse_iter</a>&lt;T, U&gt;(
     iter: T
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;U&gt;&gt;,
@@ -83,7 +83,7 @@ contain <code>None</code> items.</p>
 <span class="kw">let </span>array = FixedSizeBinaryArray::try_from_sparse_iter(input_arg.into_iter()).unwrap();</code></pre></div>
 <h5 id="errors-1"><a class="doc-anchor" href="#errors-1">§</a>Errors</h5>
 <p>Returns error if argument has length zero, or sizes of nested slices don’t match.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_sparse_iter_with_size" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#333-336">source</a><h4 class="code-header">pub fn <a href="#method.try_from_sparse_iter_with_size" class="fn">try_from_sparse_iter_with_size</a>&lt;T, U&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_sparse_iter_with_size" class="method"><h4 class="code-header">pub fn <a href="#method.try_from_sparse_iter_with_size" class="fn">try_from_sparse_iter_with_size</a>&lt;T, U&gt;(
     iter: T,
     size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;<div class="where">where
@@ -106,7 +106,7 @@ created.</p>
 <span class="kw">let </span>array = FixedSizeBinaryArray::try_from_sparse_iter_with_size(input_arg.into_iter(), <span class="number">2</span>).unwrap();</code></pre></div>
 <h5 id="errors-2"><a class="doc-anchor" href="#errors-2">§</a>Errors</h5>
 <p>Returns error if argument has length zero, or sizes of nested slices don’t match.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#403-406">source</a><h4 class="code-header">pub fn <a href="#method.try_from_iter" class="fn">try_from_iter</a>&lt;T, U&gt;(iter: T) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_iter" class="method"><h4 class="code-header">pub fn <a href="#method.try_from_iter" class="fn">try_from_iter</a>&lt;T, U&gt;(iter: T) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeB [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = U&gt;,
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;,</div></h4></section></summary><div class="docblock"><p>Create an array from an iterable argument of byte slices.</p>
 <h5 id="examples-3"><a class="doc-anchor" href="#examples-3">§</a>Examples</h5>
@@ -119,38 +119,38 @@ created.</p>
 <span class="kw">let </span>array = FixedSizeBinaryArray::try_from_iter(input_arg.into_iter()).unwrap();</code></pre></div>
 <h5 id="errors-3"><a class="doc-anchor" href="#errors-3">§</a>Errors</h5>
 <p>Returns error if argument has length zero, or sizes of nested slices don’t match.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#458">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.FixedSizeBinaryArra [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-FixedSizeBinaryArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#564">source</a><a href="#impl-Array-for-FixedSizeBinaryArray" class=" [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#569">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt;  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a>&gt; <a href="#" class="too [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-FixedSizeBinaryArray" class="impl"><a href="#impl-Array-for-FixedSizeBinaryArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::arr [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#597">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum"  [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#609">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_siz [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <cod [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <cod [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <cod [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#502">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href="../struct.FixedSizeListArray.html" title= [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <cod [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a>) -&gt; <a class="struct" href="../struct.FixedSi [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-FixedSizeBinaryArray" class="impl"><a href="#impl-RefUnwindSafe-for-FixedSizeBinaryArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="htt [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"&[u8]":"<h3>Notable traits for <code>&amp;[<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u8.html\">u8</a>]</code></h3><pre><code><div class=\"where\">impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Read.html\" title= [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.FixedSizeListArray.html b/arrow/array/array/struct.FixedSizeListArray.html
index c6f6b4544dd..5f24f0eefe8 100644
--- a/arrow/array/array/struct.FixedSizeListArray.html
+++ b/arrow/array/array/struct.FixedSizeListArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of [fixed length lists], similar to JSON arrays (e.g. `[&quot;A&quot;, &quot;B&quot;]`)."><title>FixedSizeListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295. [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of [fixed length lists], similar to JSON arrays (e.g. `[&quot;A&quot;, &quot;B&quot;]`)."><title>FixedSizeListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295. [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -72,7 +72,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
 <span class="macro">assert_eq!</span>( <span class="kw-2">&amp;</span>[<span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>], list1.as_any().downcast_ref::&lt;Int32Array&gt;().unwrap().values());
 <span class="macro">assert_eq!</span>( <span class="kw-2">&amp;</span>[<span class="number">6</span>, <span class="number">7</span>, <span class="number">8</span>], list2.as_any().downcast_ref::&lt;Int32Array&gt;().unwrap().values());</code></pre></div>
 <p><a href="https://arrow.apache.org/docs/format/Columnar.html#fixed-size-list-layout">fixed size arrays</a></p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="anchor fiel [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="anchor fiel [...]
     field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;,
     size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;,
@@ -80,7 +80,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
 ) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a></h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a> with <code>size</code> element size, panicking on failure</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.FixedSizeListArray.html#method.try_new" title="associated function arrow::array::FixedSizeListArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#145-150">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;,
     size: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;,
@@ -93,23 +93,23 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
 <li><code>values.data_type() != field.data_type()</code></li>
 <li><code>!field.is_nullable() &amp;&amp; !nulls.expand(size).contains(values.logical_nulls())</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#208">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.h [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;, size: <a class="primitive" href="https://doc.rus [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if</p>
 <ul>
 <li><code>size &lt; 0</code></li>
 <li><code>size * len</code> would overflow <code>usize</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#220">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/st [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#229">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.htm [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#234">source</a><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#239">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.h [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offset" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#248">source</a><h4 class="code-header">pub fn <a href="#method.value_offset" class="fn">value_offset</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;, <a class="primitive" href="https://d [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a clone of the value type of this list.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trai [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offset" class="method"><h4 class="code-header">pub fn <a href="#method.value_offset" class="fn">value_offset</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the offset for va [...]
 <p>Note this doesn’t do any bound checking, for performance reason.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#256">source</a><h4 class="code-header">pub const fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the l [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><h4 class="code-header">pub const fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the length for an element.</p>
 <p>All elements have the same length as the array is a fixed size.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#266">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.us [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_primitive" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#297-301">source</a><h4 class="code-header">pub fn <a href="#method.from_iter_primitive" class="fn">from_iter_primitive</a>&lt;T, P, I&gt;(iter: I, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>) -&gt; <a class="struct" hre [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow:: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_primitive" class="method"><h4 class="code-header">pub fn <a href="#method.from_iter_primitive" class="fn">from_iter_primitive</a>&lt;T, P, I&gt;(iter: I, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a><di [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     P: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a  [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;P&gt;&gt;,</div></h4></section></summary><div class="docblock"><p>Creates a <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeList [...]
@@ -123,38 +123,38 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
 ];
 <span class="kw">let </span>list_array = FixedSizeListArray::from_iter_primitive::&lt;Int32Type, <span class="kw">_</span>, <span class="kw">_</span>&gt;(data, <span class="number">3</span>);
 <span class="macro">println!</span>(<span class="string">"{:?}"</span>, list_array);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#330">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.FixedSizeListArray.ht [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-FixedSizeListArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#368">source</a><a href="#impl-Array-for-FixedSizeListArray" class="anchor [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#373">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a>&gt; <a href="#" class="tooltip"  [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-FixedSizeListArray" class="impl"><a href="#impl-Array-for-FixedSizeListArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::array:: [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#401">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" hr [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#413">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size< [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</c [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</c [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;<a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a  [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#502">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href="../struct.FixedSizeListArray.html" title= [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
+) -&gt; &lt;<a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a  [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a>) -&gt; <a class="struct" href="../struct.Fix [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(value: <a class="struc [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-FixedSizeListArray" class="impl"><a href="#impl-RefUnwindSafe-for-FixedSizeListArray" class="anchor">§</a><h3 class="code-header">impl !<a class="trait" href="https: [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"ArrayIter<&FixedSizeListArray>":"<h3>Notable traits for <code><a class=\"struct\" href=\"../iterator/struct.ArrayIter.html\" title=\"struct arrow::array::iterator::ArrayIter\">ArrayIter</a>&lt;T&gt;</code></h3><pre><code><div class=\"where\">impl&lt;T&gt; <a class=\"trait\" hre [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.GenericByteArray.html b/arrow/array/array/struct.GenericByteArray.html
index 1ba7b556765..5f989fe4a98 100644
--- a/arrow/array/array/struct.GenericByteArray.html
+++ b/arrow/array/array/struct.GenericByteArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of variable length byte arrays"><title>GenericByteArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" c [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of variable length byte arrays"><title>GenericByteArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" c [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div>{
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     value_offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
@@ -32,35 +32,35 @@ builder.append_value(<span class="string">"world"</span>);
 <span class="kw">let </span>array = builder.finish();
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = array.iter().collect();
 <span class="macro">assert_eq!</span>(values, <span class="kw-2">&amp;</span>[<span class="prelude-val">Some</span>(<span class="string">"hello"</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="string">"world"</span>)]);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.value_offsets" class="structfield section-header"><a href="#structfield.value_offsets" clas [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get_data_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#29">source</a><h4 class="code-header">pub const fn <a href="#method.get_data_type" class="fn">get_data_type</a>() -&gt [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_vec" class="method"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#36">source</a><h4 class="code-header">pub fn <a href="#method.from_vec" class="fn">from_vec</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.value_offsets" class="structfield section-header"><a href="#structfield.value_offsets" clas [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get_data_type" class="method"><h4 class="code-header">pub const fn <a href="#method.get_data_type" class="fn">get_data_type</a>() -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataTyp [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_vec" class="method"><h4 class="code-header">pub fn <a href="#method.from_vec" class="fn">from_vec</a>(
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;
 ) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class="docblock"><p>Creates a <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray">GenericBinaryArray</a> from a vector of byte [...]
 <p>See also <a href="../struct.GenericByteArray.html#method.from_iter_values" title="associated function arrow::array::GenericByteArray::from_iter_values"><code>Self::from_iter_values</code></a></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_opt_vec" class="method"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#41">source</a><h4 class="code-header">pub fn <a href="#method.from_opt_vec" class="fn">from_opt_vec</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_opt_vec" class="method"><h4 class="code-header">pub fn <a href="#method.from_opt_vec" class="fn">from_opt_vec</a>(
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;&gt;
 ) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class="docblock"><p>Creates a <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray">GenericBinaryArray</a> from a vector of Opti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#84-87">source</a><h4 class="code-header">pub fn <a href="#method.take_iter" class="fn">take_iter</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter" class="method"><h4 class="code-header">pub fn <a href="#method.take_iter" class="fn">take_iter</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Re [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#95-98">source</a><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Re [...]
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>caller must ensure that the indexes in the iterator are less than the <code>array.len()</code></p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#105">source</a><a href="#impl-GenericByteArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;<div class="where">where
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedconstant.DATA_TYPE" class="associatedconstant"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#107">source</a><h4 class="code-header">pub const <a href="#associatedconstant.DATA_TYPE" class="constant">DATA_T [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#114-118">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteArray%3CT%3E" class="impl"><a href="#impl-GenericByteArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;<div class="where">where
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedconstant.DATA_TYPE" class="associatedconstant"><h4 class="code-header">pub const <a href="#associatedconstant.DATA_TYPE" class="constant">DATA_TYPE</a>: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
     values: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> from the provided parts, panicking on failure</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.GenericByteArray.html#method.try_new" title="associated function arrow::array::GenericByteArray::try_new"><code>GenericByteArray::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#128-132">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
     values: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
@@ -70,136 +70,136 @@ builder.append_value(<span class="string">"world"</span>);
 <li><code>offsets.len() - 1 != nulls.len()</code></li>
 <li>Any consecutive pair of <code>offsets</code> does not denote a valid slice of <code>values</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#162-166">source</a><h4 class="code-header">pub unsafe fn <a href="#method.new_unchecked" class="fn">new_unchecked</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.new_unchecked" class="fn">new_unchecked</a>(
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
     values: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> from the provided parts, without validation</p>
 <h5 id="safety-1"><a class="doc-anchor" href="#safety-1">§</a>Safety</h5>
 <p>Safe if <a href="../struct.GenericByteArray.html#method.try_new" title="associated function arrow::array::GenericByteArray::try_new"><code>Self::try_new</code></a> would not error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#176">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::Generic [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_scalar" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#186">source</a><h4 class="code-header">pub fn <a href="#method.new_scalar" class="fn">new_scalar</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Create [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_scalar" class="method"><h4 class="code-header">pub fn <a href="#method.new_scalar" class="fn">new_scalar</a>(
     value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;
 ) -&gt; <a class="struct" href="../struct.Scalar.html" title="struct arrow::array::Scalar">Scalar</a>&lt;<a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.Scalar.html" title="struct arrow::array::Scalar"><code>Scalar</code></a> from <code>v</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#191-194">source</a><h4 class="code-header">pub fn <a href="#method.from_iter_values" class="fn">from_iter_values</a>&lt;Ptr, I&gt;(iter: I) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;<div class=" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_values" class="method"><h4 class="code-header">pub fn <a href="#method.from_iter_values" class="fn">from_iter_values</a>&lt;Ptr, I&gt;(iter: I) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;<div class="where">where
     Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = Ptr&gt;,</div></h4></section></summary><div class="docblock"><p>Creates a <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> based on an iterator of values without nulls</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#225">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
     self
 ) -&gt; (<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;, <a class="struct" href="../../buffer/struct.Buffe [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#233">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.htm [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if index <code>i</code> is out of bounds.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#243">source</a><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.By [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class= [...]
 <p>Unlike <a href="../struct.GenericByteArray.html#method.value_offsets" title="method arrow::array::GenericByteArray::value_offsets"><code>Self::value_offsets</code></a> this returns the <a href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer"><code>OffsetBuffer</code></a>
 allowing for zero-copy cloning</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#252">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the values of this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the values of this array</p>
 <p>Unlike <a href="../struct.GenericByteArray.html#method.value_data" title="method arrow::array::GenericByteArray::value_data"><code>Self::value_data</code></a> this returns the <a href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer"><code>Buffer</code></a>
 allowing for zero-copy cloning</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_data" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#257">source</a><h4 class="code-header">pub fn <a href="#method.value_data" class="fn">value_data</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></su [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#262">source</a><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns true if all data within this arr [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#271">source</a><h4 class="code-header">pub fn <a href="#method.value_offsets" class="fn">value_offsets</a>(&amp;self) -&gt; &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associated [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#278">source</a><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;&lt;T as <a class="trait" href="../../datatypes/tr [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_data" class="method"><h4 class="code-header">pub fn <a href="#method.value_data" class="fn">value_data</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div class="docblock"><p>Returns the raw value data</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns true if all data within this array is ASCII</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offsets" class="method"><h4 class="code-header">pub fn <a href="#method.value_offsets" class="fn">value_offsets</a>(&amp;self) -&gt; &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::d [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a  [...]
 <h5 id="safety-2"><a class="doc-anchor" href="#safety-2">§</a>Safety</h5>
 <p>Caller is responsible for ensuring that the index is within the bounds of the array</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#304">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../da [...]
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>Panics if index <code>i</code> is out of bounds.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#319">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.GenericByteArray.html" title="st [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#324">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_builder" class="method"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#335">source</a><h4 class="code-header">pub fn <a href="#method.into_builder" class="fn">into_builder</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../builder/struct.G [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;&gt; <a href="#" class="toolti [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_builder" class="method"><h4 class="code-header">pub fn <a href="#method.into_builder" class="fn">into_builder</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../builder/struct.GenericByteBuilder.html" title="struct arrow::array::builder::GenericByteBuilder">GenericByteBuil [...]
 offset and data buffers are not shared by others.</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#25">source</a><a href="#impl-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow:: [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get_data_type-1" class="method"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#28">source</a><h4 class="code-header">pub const fn <a href="#method.get_data_type-1" class="fn">get_data_type</a>()  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.num_chars" class="method"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#37">source</a><h4 class="code-header">pub fn <a href="#method.num_chars" class="fn">num_chars</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usiz [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="impl"><a href="#impl-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.G [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get_data_type-1" class="method"><h4 class="code-header">pub const fn <a href="#method.get_data_type-1" class="fn">get_data_type</a>() -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::Dat [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.num_chars" class="method"><h4 class="code-header">pub fn <a href="#method.num_chars" class="fn">num_chars</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of <code>Un [...]
 <h5 id="performance"><a class="doc-anchor" href="#performance">§</a>Performance</h5>
 <p>This function has <code>O(n)</code> time complexity where <code>n</code> is the string length.
 If you can make sure that all chars in the string are in the range <code>U+0x0000</code> ~ <code>U+0x007F</code>,
 please use the function <a href="#method.value_length"><code>value_length</code></a> which has O(1) time complexity.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter-1" class="method"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#42-45">source</a><h4 class="code-header">pub fn <a href="#method.take_iter-1" class="fn">take_iter</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter-1" class="method"><h4 class="code-header">pub fn <a href="#method.take_iter-1" class="fn">take_iter</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Re [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked-1" class="method"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#53-56">source</a><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked-1" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked-1" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked-1" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Re [...]
 <h5 id="safety-3"><a class="doc-anchor" href="#safety-3">§</a>Safety</h5>
 <p>caller must ensure that the indexes in the iterator are less than the <code>array.len()</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_binary" class="method"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#62">source</a><h4 class="code-header">pub fn <a href="#method.try_from_binary" class="fn">try_from_binary</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_from_binary" class="method"><h4 class="code-header">pub fn <a href="#method.try_from_binary" class="fn">try_from_binary</a>(
     v: <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;, <a class="enum" href="../../error/enum.ArrowError.html"  [...]
 an error if <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray"><code>GenericBinaryArray</code></a> contains invalid UTF-8 data</p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-GenericByteArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#427">source</a><a href="#impl-Array-for-GenericByteArray%3CT%3E" class="anchor" [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#428">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.htm [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#432">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="str [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-GenericByteArray%3CT%3E" class="impl"><a href="#impl-Array-for-GenericByteArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="t [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#460">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:/ [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#473">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;se [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item-1" class="associatedtype trait-impl"><a href="#associatedtype.Item-1" class="anchor">§</a><h4 class="code-header">type <a href="../trait.ArrayAccessor.html#associatedtype.Item" class="associatedtype">Item</a> = &amp;'a &lt;T as <a [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item-1" class="associatedtype trait-impl"><a href="#associatedtype.Item-1" class="anchor">§</a><h4 class="code-header">type <a href="../trait.ArrayAccessor.html#associatedtype.Item" class="associatedtype">Item</a> = &amp;'a &lt;T as <a [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#95">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#418">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-6" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#79">source</a><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn">clone</a>(&amp;self) -&gt;  [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>(&amp;self, f: &amp;mut <a c [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-9" class="method trait-impl"><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class=" [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(
     v: <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;
-) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-8" class="method trait-impl"><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(
     value: <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;
-) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-10" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
+) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(array: <a class="str [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-11" class="method trait-impl"><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(
     v: <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;
-) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
-    T: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#110">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-11" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#91">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-9" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#104">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
+    T: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-7" class="method trait-impl"><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href=" [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-5" class="method trait-impl"><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struc [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-6" class="method trait-impl"><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struc [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-4" class="method trait-impl"><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;&gt;
-) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#85">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#97">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struc [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-10" class="method trait-impl"><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>&gt;&gt;
-) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#103">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
+) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struc [...]
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,
-    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt; + 'a,</div></h3></section></summary><div [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;Ptr&gt;&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/t [...]
+    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt; + 'a,</div></h3></section></summary><div [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;Ptr&gt;&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/t [...]
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,
-    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div clas [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;Ptr&gt;&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/co [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associatedtype.Item" cl [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#488">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/c [...]
-by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
-sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialEq-for-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#481">source</a><a href="#impl-PartialEq-for-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetS [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#482">source</a><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/night [...]
+    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div clas [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;Ptr&gt;&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/co [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associatedtype.Item" cl [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq-1" class="method trait-impl"><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymethod.eq" class="fn">eq</a>(&amp;self, other: &amp;<a [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-1" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" cl [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialEq-for-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="impl"><a href="#impl-PartialEq-for-GenericByteArray%3CGenericStringType%3COffsetSize%3E%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymethod.eq" class="fn">eq</a>(&amp;self, other: &amp;<a cla [...]
+by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-GenericByteArray%3CT%3E" class="impl"><a href="#impl-RefUnwindSafe-for-GenericByteArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="t [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div> [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><section id="impl-UnwindSafe-for [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe::UnwindSafe">UnwindSafe</a>,</div></h3></se [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"&[u8]":"<h3>Notable traits for <code>&amp;[<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u8.html\">u8</a>]</code></h3><pre><code><div class=\"where\">impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Read.html\" title= [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.GenericListArray.html b/arrow/array/array/struct.GenericListArray.html
index c93c5e952a6..64c24b79a27 100644
--- a/arrow/array/array/struct.GenericListArray.html
+++ b/arrow/array/array/struct.GenericListArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of variable length lists, similar to JSON arrays (e.g. `[&quot;A&quot;, &quot;B&quot;, &quot;C&quot;]`)."><title>GenericListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of variable length lists, similar to JSON arrays (e.g. `[&quot;A&quot;, &quot;B&quot;, &quot;C&quot;]`)."><title>GenericListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div>{
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -60,11 +60,11 @@ the actual <code>ListArray</code> encoding on the right.</p>
                                         └ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─
 
 
-</code></pre></div></div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.nulls" class="structfield section-header"><a href="#structfield.nulls" c [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedconstant.DATA_TYPE_CONSTRUCTOR" class="associatedconstant"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#149">source</a><h4 class="code-header">pub const <a href="#associatedconstant.DATA_TYPE_CONSTRUCTOR" c [...]
+</code></pre></div></div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.nulls" class="structfield section-header"><a href="#structfield.nulls" c [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedconstant.DATA_TYPE_CONSTRUCTOR" class="associatedconstant"><h4 class="code-header">pub const <a href="#associatedconstant.DATA_TYPE_CONSTRUCTOR" class="constant">DATA_TYPE_CONSTRUCTOR</a>: <a class="primitive" href="https://doc.rust-lang.org/ [...]
 The input is the schema of the child array and
 the output is the <a href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a>, List or LargeList.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#165-170">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;,
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;OffsetSize&gt;,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;,
@@ -78,7 +78,7 @@ the output is the <a href="../../datatypes/enum.DataType.html" title="enum arrow
 <li><code>!field.is_nullable() &amp;&amp; values.is_nullable()</code></li>
 <li><code>field.data_type() != values.data_type()</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#222-227">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
     field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;,
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;OffsetSize&gt;,
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;,
@@ -86,28 +86,28 @@ the output is the <a href="../../datatypes/enum.DataType.html" title="enum arrow
 ) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a> from the provided parts</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.GenericListArray.html#method.try_new" title="associated function arrow::array::GenericListArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#232">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title= [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#243-250">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;, len: <a class="primitive" href="https://doc.rust [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
     self
 ) -&gt; (<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;, <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;OffsetSize&gt;, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#263">source</a><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;OffsetSize&gt;</h4></section></summary><div class="docbl [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;OffsetSize&gt;</h4></section></summary><div class="docblock"><p>Returns a reference to the offsets of this list</p>
 <p>Unlike <a href="../struct.GenericListArray.html#method.value_offsets" title="method arrow::array::GenericListArray::value_offsets"><code>Self::value_offsets</code></a> this returns the <a href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer"><code>OffsetBuffer</code></a>
 allowing for zero-copy cloning</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#269">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#274">source</a><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a clone of [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#281">source</a><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/night [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a clone of the value type of this list.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" h [...]
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>Caller must ensure that the index is within the array bounds</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#288">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title= [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#296">source</a><h4 class="code-header">pub fn <a href="#method.value_offsets" class="fn">value_offsets</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[OffsetSize]</a></h4></section></summary><div class="docblock"><p>Returns the [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#302">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; OffsetSize</h4></section></summary><div class="docblock"><p>Returns the [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#308">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>&lt;'a&gt;(&amp;'a self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;'a <a class="struct" href="../struct.GenericListArray [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#323">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trai [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offsets" class="method"><h4 class="code-header">pub fn <a href="#method.value_offsets" class="fn">value_offsets</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[OffsetSize]</a></h4></section></summary><div class="docblock"><p>Returns the offset values in the offsets buffer</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; OffsetSize</h4></section></summary><div class="docblock"><p>Returns the length for value at index <code>i</code>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>&lt;'a&gt;(&amp;'a self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;&gt;  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(
     &amp;self,
     offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;</h4></section></summary><div class="docblock"><p>Returns a zero-copy slice of this array with the indicated offset and length.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_primitive" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#347-351">source</a><h4 class="code-header">pub fn <a href="#method.from_iter_primitive" class="fn">from_iter_primitive</a>&lt;T, P, I&gt;(iter: I) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetS [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_primitive" class="method"><h4 class="code-header">pub fn <a href="#method.from_iter_primitive" class="fn">from_iter_primitive</a>&lt;T, P, I&gt;(iter: I) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;<div class="where">where
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     P: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a  [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;P&gt;&gt;,</div></h4></section></summary><div class="docblock"><p>Creates a <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArra [...]
@@ -121,48 +121,48 @@ allowing for zero-copy cloning</p>
 ];
 <span class="kw">let </span>list_array = ListArray::from_iter_primitive::&lt;Int32Type, <span class="kw">_</span>, <span class="kw">_</span>&gt;(data);
 <span class="macro">println!</span>(<span class="string">"{:?}"</span>, list_array);</code></pre></div>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-GenericListArray%3COffsetSize%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#459">source</a><a href="#impl-Array-for-GenericListArray%3COffsetSize% [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#460">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html# [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#464">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="str [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-Array-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; <a class="trait" href=".. [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https:/ [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#492">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:/ [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#505">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;se [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="../trait.ArrayAccessor.html#associatedtype.Item" class="associatedtype">Item</a> = <a class="struct" href="h [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="../trait.ArrayAccessor.html#associatedtype.Item" class="associatedtype">Item</a> = <a class="struct" href="h [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at inde [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at inde [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at inde [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#135">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#528">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#374">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lan [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#381">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lan [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at inde [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn">clone</a>(&amp;self) -&gt; <a [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>(&amp;self, f: &amp;mut <a cla [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-5" class="method trait-impl"><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="st [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(value: <a class="struc [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(array: <a class="s [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-4" class="method trait-impl"><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(
     v: <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;
-) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
-    T: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#500">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/c [...]
+) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id=" [...]
+    T: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href=" [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymethod.eq" class="fn">eq</a>(&amp;self, other: &amp;<a cla [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-RefUnwindSafe-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt [...]
     OffsetSize: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><section id="impl-UnwindSafe-for-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-UnwindSafe-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; !<a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="tr [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"ArrayIter<&'a GenericListArray<OffsetSize>>":"<h3>Notable traits for <code><a class=\"struct\" href=\"../iterator/struct.ArrayIter.html\" title=\"struct arrow::array::iterator::ArrayIter\">ArrayIter</a>&lt;T&gt;</code></h3><pre><code><div class=\"where\">impl&lt;T&gt; <a class= [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.MapArray.html b/arrow/array/array/struct.MapArray.html
index 4a6d76e8561..ca3a7d023f7 100644
--- a/arrow/array/array/struct.MapArray.html
+++ b/arrow/array/array/struct.MapArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of key-value maps"><title>MapArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../. [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of key-value maps"><title>MapArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../. [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
     entries: <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a>,
@@ -9,7 +9,7 @@
 <p><a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a> is physically a <a href="../type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a> of key values pairs stored as an <code>entries</code>
 <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> with 2 child fields.</p>
 <p>See <a href="../builder/struct.MapBuilder.html" title="struct arrow::array::builder::MapBuilder"><code>MapBuilder</code></a> for how to construct a <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a></p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.nulls" class="structfield section-header"><a href="#structfield.nulls" class="anchor field" [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.nulls" class="structfield section-header"><a href="#structfield.nulls" class="anchor field" [...]
     field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;,
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
     entries: <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a>,
@@ -28,7 +28,7 @@ to construct a <a href="../struct.MapArray.html" title="struct arrow::array::Map
 <li><code>entries.columns().len() != 2</code></li>
 <li><code>field.data_type() != entries.data_type()</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#125-131">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
     field: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;,
     offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
     entries: <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a>,
@@ -39,57 +39,57 @@ to construct a <a href="../struct.MapArray.html" title="struct arrow::array::Map
 to construct a <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a></p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.MapArray.html#method.try_new" title="associated function arrow::array::MapArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#136-144">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
     self
 ) -&gt; (<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;, <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;, <a class="struct" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nigh [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</h4></section></summary><div class="docblock"><p>Return [...]
 <p>Unlike <a href="../struct.MapArray.html#method.value_offsets" title="method arrow::array::MapArray::value_offsets"><code>Self::value_offsets</code></a> this returns the <a href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer"><code>OffsetBuffer</code></a>
 allowing for zero-copy cloning</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#162">source</a><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait ar [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#167">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="tr [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.entries" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#172">source</a><h4 class="code-header">pub fn <a href="#method.entries" class="fn">entries</a>(&amp;self) -&gt; &amp;<a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Returns a reference to th [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.key_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#177">source</a><h4 class="code-header">pub fn <a href="#method.key_type" class="fn">key_type</a>(&amp;self) -&gt; &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns the data typ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#182">source</a><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns the da [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#190">source</a><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.StructArray.html" titl [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns a ref [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.entries" class="method"><h4 class="code-header">pub fn <a href="#method.entries" class="fn">entries</a>(&amp;self) -&gt; &amp;<a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Returns a reference to the <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArr [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.key_type" class="method"><h4 class="code-header">pub fn <a href="#method.key_type" class="fn">key_type</a>(&amp;self) -&gt; &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns the data type of the map’s keys.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_type" class="method"><h4 class="code-header">pub fn <a href="#method.value_type" class="fn">value_type</a>(&amp;self) -&gt; &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns the data type of the map’s values.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblo [...]
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>Caller must ensure that the index is within the array bounds</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#200">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray"> [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Returns ith value of this map  [...]
 <p>This is a <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> containing two fields</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#208">source</a><h4 class="code-header">pub fn <a href="#method.value_offsets" class="fn">value_offsets</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>]</h4></section></summary><div class="docblock"><p>Returns the offset va [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#214">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primiti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#220">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#230">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.MapArray.html" title="struct arro [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-MapArray-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#255">source</a><a href="#impl-MapArray-1" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" op [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offsets" class="method"><h4 class="code-header">pub fn <a href="#method.value_offsets" class="fn">value_offsets</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>]</h4></section></summary><div class="docblock"><p>Returns the offset values in the offsets buffer</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the length for va [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.MapArray.html" title="struct arrow::array:: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a>&lt;&amp;<a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a>&gt; <a href="#" class="tooltip" data-notable-ty="ArrayIter&lt; [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-MapArray-1" class="impl"><a href="#impl-MapArray-1" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new_from_strings" class="method"><h4 class="code-header">pub fn [...]
     keys: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,
     values: &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,
     entry_offsets: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u32.html">u32</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Creates map array from provided keys, values and entry_offsets.</p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-MapArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#346">source</a><a href="#impl-Array-for-MapArray" class="anchor">§</a><h3 class="code-header">i [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#351">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="stru [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-MapArray" class="impl"><a href="#impl-Array-for-MapArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#379">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:// [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/map_array.rs.html#392">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;sel [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a href="../trait.ArrayAc [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a href="../trait.ArrayAc [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-MapArray" class="impl"><a href="#impl-RefUnwindSafe-for-MapArray" class="anchor">§</a><h3 class="code-header">impl !<a class="trait" href="https://doc.rust-lang.org/ [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"ArrayIter<&MapArray>":"<h3>Notable traits for <code><a class=\"struct\" href=\"../iterator/struct.ArrayIter.html\" title=\"struct arrow::array::iterator::ArrayIter\">ArrayIter</a>&lt;T&gt;</code></h3><pre><code><div class=\"where\">impl&lt;T&gt; <a class=\"trait\" href=\"https: [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.NativeAdapter.html b/arrow/array/array/struct.NativeAdapter.html
index 47db7ff6cc5..11c68c5bcc5 100644
--- a/arrow/array/array/struct.NativeAdapter.html
+++ b/arrow/array/array/struct.NativeAdapter.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An optional primitive value"><title>NativeAdapter in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An optional primitive value"><title>NativeAdapter in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div>{
     pub native: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An optional primitive value</p>
@@ -8,11 +8,11 @@
 this struct. So once implementing <code>From</code> or <code>Into</code> trait for a type, an iterator of
 the type can be collected to <code>PrimitiveArray</code>.</p>
 </div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.native" class="structfield section-header"><a href="#structfield.native" class="anchor field">§</a><code>native: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::Ar [...]
-</div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-NativeAdapter%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1167">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-header">im [...]
+</div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-NativeAdapter%3CT%3E" class="impl"><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title= [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1206">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1200">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
+    &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(value [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-14" class="method trait-impl"><a href="#method.from-14" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a> [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><sectio [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe::UnwindSafe">Unwin [...]
@@ -24,8 +24,8 @@ the type can be collected to <code>PrimitiveArray</code>.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.NullArray.html b/arrow/array/array/struct.NullArray.html
index bacb6ac0af0..a09ee9faf55 100644
--- a/arrow/array/array/struct.NullArray.html
+++ b/arrow/array/array/struct.NullArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of null values"><title>NullArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of null values"><title>NullArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#null-layout">null values</a></p>
 <p>A <code>NullArray</code> is a simplified array where all values are null.</p>
@@ -12,35 +12,35 @@
 <span class="macro">assert_eq!</span>(array.len(), <span class="number">10</span>);
 <span class="macro">assert_eq!</span>(array.null_count(), <span class="number">0</span>);
 <span class="macro">assert_eq!</span>(array.logical_nulls().unwrap().null_count(), <span class="number">10</span>);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><h2 id="implementations" class="section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list" [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><h2 id="implementations" class="section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list" [...]
 <p><em>Note</em>: Use <a href="../fn.new_null_array.html" title="fn arrow::array::new_null_array"><code>crate::array::new_null_array</code></a> if you need an array of some
 other <a href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/null_array.rs.html#60">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">us [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.builder" class="method"><a class="src rightside" href="../../../src/arrow_array/array/null_array.rs.html#70">source</a><h4 class="code-header">pub fn <a href="#method.builder" class="fn">builder</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../builder/struct.NullBuilder.html" title="struct arrow::array::bui [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-NullArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/null_array.rs.html#75">source</a><a href="#impl-Array-for-NullArray" class="anchor">§</a><h3 class="code-header" [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/null_array.rs.html#80">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="stru [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.NullArray.html" title="struct arrow::array::Nu [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.builder" class="method"><h4 class="code-header">pub fn <a href="#method.builder" class="fn">builder</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../builder/struct.NullBuilder.html" title="struct arrow::array::builder::NullBuilder">NullBuilder</a></h4></section></summary><div class="docblock"><p>Returns a n [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-NullArray" class="impl"><a href="#impl-Array-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> f [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/null_array.rs.html#108">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:/ [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/null_array.rs.html#124">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;se [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#220">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href=" [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="pr [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-NullArray" class="impl"><a href="#impl-RefUnwindSafe-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.PrimitiveArray.html b/arrow/array/array/struct.PrimitiveArray.html
index 69b3b285b39..8c7b8e085bb 100644
--- a/arrow/array/array/struct.PrimitiveArray.html
+++ b/arrow/array/array/struct.PrimitiveArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of primitive values"><title>PrimitiveArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of primitive values"><title>PrimitiveArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div>{
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
@@ -38,8 +38,8 @@ builder.append_value(<span class="number">2</span>);
 <span class="comment">// Note: values for null indexes are arbitrary
 </span><span class="macro">assert_eq!</span>(array.values(), <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">0</span>, <span class="number">2</span>]);
 <span class="macro">assert!</span>(array.is_null(<span class="number">1</span>));</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="anchor fiel [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#522">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="anchor fiel [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> from the provided values and nulls</p>
@@ -54,8 +54,8 @@ this constructor is the most performant approach, avoiding any additional alloca
 <span class="comment">// [1, null, 3, 4]
 </span><span class="kw">let </span>nulls = NullBuffer::from(<span class="macro">vec!</span>[<span class="bool-val">true</span>, <span class="bool-val">false</span>, <span class="bool-val">true</span>, <span class="bool-val">true</span>]);
 <span class="kw">let </span>array = Int32Array::new(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>].into(), <span class="prelude-val">Some</span>(nulls));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#527">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::P [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#541-544">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Create a  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.PrimitiveArray.html" title=" [...]
@@ -64,51 +64,51 @@ this constructor is the most performant approach, avoiding any additional alloca
 <ul>
 <li><code>values.len() != nulls.len()</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_scalar" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#563">source</a><h4 class="code-header">pub fn <a href="#method.new_scalar" class="fn">new_scalar</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_scalar" class="method"><h4 class="code-header">pub fn <a href="#method.new_scalar" class="fn">new_scalar</a>(
     value: &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>
 ) -&gt; <a class="struct" href="../struct.Scalar.html" title="struct arrow::array::Scalar">Scalar</a>&lt;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;&gt;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.Scalar.html" title="struct arrow::array::Scalar"><code>Scalar</code></a> from <code>value</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#572">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(
     self
 ) -&gt; (<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>, <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associate [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_data_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#584">source</a><h4 class="code-header">pub fn <a href="#method.with_data_type" class="fn">with_data_type</a>(self, data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>) -&gt; <a class="struct" href="../struct.Primitive [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_data_type" class="method"><h4 class="code-header">pub fn <a href="#method.with_data_type" class="fn">with_data_type</a>(self, data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></s [...]
 <p>Prefer using <a href="../struct.PrimitiveArray.html#method.with_timezone" title="method arrow::array::PrimitiveArray::with_timezone"><code>Self::with_timezone</code></a> or <a href="../struct.PrimitiveArray.html#method.with_precision_and_scale" title="method arrow::array::PrimitiveArray::with_precision_and_scale"><code>Self::with_precision_and_scale</code></a> where
 the primitive type is suitably constrained, as these cannot panic</p>
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if ![Self::is_compatible]</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#601">source</a><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of this array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#606">source</a><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether this array is empty.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#612">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.builder" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#617">source</a><h4 class="code-header">pub fn <a href="#method.builder" class="fn">builder</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../builder/struct.PrimitiveBuilder.html" title="struct arrow: [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_compatible" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#625">source</a><h4 class="code-header">pub fn <a href="#method.is_compatible" class="fn">is_compatible</a>(data_type: &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>) -&gt; <a class="primitive" href="https://doc.rust-lan [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of this array.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether this array is empty.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.builder" class="method"><h4 class="code-header">pub fn <a href="#method.builder" class="fn">builder</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../builder/struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;T&gt;</h4></section></summary><div class=" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_compatible" class="method"><h4 class="code-header">pub fn <a href="#method.is_compatible" class="fn">is_compatible</a>(data_type: &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Retu [...]
 <p>This is equivalent to <code>data_type == T::DATA_TYPE</code>, however ignores timestamp
 timezones and decimal precision and scale</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#642">source</a><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.value_unchecked" class="fn">value_unchecked</a>(
     &amp;self,
     i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a></h4></section></summary><div class="docblock"><p>Returns the primitive value at index <code>i</code>.</p>
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>caller must ensure that the passed in offset is less than the array len()</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#650">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href [...]
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>Panics if index <code>i</code> is out of bounds</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#661">source</a><h4 class="code-header">pub fn <a href="#method.from_iter_values" class="fn">from_iter_values</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_iter_values" class="method"><h4 class="code-header">pub fn <a href="#method.from_iter_values" class="fn">from_iter_values</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowP [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#672">source</a><h4 class="code-header">pub fn <a href="#method.from_value" class="fn">from_value</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_value" class="method"><h4 class="code-header">pub fn <a href="#method.from_value" class="fn">from_value</a>(
     value: &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>,
     count: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Creates a PrimitiveArray based on a constant value with <code>count</code> elements</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#680-683">source</a><h4 class="code-header">pub fn <a href="#method.take_iter" class="fn">take_iter</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter" class="method"><h4 class="code-header">pub fn <a href="#method.take_iter" class="fn">take_iter</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a clas [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#691-694">source</a><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.take_iter_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.take_iter_unchecked" class="fn">take_iter_unchecked</a>&lt;'a&gt;(
     &amp;'a self,
     indexes: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;&gt; + 'a
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a clas [...]
 <h5 id="safety-1"><a class="doc-anchor" href="#safety-1">§</a>Safety</h5>
 <p>caller must ensure that the offsets in the iterator are less than the array len()</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#699">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.reinterpret_cast" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#724-726">source</a><h4 class="code-header">pub fn <a href="#method.reinterpret_cast" class="fn">reinterpret_cast</a>&lt;K&gt;(&amp;self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;<div class="wher [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::a [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.reinterpret_cast" class="method"><h4 class="code-header">pub fn <a href="#method.reinterpret_cast" class="fn">reinterpret_cast</a>&lt;K&gt;(&amp;self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;<div class="where">where
     K: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&lt;Native = &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&g [...]
 <p>This can be used to efficiently convert between primitive arrays with the
 same underlying representation</p>
@@ -120,7 +120,7 @@ will become 100 seconds in a <a href="../type.TimestampSecondArray.html" title="
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = Int64Array::from_iter_values([<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>]);
 <span class="kw">let </span>b: TimestampNanosecondArray = a.reinterpret_cast();</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.unary" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#753-756">source</a><h4 class="code-header">pub fn <a href="#method.unary" class="fn">unary</a>&lt;F, O&gt;(&amp;self, op: F) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;O&gt;<div class="where">where
+</div></details><details class="toggle method-toggle" open><summary><section id="method.unary" class="method"><h4 class="code-header">pub fn <a href="#method.unary" class="fn">unary</a>&lt;F, O&gt;(&amp;self, op: F) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;O&gt;<div class="where">where
     O: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>) -&gt; &lt;O as <a cla [...]
 This is the fastest way to perform an operation on a primitive array when
@@ -133,7 +133,7 @@ or this function may panic.</p>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">5</span>), <span class="prelude-val">Some</span>(<span class="number">7</span>), <span class="prelude-val">None</span>]);
 <span class="kw">let </span>c = array.unary(|x| x * <span class="number">2 </span>+ <span class="number">1</span>);
 <span class="macro">assert_eq!</span>(c, Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">11</span>), <span class="prelude-val">Some</span>(<span class="number">15</span>), <span class="prelude-val">None</span>]));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.unary_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#787-789">source</a><h4 class="code-header">pub fn <a href="#method.unary_mut" class="fn">unary_mut</a>&lt;F&gt;(self, op: F) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.unary_mut" class="method"><h4 class="code-header">pub fn <a href="#method.unary_mut" class="fn">unary_mut</a>&lt;F&gt;(self, op: F) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;, <a c [...]
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>) -&gt; &lt;T as <a cla [...]
 Mutable primitive array means that the buffer is not shared with other arrays.
 As a result, this mutates the buffer directly without allocating new buffer.</p>
@@ -145,14 +145,14 @@ or this function may panic.</p>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">5</span>), <span class="prelude-val">Some</span>(<span class="number">7</span>), <span class="prelude-val">None</span>]);
 <span class="kw">let </span>c = array.unary_mut(|x| x * <span class="number">2 </span>+ <span class="number">1</span>).unwrap();
 <span class="macro">assert_eq!</span>(c, Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">11</span>), <span class="prelude-val">Some</span>(<span class="number">15</span>), <span class="prelude-val">None</span>]));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_unary" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#806-809">source</a><h4 class="code-header">pub fn <a href="#method.try_unary" class="fn">try_unary</a>&lt;F, O, E&gt;(&amp;self, op: F) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_unary" class="method"><h4 class="code-header">pub fn <a href="#method.try_unary" class="fn">try_unary</a>&lt;F, O, E&gt;(&amp;self, op: F) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt; [...]
     O: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>) -&gt; <a class="enum" [...]
 <p>This is unlike <a href="../struct.PrimitiveArray.html#method.unary" title="method arrow::array::PrimitiveArray::unary"><code>Self::unary</code></a> which will apply an infallible function to all rows
 regardless of validity, in many cases this will be significantly faster and should
 be preferred if <code>op</code> is infallible.</p>
 <p>Note: LLVM is currently unable to effectively vectorize fallible operations</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_unary_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#846-851">source</a><h4 class="code-header">pub fn <a href="#method.try_unary_mut" class="fn">try_unary_mut</a>&lt;F, E&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_unary_mut" class="method"><h4 class="code-header">pub fn <a href="#method.try_unary_mut" class="fn">try_unary_mut</a>&lt;F, E&gt;(
     self,
     op: F
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;, E&gt;, <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array [...]
@@ -167,218 +167,218 @@ array. In the case, returned <code>Err</code> wraps input array. If the function
 encounters an error during applying on values. In the case, this returns an <code>Err</code> within
 an <code>Ok</code> which wraps the actual error.</p>
 <p>Note: LLVM is currently unable to effectively vectorize fallible operations</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.unary_opt" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#878-881">source</a><h4 class="code-header">pub fn <a href="#method.unary_opt" class="fn">unary_opt</a>&lt;F, O&gt;(&amp;self, op: F) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;O&gt;<div class="where">where
+</div></details><details class="toggle method-toggle" open><summary><section id="method.unary_opt" class="method"><h4 class="code-header">pub fn <a href="#method.unary_opt" class="fn">unary_opt</a>&lt;F, O&gt;(&amp;self, op: F) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;O&gt;<div class="where">where
     O: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>) -&gt; <a class="enum" [...]
 <p>This is unlike <a href="../struct.PrimitiveArray.html#method.unary" title="method arrow::array::PrimitiveArray::unary"><code>Self::unary</code></a> which will apply an infallible function to all rows
 regardless of validity, in many cases this will be significantly faster and should
 be preferred if <code>op</code> is infallible.</p>
 <p>Note: LLVM is currently unable to effectively vectorize fallible operations</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_builder" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#920">source</a><h4 class="code-header">pub fn <a href="#method.into_builder" class="fn">into_builder</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../builder/str [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_builder" class="method"><h4 class="code-header">pub fn <a href="#method.into_builder" class="fn">into_builder</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../builder/struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a [...]
 data buffer is not shared by others.</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1051-1053">source</a><a href="#impl-PrimitiveArray%3CT%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="whe [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-1" class="impl"><a href="#impl-PrimitiveArray%3CT%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
     T: <a class="trait" href="../../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a>,
-    <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" ti [...]
+    <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" ti [...]
 <p>If a data type cannot be converted to <code>NaiveDateTime</code>, a <code>None</code> is returned.
 A valid value is expected, thus the user should first check for validity.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_datetime_with_tz" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1067">source</a><h4 class="code-header">pub fn <a href="#method.value_as_datetime_with_tz" class="fn">value_as_datetime_with_tz</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_datetime_with_tz" class="method"><h4 class="code-header">pub fn <a href="#method.value_as_datetime_with_tz" class="fn">value_as_datetime_with_tz</a>(
     &amp;self,
     i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     tz: <a class="struct" href="../timezone/struct.Tz.html" title="struct arrow::array::timezone::Tz">Tz</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://docs.rs/chrono/latest/chrono/datetime/struct.DateTime.html" title="struct chrono::datetime::DateTime">DateTime</a>&lt;<a class="struct" href="../timezone/struct.Tz.html" title="struct arrow::array::timezone::Tz">Tz</a>&gt;&gt;</h4></section></summary><div class="docblock"><p>Returns value as a chrono <code>NaiveDateT [...]
 <p>functionally it is same as <code>value_as_datetime</code>, however it adds
 the passed tz to the to-be-returned NaiveDateTime</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_date" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1074">source</a><h4 class="code-header">pub fn <a href="#method.value_as_date" class="fn">value_as_date</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/o [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_date" class="method"><h4 class="code-header">pub fn <a href="#method.value_as_date" class="fn">value_as_date</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https: [...]
 <p>If a data type cannot be converted to <code>NaiveDate</code>, a <code>None</code> is returned</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_time" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1081">source</a><h4 class="code-header">pub fn <a href="#method.value_as_time" class="fn">value_as_time</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/o [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_time" class="method"><h4 class="code-header">pub fn <a href="#method.value_as_time" class="fn">value_as_time</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https: [...]
 <p><code>Date32</code> and <code>Date64</code> return UTC midnight as they do not have time resolution</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_duration" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1088">source</a><h4 class="code-header">pub fn <a href="#method.value_as_duration" class="fn">value_as_duration</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/ni [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_duration" class="method"><h4 class="code-header">pub fn <a href="#method.value_as_duration" class="fn">value_as_duration</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct"  [...]
 <p>If a data type cannot be converted to <code>Duration</code>, a <code>None</code> is returned</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-2" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1154">source</a><a href="#impl-PrimitiveArray%3CT%3E-2" class="anchor">§</a><h3 class="code-header">impl&lt;'a, T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="wher [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1156">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;'a self) -&g [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-3" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1250">source</a><a href="#impl-PrimitiveArray%3CT%3E-3" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_trusted_len_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1256-1259">source</a><h4 class="code-header">pub unsafe fn <a href="#method.from_trusted_l [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-2" class="impl"><a href="#impl-PrimitiveArray%3CT%3E-2" class="anchor">§</a><h3 class="code-header">impl&lt;'a, T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;'a self) -&gt; <a class="struct" href="../iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::Ar [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-3" class="impl"><a href="#impl-PrimitiveArray%3CT%3E-3" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_trusted_len_iter" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.from_trusted_len_iter" class="fn">from_trusted_len_iter</a>&lt;I, P&gt;(iter: I) -&gt; <a class="struct" href="../struct. [...]
     P: <a class="trait" href="https://doc.rust-lang.org/nightly/core/borrow/trait.Borrow.html" title="trait core::borrow::Borrow">Borrow</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.Ar [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = P&gt;,</div></h4></section></summary><div class="docblock"><p>Creates a <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> from an iterator of trusted length.</p>
 <h5 id="safety-2"><a class="doc-anchor" href="#safety-2">§</a>Safety</h5>
 <p>The iterator must be <a href="https://doc.rust-lang.org/std/iter/trait.TrustedLen.html"><code>TrustedLen</code></a>.
 I.e. that <code>size_hint().1</code> correctly reports its length.</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-4" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1329">source</a><a href="#impl-PrimitiveArray%3CT%3E-4" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
-    T: <a class="trait" href="../../datatypes/trait.ArrowTimestampType.html" title="trait arrow::datatypes::ArrowTimestampType">ArrowTimestampType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_vec" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1332-1334">source</a><h4 class="code-header">pub fn <a href="#method.from_vec" class="fn">from_vec</a>( [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-4" class="impl"><a href="#impl-PrimitiveArray%3CT%3E-4" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
+    T: <a class="trait" href="../../datatypes/trait.ArrowTimestampType.html" title="trait arrow::datatypes::ArrowTimestampType">ArrowTimestampType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_vec" class="method"><h4 class="code-header">pub fn <a href="#method.from_vec" class="fn">from_vec</a>(data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct al [...]
     <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;&gt; [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_opt_vec" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1341-1343">source</a><h4 class="code-header">pub fn <a href="#method.from_opt_vec" class="fn">from_opt_vec</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_opt_vec" class="method"><h4 class="code-header">pub fn <a href="#method.from_opt_vec" class="fn">from_opt_vec</a>(
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;&gt;,
     timezone: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>&gt;
 ) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
     <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum co [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.timezone" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1349">source</a><h4 class="code-header">pub fn <a href="#method.timezone" class="fn">timezone</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="primitive" href="https://doc. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1357">source</a><h4 class="code-header">pub fn <a href="#method.with_timezone" class="fn">with_timezone</a>(self, timezone: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="ht [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone_utc" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1362">source</a><h4 class="code-header">pub fn <a href="#method.with_timezone_utc" class="fn">with_timezone_utc</a>(self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone_opt" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1367">source</a><h4 class="code-header">pub fn <a href="#method.with_timezone_opt" class="fn">with_timezone_opt</a>&lt;S&gt;(self, timezone: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;S&gt;) -& [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.timezone" class="method"><h4 class="code-header">pub fn <a href="#method.timezone" class="fn">timezone</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></summary><div class="docblock [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone" class="method"><h4 class="code-header">pub fn <a href="#method.with_timezone" class="fn">with_timezone</a>(self, timezone: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone_utc" class="method"><h4 class="code-header">pub fn <a href="#method.with_timezone_utc" class="fn">with_timezone_utc</a>(self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Construct a timestamp array with UTC</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone_opt" class="method"><h4 class="code-header">pub fn <a href="#method.with_timezone_opt" class="fn">with_timezone_opt</a>&lt;S&gt;(self, timezone: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;S&gt;) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray" [...]
     S: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class="docblock"><p>Construct a timestamp array with an optional timezone</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-5" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1394">source</a><a href="#impl-PrimitiveArray%3CT%3E-5" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
-    T: <a class="trait" href="../../datatypes/trait.DecimalType.html" title="trait arrow::datatypes::DecimalType">DecimalType</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.with_precision_and_scale" class="method"><a class="src rightside" href="../../../src/arro [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveArray%3CT%3E-5" class="impl"><a href="#impl-PrimitiveArray%3CT%3E-5" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;<div class="where">where
+    T: <a class="trait" href="../../datatypes/trait.DecimalType.html" title="trait arrow::datatypes::DecimalType">DecimalType</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.with_precision_and_scale" class="method"><h4 class="code-header">pub fn <a href="#method. [...]
     self,
     precision: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>,
     scale: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Returns a Decimal array with the same data as self, with the
 specified precision and scale.</p>
 <p>See <a href="../../datatypes/fn.validate_decimal_precision_and_scale.html" title="fn arrow::datatypes::validate_decimal_precision_and_scale"><code>validate_decimal_precision_and_scale</code></a></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.validate_decimal_precision" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1409">source</a><h4 class="code-header">pub fn <a href="#method.validate_decimal_precision" class="fn">validate_decimal_precision</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.validate_decimal_precision" class="method"><h4 class="code-header">pub fn <a href="#method.validate_decimal_precision" class="fn">validate_decimal_precision</a>(
     &amp;self,
     precision: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Validates values in this array can be properly interpreted
 with the specified precision.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.null_if_overflow_precision" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1422">source</a><h4 class="code-header">pub fn <a href="#method.null_if_overflow_precision" class="fn">null_if_overflow_precision</a>(&amp;self, precision: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>) -&gt; <a class="struct" hre [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.null_if_overflow_precision" class="method"><h4 class="code-header">pub fn <a href="#method.null_if_overflow_precision" class="fn">null_if_overflow_precision</a>(&amp;self, precision: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T& [...]
 will be casted to Null</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_string" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1429">source</a><h4 class="code-header">pub fn <a href="#method.value_as_string" class="fn">value_as_string</a>(&amp;self, row: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nigh [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.precision" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1434">source</a><h4 class="code-header">pub fn <a href="#method.precision" class="fn">precision</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a></h4></section></summary><div class="docblock"><p>Returns the decimal precision of th [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.scale" class="method"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1461">source</a><h4 class="code-header">pub fn <a href="#method.scale" class="fn">scale</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a></h4></section></summary><div class="docblock"><p>Returns the decimal scale of this array</p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-PrimitiveArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#988">source</a><a href="#impl-Array-for-PrimitiveArray%3CT%3E" class="anchor [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#989">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#993">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_as_string" class="method"><h4 class="code-header">pub fn <a href="#method.value_as_string" class="fn">value_as_string</a>(&amp;self, row: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></h4></section></s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.precision" class="method"><h4 class="code-header">pub fn <a href="#method.precision" class="fn">precision</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a></h4></section></summary><div class="docblock"><p>Returns the decimal precision of this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.scale" class="method"><h4 class="code-header">pub fn <a href="#method.scale" class="fn">scale</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a></h4></section></summary><div class="docblock"><p>Returns the decimal scale of this array</p>
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-PrimitiveArray%3CT%3E" class="impl"><a href="#impl-Array-for-PrimitiveArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="tra [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1021">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="h [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1033">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(& [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item-1" class="associatedtype trait-impl"><a href="#associatedtype.Item-1" class="anchor">§</a><h4 class="code-header">type <a href="../trait.ArrayAccessor.html#associatedtype.Item" class="associatedtype">Item</a> = &lt; [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item-1" class="associatedtype trait-impl"><a href="#associatedtype.Item-1" class="anchor">§</a><h4 class="code-header">type <a href="../trait.ArrayAccessor.html#associatedtype.Item" class="associatedtype">Item</a> = &lt; [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;&amp;'a <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#491">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href=" [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1094">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="htt [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn">clone</a>(&a [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>(&amp;self, f [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>PrimitiveArray</code> from an array data reference.</p>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-40" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-40" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="../struct.ArrayData.html" title="struct arr [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-22" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#978">source</a><a href="#method.from-22" class="anchor">§</a><h4 class="code-header">fn <a hr [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-15" class="method trait-impl"><a href="#method.from-15" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" titl [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-18" class="method trait-impl"><a href="#method.from-18" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a> [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDate64Type+as+ArrowPrimi [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDate64Type+as+ArrowPrimi [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal128Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal128Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimi [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal256Ty [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal256Ty [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimi [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDurationMicr [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDurationMicr [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../.. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../.. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../da [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trai [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat32Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat32Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat64Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat64Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt16Type+as+ArrowPri [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt16Type+as+ArrowPri [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt32Type+as+ArrowPrimitive [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt32Type+as+ArrowPrimitive [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt64Type+as+ArrowPrimitive [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt64Type+as+ArrowPrimitive [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt8Type+as+ArrowPrimitiveT [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt8Type+as+ArrowPrimitiveT [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#asso [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CIntervalDayTimeType+as+ArrowPr [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CIntervalDayTimeType+as+ArrowPr [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/t [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href=".. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datat [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datat [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.Arro [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CTime64 [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CTime64 [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time64MicrosecondType.html" title="struct arrow::datatypes::Time64MicrosecondType">Time64MicrosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datat [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64MicrosecondType.html" title="struct arrow::datatypes::Time64MicrosecondType">Time64MicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64MicrosecondType.html" title="struct arrow::datatypes::Time64MicrosecondType">Time64MicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatype [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href=".. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href=".. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../.. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/t [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt16Type.html" title="struct arrow::datatypes::UInt16Type">UInt16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt16Type.html" title="struct arrow::datatypes::UInt16Type">UInt16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CUInt32Type+as+ArrowPrimi [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt16Type.html" title="struct arrow::datatypes::UInt16Type">UInt16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CUInt32Type+as+ArrowPrimi [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt32Type.html" title="struct arrow::datatypes::UInt32Type">UInt32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt32Type.html" title="struct arrow::datatypes::UInt32Type">UInt32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CUInt64Type+as+ArrowPrimi [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt32Type.html" title="struct arrow::datatypes::UInt32Type">UInt32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CUInt64Type+as+ArrowPrimi [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt64Type.html" title="struct arrow::datatypes::UInt64Type">UInt64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt64Type.html" title="struct arrow::datatypes::UInt64Type">UInt64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CUInt8Type+as+ArrowPrimit [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt64Type.html" title="struct arrow::datatypes::UInt64Type">UInt64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CUInt8Type+as+ArrowPrimit [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt8Type.html" title="struct arrow::datatypes::UInt8Type">UInt8Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt8Type.html" title="struct arrow::datatypes::UInt8Type">UInt8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDate32Type+as+Arro [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt8Type.html" title="struct arrow::datatypes::UInt8Type">UInt8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDate32Type+as+Arro [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::d [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDate64Type+as+A [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDate64Type+as+A [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::d [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDecimal128Type+ [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDecimal128Type+ [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="tr [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDec [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDec [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="tr [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDur [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CDur [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPr [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPr [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimi [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COpt [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COpt [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CFloat32Type+ [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CFloat32Type+ [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CFloat64Type+ [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CFloat64Type+ [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt16Type+as [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt16Type+as [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::data [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt32Type+as+Arrow [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt32Type+as+Arrow [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::data [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt64Type+as+Arrow [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt64Type+as+Arrow [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::data [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt8Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CInt8Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatyp [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CIntervalDayTimeType+a [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CIntervalDayTimeType+a [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../../datatypes/trait.Arro [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiv [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiv [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" tit [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time64MicrosecondType.html" title="struct arrow::datatypes::Time64MicrosecondType">Time64MicrosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiv [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64MicrosecondType.html" title="struct arrow::datatypes::Time64MicrosecondType">Time64MicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64MicrosecondType.html" title="struct arrow::datatypes::Time64MicrosecondType">Time64MicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveTy [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</a> as <a class="trait" href="../../datatypes/trait.Arro [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</a> as <a class="trait" href="../../datatypes/trait.Arro [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPr [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt16Type.html" title="struct arrow::datatypes::UInt16Type">UInt16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::d [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt16Type.html" title="struct arrow::datatypes::UInt16Type">UInt16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CUInt32Type+as+A [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt16Type.html" title="struct arrow::datatypes::UInt16Type">UInt16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CUInt32Type+as+A [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt32Type.html" title="struct arrow::datatypes::UInt32Type">UInt32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::d [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt32Type.html" title="struct arrow::datatypes::UInt32Type">UInt32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CUInt64Type+as+A [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt32Type.html" title="struct arrow::datatypes::UInt32Type">UInt32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CUInt64Type+as+A [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt64Type.html" title="struct arrow::datatypes::UInt64Type">UInt64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::d [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt64Type.html" title="struct arrow::datatypes::UInt64Type">UInt64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CUInt8Type+as+Ar [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt64Type.html" title="struct arrow::datatypes::UInt64Type">UInt64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3COption%3C%3CUInt8Type+as+Ar [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.UInt8Type.html" title="struct arrow::datatypes::UInt8Type">UInt8Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::data [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt8Type.html" title="struct arrow::datatypes::UInt8Type">UInt8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-FromIterator%3CPtr%3E-for-PrimitiveArray%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.UInt8Type.html" title="struct arrow::datatypes::UInt8Type">UInt8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-FromIterator%3CPtr%3E-for-PrimitiveArray%3C [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="../struct.NativeAdapter.html" title="struct arrow::array::NativeAdapter">NativeAdapter</a>&lt;T&gt;&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/ar [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = Ptr&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter">Read more</a></div></details></div></details><details class="toggle implementors-toggle" [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associat [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#464">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="../struct.NativeAdapter.html" title="struct arrow::array::NativeAdapter">NativeAdapter</a>&lt;T&gt;&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a href="#method.from_iter" class="anchor">§</a><h4 class= [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = Ptr&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter">Read more</a></div></details></div></details><details class="toggle implementors-toggle" [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associat [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymethod.eq" class="fn">eq</a>(&amp;self, o [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-PrimitiveArray%3CT%3E" class="impl"><a href="#impl-RefUnwindSafe-for-PrimitiveArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
@@ -386,16 +386,16 @@ sufficient, and should not be overridden without very good reason.</div></detail
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe::UnwindSafe">Unwin [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"ArrayIter<&'a PrimitiveArray<T>>":"<h3>Notable traits for <code><a class=\"struct\" href=\"../iterator/struct.ArrayIter.html\" title=\"struct arrow::array::iterator::ArrayIter\">ArrayIter</a>&lt;T&gt;</code></h3><pre><code><div class=\"where\">impl&lt;T&gt; <a class=\"trait\" h [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.RunArray.html b/arrow/array/array/struct.RunArray.html
index 390d21c92d3..69e61ee5e4e 100644
--- a/arrow/array/array/struct.RunArray.html
+++ b/arrow/array/array/struct.RunArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of run-end encoded values"><title>RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of run-end encoded values"><title>RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div>{
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     run_ends: <a class="struct" href="../../buffer/struct.RunEndBuffer.html" title="struct arrow::buffer::RunEndBuffer">RunEndBuffer</a>&lt;&lt;R as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
@@ -28,22 +28,22 @@ stores the value of each run. Below example illustrates how a logical array is r
   
                                             Logical array
                                                Contents
-</code></pre></div></div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.run_ends" class="structfield section-header"><a href="#structfield.run_e [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.logical_len" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#83">source</a><h4 class="code-header">pub fn <a href="#method.logical_len" class="fn">logical_len</a>(run_ends: &am [...]
+</code></pre></div></div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.run_ends" class="structfield section-header"><a href="#structfield.run_e [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.logical_len" class="method"><h4 class="code-header">pub fn <a href="#method.logical_len" class="fn">logical_len</a>(run_ends: &amp;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::Primitive [...]
 by the given run_ends array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#94">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     run_ends: &amp;<a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;R&gt;,
     values: &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Attempts to create RunArray using given run_ends (index where a run ends)
 and the values (value of the run). Returns an error if the given data is not compatible
 with RunEndEncoded specification.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.run_ends" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#122">source</a><h4 class="code-header">pub fn <a href="#method.run_ends" class="fn">run_ends</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.RunEndBuffer.html" title="struct arrow::buffer::RunEndBuffer">RunEndBuffer</a>&lt;&lt;R as <a class="trait" href="../../datatypes/trait. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#130">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="tr [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.run_ends" class="method"><h4 class="code-header">pub fn <a href="#method.run_ends" class="fn">run_ends</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.RunEndBuffer.html" title="struct arrow::buffer::RunEndBuffer">RunEndBuffer</a>&lt;&lt;R as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns [...]
 <p>Note: any slicing of this <a href="../struct.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray</code></a> array is not applied to the returned array
 and must be handled separately</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.get_start_physical_index" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#135">source</a><h4 class="code-header">pub fn <a href="#method.get_start_physical_index" class="fn">get_start_physical_index</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docb [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.get_end_physical_index" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#140">source</a><h4 class="code-header">pub fn <a href="#method.get_end_physical_index" class="fn">get_end_physical_index</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.downcast" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.downcast" class="fn">downcast</a>&lt;V&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../struct.TypedRun [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.get_start_physical_index" class="method"><h4 class="code-header">pub fn <a href="#method.get_start_physical_index" class="fn">get_start_physical_index</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the physical index at which the array slice starts.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.get_end_physical_index" class="method"><h4 class="code-header">pub fn <a href="#method.get_end_physical_index" class="fn">get_end_physical_index</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the physical index at which the array slice ends.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.downcast" class="method"><h4 class="code-header">pub fn <a href="#method.downcast" class="fn">downcast</a>&lt;V&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray">TypedRunArray</a>&lt;'_, R, V&gt;&gt;<di [...]
     V: 'static,</div></h4></section></summary><div class="docblock"><p>Downcast this <a href="../struct.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray</code></a> to a <a href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray"><code>TypedRunArray</code></a></p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, ArrayAccessor, RunArray, StringArray, types::Int32Type};
@@ -54,11 +54,11 @@ and must be handled separately</p>
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">0</span>), <span class="string">"a"</span>);
 <span class="macro">assert_eq!</span>(typed.value(<span class="number">1</span>), <span class="string">"b"</span>);
 <span class="macro">assert!</span>(typed.values().is_null(<span class="number">2</span>));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.get_physical_index" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#170">source</a><h4 class="code-header">pub fn <a href="#method.get_physical_index" class="fn">get_physical_index</a>(&amp;self, logical_index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rus [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.get_physical_index" class="method"><h4 class="code-header">pub fn <a href="#method.get_physical_index" class="fn">get_physical_index</a>(&amp;self, logical_index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docb [...]
 This function adjusts the input logical index based on <code>ArrayData::offset</code>
 Performs a binary search on the run_ends array for the input index.</p>
 <p>The result is arbitrary if <code>logical_index &gt;= self.len()</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.get_physical_indices" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#182-184">source</a><h4 class="code-header">pub fn <a href="#method.get_physical_indices" class="fn">get_physical_indices</a>&lt;I&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.get_physical_indices" class="method"><h4 class="code-header">pub fn <a href="#method.get_physical_indices" class="fn">get_physical_indices</a>&lt;I&gt;(
     &amp;self,
     logical_indices: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[I]</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;<div clas [...]
@@ -69,24 +69,24 @@ finding physical index for each logical index using binary search using the func
 <code>get_physical_index</code>. Running benchmarks on both approaches showed that the approach used here
 scaled well for larger inputs.
 See <a href="https://github.com/apache/arrow-rs/pull/3622#issuecomment-1407753727">https://github.com/apache/arrow-rs/pull/3622#issuecomment-1407753727</a> for more details.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#248">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-RunArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#305">source</a><a href="#impl-Array-for-RunArray%3CT%3E" class="anchor">§</a><h3 class=" [...]
-    T: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#306">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Arra [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#310">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="stru [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array:: [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-RunArray%3CT%3E" class="impl"><a href="#impl-Array-for-RunArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+    T: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href= [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#338">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:// [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#383">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;sel [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#220">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href=" [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#71">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#391">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#259">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#286">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.r [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="pr [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn">clone</a>(&amp;self)  [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>(&amp;self, f: &amp;mu [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(array: <a  [...]
     T: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>RunArray</code> from an iterator of strings.</p>
-<h4 id="example-1"><a class="doc-anchor" href="#example-1">§</a>Example:</h4>
+<h4 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{RunArray, PrimitiveArray, StringArray, types::Int16Type};
 
 <span class="kw">let </span>test = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>];
@@ -95,10 +95,10 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"RunArray {run_ends: [2, 3, 4], values: StringArray\n[\n  \"a\",\n  \"b\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#445">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct"  [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.fr [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;T&gt;<div clas [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.fr [...]
     T: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>RunArray</code> from an iterator of optional strings.</p>
-<h4 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h4>
+<h4 id="example-1"><a class="doc-anchor" href="#example-1">§</a>Example:</h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{RunArray, PrimitiveArray, StringArray, types::Int16Type};
 
 <span class="kw">let </span>test = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>, <span class="string">"c"</span>];
@@ -110,20 +110,20 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"RunArray {run_ends: [2, 3, 5], values: StringArray\n[\n  \"a\",\n  null,\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#418">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;T&gt;<div  [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
     &lt;R as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><sectio [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.StructArray.html b/arrow/array/array/struct.StructArray.html
index 56c53ef1ddd..c245ccf6ca0 100644
--- a/arrow/array/array/struct.StructArray.html
+++ b/arrow/array/array/struct.StructArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of structs"><title>StructArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../.. [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of structs"><title>StructArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../.. [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -45,14 +45,14 @@ is no way to preserve them.</p>
 <span class="macro">assert_eq!</span>(<span class="number">4</span>, struct_array.len());
 <span class="macro">assert_eq!</span>(<span class="number">0</span>, struct_array.null_count());
 <span class="macro">assert_eq!</span>(<span class="number">0</span>, struct_array.offset());</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: < [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: < [...]
     fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>,
     arrays: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> from the provided parts, panicking on failure</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.StructArray.html#method.try_new" title="associated function arrow::array::StructArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#104-108">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>,
     arrays: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
@@ -66,61 +66,61 @@ is no way to preserve them.</p>
 <li><code>arrays[i].len() != nulls.len()</code></li>
 <li><code>!fields[i].is_nullable() &amp;&amp; !nulls.contains(arrays[i].nulls())</code></li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#167">source</a><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#186-190">source</a><h4 class="code-header">pub unsafe fn <a href="#method.new_unchecked" class="fn">new_unchecked</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_null" class="method"><h4 class="code-header">pub fn <a href="#method.new_null" class="fn">new_null</a>(fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct ar [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_unchecked" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.new_unchecked" class="fn">new_unchecked</a>(
     fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>,
     arrays: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;
 ) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> from the provided parts without validation</p>
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>Safe if <a href="../struct.StructArray.html#method.new" title="associated function arrow::array::StructArray::new"><code>Self::new</code></a> would not panic with the given arguments</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_empty_fields" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#205">source</a><h4 class="code-header">pub fn <a href="#method.new_empty_fields" class="fn">new_empty_fields</a>(len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/opti [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_empty_fields" class="method"><h4 class="code-header">pub fn <a href="#method.new_empty_fields" class="fn">new_empty_fields</a>(len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../.. [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>If <code>len != nulls.len()</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#218">source</a><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.column" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#227">source</a><h4 class="code-header">pub fn <a href="#method.column" class="fn">column</a>(&amp;self, pos: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.num_columns" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#232">source</a><h4 class="code-header">pub fn <a href="#method.num_columns" class="fn">num_columns</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Return the number of fields [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.columns" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#237">source</a><h4 class="code-header">pub fn <a href="#method.columns" class="fn">columns</a>(&amp;self) -&gt; &amp;[<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" ti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.columns_ref" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#243">source</a><h4 class="code-header">pub fn <a href="#method.columns_ref" class="fn">columns_ref</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.column_names" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#248">source</a><h4 class="code-header">pub fn <a href="#method.column_names" class="fn">column_names</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&amp;<a class="primitive" href="https://doc [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.fields" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#259">source</a><h4 class="code-header">pub fn <a href="#method.fields" class="fn">fields</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a></h4></section></summary><div class="docblock"><p>Returns the <a href=".. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.column_by_name" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#271">source</a><h4 class="code-header">pub fn <a href="#method.column_by_name" class="fn">column_by_name</a>(&amp;self, column_name: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nigh [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_parts" class="method"><h4 class="code-header">pub fn <a href="#method.into_parts" class="fn">into_parts</a>(self) -&gt; (<a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rus [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.column" class="method"><h4 class="code-header">pub fn <a href="#method.column" class="fn">column</a>(&amp;self, pos: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.num_columns" class="method"><h4 class="code-header">pub fn <a href="#method.num_columns" class="fn">num_columns</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Return the number of fields in this struct array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.columns" class="method"><h4 class="code-header">pub fn <a href="#method.columns" class="fn">columns</a>(&amp;self) -&gt; &amp;[<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;]</h4></section></summary><div class="docblock"><p>Re [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.columns_ref" class="method"><h4 class="code-header">pub fn <a href="#method.columns_ref" class="fn">columns_ref</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.column_names" class="method"><h4 class="code-header">pub fn <a href="#method.column_names" class="fn">column_names</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></summary><div class="doc [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.fields" class="method"><h4 class="code-header">pub fn <a href="#method.fields" class="fn">fields</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a></h4></section></summary><div class="docblock"><p>Returns the <a href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields"><code>Fields</code></a>  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.column_by_name" class="method"><h4 class="code-header">pub fn <a href="#method.column_by_name" class="fn">column_by_name</a>(&amp;self, column_name: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="s [...]
 <p>Note: A schema can currently have duplicate field names, in which case
 the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#279">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-StructArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#343">source</a><a href="#impl-Array-for-StructArray" class="anchor">§</a><h3 class="code- [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#348">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array:: [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-StructArray" class="impl"><a href="#impl-Array-for-StructArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</ [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#376">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#388">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp; [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
 <p>Note: A schema can currently have duplicate field names, in which case
 the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>Panics if the name is not in the schema.</p>
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/index/trait.Index.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" hr [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/index/trait.Index.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" hr [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
-sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3CVec%3C(%26str,+Arc%3Cdyn+Array%3E)%3E%3E-for-StructArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/struct_array.rs.html#324">source</a><a href="#impl-TryFrom%3CVec%3C(%26str,+Arc%3Cdyn+Array%3E)%3E%3E-for-StructArray" class="anchor">§</a><h3 class="code-header">impl <a clas [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3CVec%3C(%26str,+Arc%3Cdyn+Array%3E)%3E%3E-for-StructArray" class="impl"><a href="#impl-TryFrom%3CVec%3C(%26str,+Arc%3Cdyn+Array%3E)%3E%3E-for-StructArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait co [...]
     values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;(&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;)&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>builds a StructArray from a vector of names and arrays.</p>
 </div></details><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'>T [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-2" class="associatedtype trait-impl"><a href="#associatedtype.Error-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-2" class="associatedtype trait-impl"><a href="#associatedtype.Error-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.TypedDictionaryArray.html b/arrow/array/array/struct.TypedDictionaryArray.html
index c4e023ca919..72188a82ed7 100644
--- a/arrow/array/array/struct.TypedDictionaryArray.html
+++ b/arrow/array/array/struct.TypedDictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` typed on its child values array"><title>TypedDictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" typ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` typed on its child values array"><title>TypedDictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" typ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div>{
     dictionary: &amp;'a <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;,
     values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>,
@@ -17,49 +17,49 @@
 <span class="kw">for </span>(maybe_val, orig) <span class="kw">in </span>typed.into_iter().zip(orig) {
     <span class="macro">assert_eq!</span>(maybe_val.unwrap(), orig)
 }</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.dictionary" class="structfield section-header"><a href="#structfield.dictionary" class="anchor field">§</a><code>dictionary: &amp;'a <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</code></span><span id="structfield.values" class="structfield section-header"><a href="#structfi [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#810">source</a><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp; [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#815">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of this <a  [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#820">source</a><a href="#impl-Array-for-TypedDictionaryArray%3 [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.dictionary" class="structfield section-header"><a href="#structfield.dictionary" class="anchor field">§</a><code>dictionary: &amp;'a <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</code></span><span id="structfield.values" class="structfield section-header"><a href="#structfi [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;'a <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of this <a href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray"><code>Typ [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href=" [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#821">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Arra [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#825">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a clas [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https: [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#853">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="h [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#869">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(& [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#220">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href=" [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="pr [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;<a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictionaryArray</a>&lt;'a, K, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at in [...]
+) -&gt; &lt;<a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictionaryArray</a>&lt;'a, K, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at in [...]
     &amp;self,
     index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;<a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictionaryArray</a>&lt;'a, K, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at in [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#795">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header" [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#803">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn  [...]
+) -&gt; &lt;<a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictionaryArray</a>&lt;'a, K, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at in [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn"> [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>( [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    <a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictionaryArray</a>&lt;'a, K, V&gt;: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class=" [...]
+    <a class="struct" href="../struct.TypedDictionaryArray.html" title="struct arrow::array::TypedDictionaryArray">TypedDictionaryArray</a>&lt;'a, K, V&gt;: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class=" [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-RefUnwindSafe-f [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Sync-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Sync-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> for <a  [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Unpin-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Unpin-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a> fo [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.TypedRunArray.html b/arrow/array/array/struct.TypedRunArray.html
index 8c8f4c0614b..359cdd2a630 100644
--- a/arrow/array/array/struct.TypedRunArray.html
+++ b/arrow/array/array/struct.TypedRunArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` typed typed on its child values array"><title>TypedRunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` typed typed on its child values array"><title>TypedRunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div>{
     run_array: &amp;'a <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;,
     values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>,
@@ -17,52 +17,52 @@
 <span class="kw">for </span>(maybe_val, orig) <span class="kw">in </span>typed.into_iter().zip(orig) {
     <span class="macro">assert_eq!</span>(maybe_val.unwrap(), orig)
 }</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.run_array" class="structfield section-header"><a href="#structfield.run_array" class="anchor field">§</a><code>run_array: &amp;'a <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</code></span><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="ancho [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.run_ends" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#544">source</a><h4 class="code-header">pub fn <a href="#method.run_ends" class="fn">run_ends</a>(&amp;self) -&gt; &amp [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#549">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of this <a href=". [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.run_array" class="method"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#554">source</a><h4 class="code-header">pub fn <a href="#method.run_array" class="fn">run_array</a>(&amp;self) -&gt; &amp;'a <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Returns the run  [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#559">source</a><a href="#impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class=" [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.run_array" class="structfield section-header"><a href="#structfield.run_array" class="anchor field">§</a><code>run_array: &amp;'a <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</code></span><span id="structfield.values" class="structfield section-header"><a href="#structfield.values" class="ancho [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.run_ends" class="method"><h4 class="code-header">pub fn <a href="#method.run_ends" class="fn">run_ends</a>(&amp;self) -&gt; &amp;'a <a class="struct" href="../../buffer/struct.RunEndBuffer.html" title="struct arrow::buffer: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of this <a href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray"><code>TypedRunArray</co [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.run_array" class="method"><h4 class="code-header">pub fn <a href="#method.run_array" class="fn">run_array</a>(&amp;self) -&gt; &amp;'a <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Returns the run array of this <a href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray" [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="../trait.Array [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#560">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html# [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#564">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="stru [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https: [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#592">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:// [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#608">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;sel [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#220">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href=" [...]
-opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-heade [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="pr [...]
+opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>. <a href="../trait.Array.html#method.is_valid">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
     &amp;self,
     logical_index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;<a class="struct" href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray">TypedRunArray</a>&lt;'a, R, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a [...]
+) -&gt; &lt;<a class="struct" href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray">TypedRunArray</a>&lt;'a, R, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a [...]
     &amp;self,
     logical_index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-) -&gt; &lt;<a class="struct" href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray">TypedRunArray</a>&lt;'a, R, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#529">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rus [...]
-    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#537">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+) -&gt; &lt;<a class="struct" href="../struct.TypedRunArray.html" title="struct arrow::array::TypedRunArray">TypedRunArray</a>&lt;'a, R, V&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html#tymethod.clone" class="fn">clone</a>(&amp;self)  [...]
+    R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>(&amp;self, f: &amp;mu [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></div><h2 id="synthetic-implementations" class="section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-RefUnwindSafe-for-TypedRunArray%3C'a,+R,+V% [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Sync-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Sync-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> for <a class="struct" [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Unpin-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Unpin-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a> for <a class="st [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/struct.UnionArray.html b/arrow/array/array/struct.UnionArray.html
index 784baaf9c91..c365d02d894 100644
--- a/arrow/array/array/struct.UnionArray.html
+++ b/arrow/array/array/struct.UnionArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of values of varying types"><title>UnionArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array of values of varying types"><title>UnionArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     type_ids: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;,
     offsets: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;&gt;,
@@ -76,7 +76,7 @@ for examples.</p>
 
 <span class="kw">let </span>value = array.value(<span class="number">2</span>).as_any().downcast_ref::&lt;Int32Array&gt;().unwrap().value(<span class="number">0</span>);
 <span class="macro">assert_eq!</span>(<span class="number">34</span>, value);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.type_ids" class="structfield section-header"><a href="#structfield.type_ids" class="anchor  [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.data_type" class="structfield section-header"><a href="#structfield.data_type" class="anchor field">§</a><code>data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></code></span><span id="structfield.type_ids" class="structfield section-header"><a href="#structfield.type_ids" class="anchor  [...]
     field_type_ids: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>],
     type_ids: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     value_offsets: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>&gt;,
@@ -99,55 +99,55 @@ Arrow implementations.</p>
 <p>In both of the cases above we are accepting <code>Buffer</code>’s which are assumed to be representing
 <code>i8</code> and <code>i32</code> values respectively.  <code>Buffer</code> objects are untyped and no attempt is made
 to ensure that the data provided is valid.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#173-178">source</a><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.try_new" class="method"><h4 class="code-header">pub fn <a href="#method.try_new" class="fn">try_new</a>(
     field_type_ids: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>],
     type_ids: <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     value_offsets: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>&gt;,
     child_arrays: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;(<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;)&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.UnionArray.html" title="struct arrow::array::UnionArray">UnionArray</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Attempts to create a new <code>UnionArray</code>, validating the inputs provided.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.child" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#231">source</a><h4 class="code-header">pub fn <a href="#method.child" class="fn">child</a>(&amp;self, type_id: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.child" class="method"><h4 class="code-header">pub fn <a href="#method.child" class="fn">child</a>(&amp;self, type_id: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title= [...]
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if the <code>type_id</code> provided is less than zero or greater than the number of types
 in the <code>Union</code>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#241">source</a><h4 class="code-header">pub fn <a href="#method.type_id" class="fn">type_id</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.htm [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method"><h4 class="code-header">pub fn <a href="#method.type_id" class="fn">type_id</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a></h4></section></summary><div class="docblock"><p>Returns the <code>type_id</code> for t [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if <code>index</code> is greater than the length of the array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.type_ids" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#246">source</a><h4 class="code-header">pub fn <a href="#method.type_ids" class="fn">type_ids</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#251">source</a><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="struct" href="../../buffer/struct.Sca [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offset" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#260">source</a><h4 class="code-header">pub fn <a href="#method.value_offset" class="fn">value_offset</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/p [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.type_ids" class="method"><h4 class="code-header">pub fn <a href="#method.type_ids" class="fn">type_ids</a>(&amp;self) -&gt; &amp;<a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;</h4></section></summary><div class="docblock"><p>Retur [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets" class="method"><h4 class="code-header">pub fn <a href="#method.offsets" class="fn">offsets</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitiv [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_offset" class="method"><h4 class="code-header">pub fn <a href="#method.value_offset" class="fn">value_offset</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the offse [...]
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>Panics if <code>index</code> is greater than the length of the array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#271">source</a><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value" class="method"><h4 class="code-header">pub fn <a href="#method.value" class="fn">value</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trai [...]
 <h5 id="panics-3"><a class="doc-anchor" href="#panics-3">§</a>Panics</h5>
 <p>Panics if index <code>i</code> is out of bounds</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.type_names" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#279">source</a><h4 class="code-header">pub fn <a href="#method.type_names" class="fn">type_names</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&amp;<a class="primitive" href="https://doc.rust-l [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#298">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.htm [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-UnionArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#382">source</a><a href="#impl-Array-for-UnionArray" class="anchor">§</a><h3 class="code-hea [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.type_names" class="method"><h4 class="code-header">pub fn <a href="#method.type_names" class="fn">type_names</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="../struct.UnionArray.html" title="struct arrow::array [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Array-for-UnionArray" class="impl"><a href="#impl-Array-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> [...]
 To check validity correctly you must check the underlying vector.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_valid" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#427">source</a><a href="#method.is_valid" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_valid" class="fn">is_valid</a>(&amp;self, _index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a c [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_valid" class="method trait-impl"><a href="#method.is_valid" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_valid" class="fn">is_valid</a>(&amp;self, _index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></ [...]
 To check validity correctly you must check the underlying vector.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#433">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4>< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Union types always return 0 null count as there is no [...]
 To get null count correctly you must check the underlying vector.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#383">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any:: [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#387">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="st [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class='docblock'>Returns the array as <a hre [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></ [...]
 Note that the underlying data can be shared by many arrays.
-This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#415">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https: [...]
+This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Optio [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
-since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/union_array.rs.html#449">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;s [...]
+since multiple arrays can share the same buffers or slices thereof.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a c [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method trait-impl"><a href="#method.logical_nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title=" [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id-1" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id-1" class="anchor">§</a><h4 class="code-header">fn <a  [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
-    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/scalar.rs.html#84">source</a><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp; [...]
+    T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.get" class="method trait-impl"><a href="#method.get" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Datum.html#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Arr [...]
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-Into%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#747-749">source</a><a href="#impl-Into%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;U&gt; for T<div  [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#757">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/trait.AnyDictionaryArray.html b/arrow/array/array/trait.AnyDictionaryArray.html
index a0001c4792c..42a0a2056b7 100644
--- a/arrow/array/array/trait.AnyDictionaryArray.html
+++ b/arrow/array/array/trait.AnyDictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` with the key type erased"><title>AnyDictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/w [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` with the key type erased"><title>AnyDictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/w [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     // Required methods
     fn <a href="#tymethod.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>;
 <span class="item-spacer"></span>    fn <a href="#tymethod.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;;
@@ -38,14 +38,14 @@ dict.extend([<span class="prelude-val">Some</span>(<span class="number">1</span>
 </span><span class="kw">let </span>actual = r.into_iter().map(Option::unwrap).collect::&lt;Vec&lt;<span class="kw">_</span>&gt;&gt;();
 <span class="macro">assert_eq!</span>(actual, <span class="kw-2">&amp;</span>[<span class="string">"1"</span>, <span class="string">"1"</span>, <span class="string">"2"</span>, <span class="string">"3"</span>, <span class="string">"2"</span>]);</code></pre></div>
 <p>See <a href="../cast/trait.AsArray.html#tymethod.as_any_dictionary_opt" title="method arrow::array::cast::AsArray::as_any_dictionary_opt"><code>AsArray::as_any_dictionary_opt</code></a> and <a href="../cast/trait.AsArray.html#method.as_any_dictionary" title="method arrow::array::cast::AsArray::as_any_dictionary"><code>AsArray::as_any_dictionary</code></a></p>
-</div></details><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.keys" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#965">source</a><h4 class="code-header">fn <a href="#tymethod.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="../trait.Array.html [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#968">source</a><h4 class="code-header">fn <a href="#tymethod.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" ti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.normalized_keys" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#978">source</a><h4 class="code-header">fn <a href="#tymethod.normalized_keys" class="fn">normalized_keys</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="primitive" href="htt [...]
+</div></details><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.keys" class="method"><h4 class="code-header">fn <a href="#tymethod.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a></h4></section></summary><div class="docblock"><p>Returns [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.values" class="method"><h4 class="code-header">fn <a href="#tymethod.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Returns [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.normalized_keys" class="method"><h4 class="code-header">fn <a href="#tymethod.normalized_keys" class="fn">normalized_keys</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section></summary><div cl [...]
 <p>The values for nulls will be arbitrary, but are guaranteed
 to be in the range <code>0..self.values.len()</code></p>
 <h5 id="panic"><a class="doc-anchor" href="#panic">§</a>Panic</h5>
 <p>Panics if <code>values.len() == 0</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.with_values" class="method"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#983">source</a><h4 class="code-header">fn <a href="#tymethod.with_values" class="fn">with_values</a>(&amp;self, values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Ar [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.with_values" class="method"><h4 class="code-header">fn <a href="#tymethod.with_values" class="fn">with_values</a>(&amp;self, values: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;) -&gt; <a class="struct" href="https://doc.r [...]
 <p>See <a href="../struct.DictionaryArray.html#method.with_values" title="method arrow::array::DictionaryArray::with_values"><code>DictionaryArray::with_values</code></a></p>
-</div></details></div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><section id="impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#986">source</a><a href="#impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K&gt; <a class="trait" href="../trait.AnyD [...]
+</div></details></div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><section id="impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="impl"><a href="#impl-AnyDictionaryArray-for-DictionaryArray%3CK%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K&gt; <a class="trait" href="../trait.AnyDictionaryArray.html" title="trait arrow::array::AnyDictionaryArray">AnyDictionaryArray</a> for <a clas [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></div><script src="../../../trait.impl/arrow_array/array/dictionary_array/trait.AnyDictionaryArray.js" data-ignore-extern-crates="arrow_array" async></script></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/trait.Array.html b/arrow/array/array/trait.Array.html
index ecdad70bb1c..aee7d4108b9 100644
--- a/arrow/array/array/trait.Array.html
+++ b/arrow/array/array/trait.Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array in the arrow columnar format"><title>Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array in the arrow columnar format"><title>Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <details class="toggle type-contents-toggle"><summary class="hideme"><span>Show 16 methods</span></summary>    // Required methods
     fn <a href="#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static);
 <span class="item-spacer"></span>    fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>;
@@ -20,7 +20,7 @@
 <span class="item-spacer"></span>    fn <a href="#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a> { ... }
 <span class="item-spacer"></span>    fn <a href="#method.is_nullable" class="fn">is_nullable</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a> { ... }
 </details>}</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An array in the <a href="https://arrow.apache.org/docs/format/Columnar.html">arrow columnar format</a></p>
-</div></details><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.as_any" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#94">source</a><h4 class="code-header">fn <a href="#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/ [...]
+</div></details><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.as_any" class="method"><h4 class="code-header">fn <a href="#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></s [...]
 downcasted to a specific implementation.</p>
 <h5 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -35,10 +35,10 @@ downcasted to a specific implementation.</p>
     .as_any()
     .downcast_ref::&lt;Int32Array&gt;()
     .expect(<span class="string">"Failed to downcast"</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.to_data" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#97">source</a><h4 class="code-header">fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></section></summary><div class="docblock"><p>Returns the underlying data of this array</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.into_data" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#102">source</a><h4 class="code-header">fn <a href="#tymethod.into_data" class="fn">into_data</a>(self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></section></summary><div class="docblock"><p>Returns the underlying data of this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.to_data" class="method"><h4 class="code-header">fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></section></summary><div class="docblock"><p>Returns the underlying data of this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.into_data" class="method"><h4 class="code-header">fn <a href="#tymethod.into_data" class="fn">into_data</a>(self) -&gt; <a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></h4></section></summary><div class="docblock"><p>Returns the underlying data of this array</p>
 <p>Unlike <a href="../trait.Array.html#tymethod.to_data" title="method arrow::array::Array::to_data"><code>Array::to_data</code></a> this consumes self, allowing it avoid unnecessary clones</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.data_type" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#116">source</a><h4 class="code-header">fn <a href="#tymethod.data_type" class="fn">data_type</a>(&amp;self) -&gt; &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a reference to  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.data_type" class="method"><h4 class="code-header">fn <a href="#tymethod.data_type" class="fn">data_type</a>(&amp;self) -&gt; &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a></h4></section></summary><div class="docblock"><p>Returns a reference to the <a href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"> [...]
 <h5 id="example-1"><a class="doc-anchor" href="#example-1">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_schema::DataType;
 <span class="kw">use </span>arrow_array::{Array, Int32Array};
@@ -46,7 +46,7 @@ downcasted to a specific implementation.</p>
 <span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);
 
 <span class="macro">assert_eq!</span>(<span class="kw-2">*</span>array.data_type(), DataType::Int32);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.slice" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#131">source</a><h4 class="code-header">fn <a href="#tymethod.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.slice" class="method"><h4 class="code-header">fn <a href="#tymethod.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.A [...]
 <h5 id="example-2"><a class="doc-anchor" href="#example-2">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, Int32Array};
 
@@ -55,21 +55,21 @@ downcasted to a specific implementation.</p>
 </span><span class="kw">let </span>array_slice = array.slice(<span class="number">1</span>, <span class="number">3</span>);
 
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>array_slice, <span class="kw-2">&amp;</span>Int32Array::from(<span class="macro">vec!</span>[<span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>]));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.len" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#144">source</a><h4 class="code-header">fn <a href="#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length (i.e., number of elements) of this array.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.len" class="method"><h4 class="code-header">fn <a href="#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length (i.e., number of elements) of this array.</p>
 <h5 id="example-3"><a class="doc-anchor" href="#example-3">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, Int32Array};
 
 <span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);
 
 <span class="macro">assert_eq!</span>(array.len(), <span class="number">5</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#157">source</a><h4 class="code-header">fn <a href="#tymethod.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether this array is empty.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.is_empty" class="method"><h4 class="code-header">fn <a href="#tymethod.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether this array is empty.</p>
 <h5 id="example-4"><a class="doc-anchor" href="#example-4">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, Int32Array};
 
 <span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);
 
 <span class="macro">assert_eq!</span>(array.is_empty(), <span class="bool-val">false</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.offset" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#174">source</a><h4 class="code-header">fn <a href="#tymethod.offset" class="fn">offset</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the offset into the underlying data used by [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.offset" class="method"><h4 class="code-header">fn <a href="#tymethod.offset" class="fn">offset</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the offset into the underlying data used by this array(-slice).
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>.</p>
 <h5 id="example-5"><a class="doc-anchor" href="#example-5">§</a>Example:</h5>
@@ -80,20 +80,20 @@ This defaults to <code>0</code>.</p>
 
 <span class="macro">assert_eq!</span>(array.offset(), <span class="number">0</span>);
 <span class="macro">assert_eq!</span>(array_slice.offset(), <span class="number">1</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.nulls" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#183">source</a><h4 class="code-header">fn <a href="#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="struct" href="../../buffer/struct.NullBuffer.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.nulls" class="method"><h4 class="code-header">fn <a href="#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;</h4></section></summary><div  [...]
 <p>The null buffer encodes the “physical” nulls of an array.
 However, some arrays can also encode nullability in their children, for example,
 <a href="../struct.DictionaryArray.html#method.values" title="method arrow::array::DictionaryArray::values"><code>DictionaryArray::values</code></a> values or <a href="../struct.RunArray.html#method.values" title="method arrow::array::RunArray::values"><code>RunArray::values</code></a>, or without a null buffer,
 such as <a href="../struct.NullArray.html" title="struct arrow::array::NullArray"><code>NullArray</code></a>. To determine if each element of such an array is logically null,
 you can use the slower <a href="../trait.Array.html#method.logical_nulls" title="method arrow::array::Array::logical_nulls"><code>Array::logical_nulls</code></a> to obtain a computed mask .</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.get_buffer_memory_size" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#277">source</a><h4 class="code-header">fn <a href="#tymethod.get_buffer_memory_size" class="fn">get_buffer_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Ret [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.get_buffer_memory_size" class="method"><h4 class="code-header">fn <a href="#tymethod.get_buffer_memory_size" class="fn">get_buffer_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the total number of bytes of memory pointed to by this array.
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.
 Note that this does not always correspond to the exact memory usage of an array,
 since multiple arrays can share the same buffers or slices thereof.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.get_array_memory_size" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#282">source</a><h4 class="code-header">fn <a href="#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Return [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.get_array_memory_size" class="method"><h4 class="code-header">fn <a href="#tymethod.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the total number of bytes of memory occupied physically by this array.
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</p>
-</div></details></div><h2 id="provided-methods" class="section-header">Provided Methods<a href="#provided-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#195">source</a><h4 class="code-header">fn <a href="#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.r [...]
+</div></details></div><h2 id="provided-methods" class="section-header">Provided Methods<a href="#provided-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="method.logical_nulls" class="method"><h4 class="code-header">fn <a href="#method.logical_nulls" class="fn">logical_nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Opti [...]
 <p>In most cases this will be the same as <a href="../trait.Array.html#tymethod.nulls" title="method arrow::array::Array::nulls"><code>Array::nulls</code></a>, except for:</p>
 <ul>
 <li><a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> where <a href="../struct.DictionaryArray.html#method.values" title="method arrow::array::DictionaryArray::values"><code>DictionaryArray::values</code></a> contains nulls</li>
@@ -102,7 +102,7 @@ includes the overhead of the data structures that contain the pointers to the va
 </ul>
 <p>In these cases a logical <a href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer"><code>NullBuffer</code></a> will be computed, encoding the logical nullability
 of these arrays, beyond what is encoded in <a href="../trait.Array.html#tymethod.nulls" title="method arrow::array::Array::nulls"><code>Array::nulls</code></a></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#220">source</a><h4 class="code-header">fn <a href="#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method"><h4 class="code-header">fn <a href="#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether the element at <code>i [...]
 <p>Note: For performance reasons, this method returns nullability solely as determined by the
 null buffer. This difference can lead to surprising results, for example, <a href="../struct.NullArray.html#method.is_null" title="method arrow::array::NullArray::is_null"><code>NullArray::is_null</code></a> always
 returns <code>false</code> as the array lacks a null buffer. Similarly <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> and <a href="../struct.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray</code></a> may
@@ -118,7 +118,7 @@ encode nullability in their children. See <a href="../trait.Array.html#method.lo
 // return false for is_null.
 </span><span class="kw">let </span>array = NullArray::new(<span class="number">1</span>);
 <span class="macro">assert_eq!</span>(array.is_null(<span class="number">0</span>), <span class="bool-val">false</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_valid" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#237">source</a><h4 class="code-header">fn <a href="#method.is_valid" class="fn">is_valid</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_valid" class="method"><h4 class="code-header">fn <a href="#method.is_valid" class="fn">is_valid</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether the element at <cod [...]
 opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_array::array::Array::is_null::is_null"><code>Self::is_null</code></a>.</p>
 <h5 id="example-7"><a class="doc-anchor" href="#example-7">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, Int32Array};
@@ -127,7 +127,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 
 <span class="macro">assert_eq!</span>(array.is_valid(<span class="number">0</span>), <span class="bool-val">true</span>);
 <span class="macro">assert_eq!</span>(array.is_valid(<span class="number">1</span>), <span class="bool-val">false</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#256">source</a><h4 class="code-header">fn <a href="#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the total number of physical null v [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method"><h4 class="code-header">fn <a href="#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the total number of physical null values in this array.</p>
 <p>Note: this method returns the physical null count, i.e. that encoded in <a href="../trait.Array.html#tymethod.nulls" title="method arrow::array::Array::nulls"><code>Array::nulls</code></a>,
 see <a href="../trait.Array.html#method.logical_nulls" title="method arrow::array::Array::logical_nulls"><code>Array::logical_nulls</code></a> for logical nullability</p>
 <h5 id="example-8"><a class="doc-anchor" href="#example-8">§</a>Example:</h5>
@@ -137,39 +137,39 @@ see <a href="../trait.Array.html#method.logical_nulls" title="method arrow::arra
 </span><span class="kw">let </span>array = Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">1</span>), <span class="prelude-val">None</span>, <span class="prelude-val">None</span>]);
 
 <span class="macro">assert_eq!</span>(array.null_count(), <span class="number">2</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_nullable" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#269">source</a><h4 class="code-header">fn <a href="#method.is_nullable" class="fn">is_nullable</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>false</code> if the array is [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_nullable" class="method"><h4 class="code-header">fn <a href="#method.is_nullable" class="fn">is_nullable</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>false</code> if the array is guaranteed to not contain any logical nulls</p>
 <p>In general this will be equivalent to <code>Array::null_count() != 0</code> but may differ in the
 presence of logical nullability, see <a href="../trait.Array.html#method.logical_nulls" title="method arrow::array::Array::logical_nulls"><code>Array::logical_nulls</code></a>.</p>
 <p>Implementations will return <code>true</code> unless they can cheaply prove no logical nulls
 are present. For example a <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> with nullable values will still return true,
 even if the nulls present in <a href="../struct.DictionaryArray.html#method.values" title="method arrow::array::DictionaryArray::values"><code>DictionaryArray::values</code></a> are not referenced by any key,
 and therefore would not appear in <a href="../trait.Array.html#method.logical_nulls" title="method arrow::array::Array::logical_nulls"><code>Array::logical_nulls</code></a>.</p>
-</div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-AsArray-for-dyn+Array" class="impl"><a class="src rightside" href="../../../src/arrow_array/cast.rs.html#842">source</a><a href="#impl-AsArray-for-dyn+Array" class="anchor">§</a><h3 class="code-header">impl <a class="trait"  [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes_opt" class="m [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_struct_opt" class="method tr [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_fixed_size_binary_opt" class="method tr [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_ [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method trait-impl"><a c [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_string_opt" class="method trait-impl"><a class [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericStringArray.html" title="type arrow::array::GenericStringArray"><code>GenericStringArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_string" class="method trait-impl"><a  [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericStringArray.html" title="type arrow::array::GenericStringArray"><code>GenericStringArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_binary_opt" class="method trait-impl"><a class="src rig [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray"><code>GenericBinaryArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_binary" class="method trait-impl"><a  [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray"><code>GenericBinaryArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_struct" class="method trait-impl"><a class="src rightsi [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_fixed_size_binary" class="method trait-impl"><a class="sr [...]
-    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_dictionary" class= [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#452">source</a><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymeth [...]
-by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-1" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" cl [...]
-sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialEq-for-dyn+Array" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#445">source</a><a href="#impl-PartialEq-for-dyn+Array" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait c [...]
+</div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-AsArray-for-dyn+Array" class="impl"><a href="#impl-AsArray-for-dyn+Array" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../cast/trait.AsArray.html" title="trait arrow::array::cast::AsArray">AsArray< [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes_opt" class="m [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_struct_opt" class="method tr [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_fixed_size_binary_opt" class="method tr [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_ [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method trait-impl"><a h [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_string_opt" class="method trait-impl"><a href= [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericStringArray.html" title="type arrow::array::GenericStringArray"><code>GenericStringArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_string" class="method trait-impl"><a  [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericStringArray.html" title="type arrow::array::GenericStringArray"><code>GenericStringArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_binary_opt" class="method trait-impl"><a href="#method. [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray"><code>GenericBinaryArray</code></a> returning <code>None</code> if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_binary" class="method trait-impl"><a  [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../type.GenericBinaryArray.html" title="type arrow::array::GenericBinaryArray"><code>GenericBinaryArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_struct" class="method trait-impl"><a href="#method.as_s [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_fixed_size_binary" class="method trait-impl"><a href="#me [...]
+    K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> panicking if not possible</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_dictionary" class= [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#tymethod.eq" class="fn">eq</a>(&amp;self, other: <a class="primitive" href="https://doc.rust-lang.o [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" class= [...]
-sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="foreign-impls" class="section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§</a></h2><details class="toggle implementors-toggle"><summary><section id="impl-Array-for-Arc%3Cdyn+Array%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#289">source</a><a href="#impl-Array-for-Arc%3Cdyn+Array%3E" class="ancho [...]
-</div><div class="impl-items"><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#290">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_array/foreigntype.array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static [...]
-    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><section id="method.as_any-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#356">source</a><a href="#method.as_any-1" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_array/foreigntype.array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a c [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialEq-for-dyn+Array" class="impl"><a href="#impl-PartialEq-for-dyn+Array" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a> for dyn <a class="trait" href="../trait.Array.html" ti [...]
+by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-1" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#263">source</a></span><a href="#method.ne-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" cl [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="foreign-impls" class="section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§</a></h2><details class="toggle implementors-toggle"><summary><section id="impl-Array-for-Arc%3Cdyn+Array%3E" class="impl"><a href="#impl-Array-for-Arc%3Cdyn+Array%3E" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.Array.html" title="t [...]
+</div><div class="impl-items"><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section><section id="method.to_data" class="method trait-impl"><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a class="fn [...]
+    T: <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>,</div></h3></section></summary><div class="impl-items"><section id="method.as_any-1" class="method trait-impl"><a href="#method.as_any-1" class="anchor">§</a><h4 class="code-header">fn <a class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section><section id="met [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#559">source</a><a href="#impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="../trait.Array.html" title="t [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for <a class="struct" href="../struct.TypedRunArray.html" t [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Array-for-GenericListArray%3COffsetSize%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#459">source</a><a href="#impl-Array-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; <a class="trait" href="../trait.Array.h [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section><section id="impl-Array-for-DictionaryArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#686">source</a><a href="#impl-Array-for-DictionaryArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow: [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section><section id="impl-Array-for-GenericByteArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#427">source</a><a href="#impl-Array-for-GenericByteArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array. [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-Array-for-PrimitiveArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#988">source</a><a href="#impl-Array-for-PrimitiveArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow:: [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section><section id="impl-Array-for-RunArray%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#305">source</a><a href="#impl-Array-for-RunArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::arr [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Array-for-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-Array-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for <a class="struct" href="../struct.GenericLi [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section><section id="impl-Array-for-DictionaryArray%3CT%3E" class="impl"><a href="#impl-Array-for-DictionaryArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for <a class="struct" href="../struct.DictionaryArray.html" title="struct arr [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section><section id="impl-Array-for-GenericByteArray%3CT%3E" class="impl"><a href="#impl-Array-for-GenericByteArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for <a class="struct" href="../struct.GenericB [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-Array-for-PrimitiveArray%3CT%3E" class="impl"><a href="#impl-Array-for-PrimitiveArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for <a class="struct" href="../struct.PrimitiveArray.html" title="struct arro [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section><section id="impl-Array-for-RunArray%3CT%3E" class="impl"><a href="#impl-Array-for-RunArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a> for <a class="struct" href="../struct.RunArray.html" title="struct arrow:: [...]
     T: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></h3></section></div><script src="../../../trait.impl/arrow_array/array/trait.Array.js" data-ignore-extern-crates="arrow_array,alloc" async></script></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/array/trait.ArrayAccessor.html b/arrow/array/array/trait.ArrayAccessor.html
index 1e5b1c411db..16d1c7417ff 100644
--- a/arrow/array/array/trait.ArrayAccessor.html
+++ b/arrow/array/array/trait.ArrayAccessor.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A generic trait for accessing the values of an `Array`"><title>ArrayAccessor in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A generic trait for accessing the values of an `Array`"><title>ArrayAccessor in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     type <a href="#associatedtype.Item" class="associatedtype">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>;
 
     // Required methods
@@ -11,22 +11,22 @@
 within the bounds <code>0..Array::len</code>, including for null indexes where <a href="../trait.Array.html#method.is_null" title="method arrow::array::Array::is_null"><code>Array::is_null</code></a> is true.</p>
 <p>The value at null indexes is unspecified, and implementations must not rely on a specific
 value such as <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" title="associated function core::default::Default::default"><code>Default::default</code></a> being returned, however, it must not be undefined</p>
-</div></details><h2 id="required-associated-types" class="section-header">Required Associated Types<a href="#required-associated-types" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedtype.Item" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#432">source</a><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a>: <a class="trait" href="https://doc.rust-l [...]
-</div></details></div><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.value" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#437">source</a><h4 class="code-header">fn <a href="#tymethod.value" class="fn">value</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/n [...]
+</div></details><h2 id="required-associated-types" class="section-header">Required Associated Types<a href="#required-associated-types" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedtype.Item" class="method"><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> +  [...]
+</div></details></div><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.value" class="method"><h4 class="code-header">fn <a href="#tymethod.value" class="fn">value</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; Self::<a class="associatedtype" href=". [...]
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if the value is outside the bounds of the array</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.value_unchecked" class="method"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#442">source</a><h4 class="code-header">unsafe fn <a href="#tymethod.value_unchecked" class="fn">value_unchecked</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; Self::<a class="associatedtype" href="../trait.ArrayAccess [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.value_unchecked" class="method"><h4 class="code-header">unsafe fn <a href="#tymethod.value_unchecked" class="fn">value_unchecked</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; Self::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4> [...]
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>Caller is responsible for ensuring that the index is within the bounds of the array</p>
-</div></details></div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><details class="toggle implementors-toggle"><summary><section id="impl-ArrayAccessor-for-FixedSizeListArray" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#422">source</a><a href="#impl-ArrayAccessor-for-FixedSizeListArray" class="anchor">§</a><h3 class="code-header">impl <a cl [...]
+</div></details></div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><details class="toggle implementors-toggle"><summary><section id="impl-ArrayAccessor-for-FixedSizeListArray" class="impl"><a href="#impl-ArrayAccessor-for-FixedSizeListArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>  [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><section id="associatedtype.Item-7" class="associatedtype trait-impl"><a href="#associatedtype.Item-7" class="anchor">§</a><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html"  [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><section id="associatedtype.Item-7" class="associatedtype trait-impl"><a href="#associatedtype.Item-7" class="anchor">§</a><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html"  [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><section id="associatedtype.Item-9" class="associatedtype trait-impl"><a href="#associatedtype.Item-9" class="anchor">§</a><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a> = &amp;'a &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" ti [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Def [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><section id="associatedtype.Item-9" class="associatedtype trait-impl"><a href="#associatedtype.Item-9" class="anchor">§</a><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a> = &amp;'a &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" ti [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><section id="associatedtype.Item-10" class="associatedtype trait-impl"><a href="#associatedtype.Item-10" class="anchor">§</a><h4 class="code-header">type <a href="#associatedtype.Item" class="associatedtype">Item</a> = &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiv [...]
\ No newline at end of file
diff --git a/arrow/array/array/trait.ArrowPrimitiveType.html b/arrow/array/array/trait.ArrowPrimitiveType.html
index 3ebc2cee336..90374a51211 100644
--- a/arrow/array/array/trait.ArrowPrimitiveType.html
+++ b/arrow/array/array/trait.ArrowPrimitiveType.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Trait bridging the dynamic-typed nature of Arrow (via `DataType`) with the static-typed nature of rust types (`ArrowNativeType`) for all types that implement `ArrowNativeType`."><title>ArrowPrimitiveType in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Trait bridging the dynamic-typed nature of Arrow (via `DataType`) with the static-typed nature of rust types (`ArrowNativeType`) for all types that implement `ArrowNativeType`."><title>ArrowPrimitiveType in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     type <a href="#associatedtype.Native" class="associatedtype">Native</a>: <a class="trait" href="../../datatypes/trait.ArrowNativeTypeOp.html" title="trait arrow::datatypes::ArrowNativeTypeOp">ArrowNativeTypeOp</a>;
 
     const <a href="#associatedconstant.DATA_TYPE" class="constant">DATA_TYPE</a>: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>;
@@ -9,9 +9,9 @@
 <span class="item-spacer"></span>    fn <a href="#method.default_value" class="fn">default_value</a>() -&gt; Self::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a> { ... }
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Trait bridging the dynamic-typed nature of Arrow (via <a href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a>) with the
 static-typed nature of rust types (<a href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType"><code>ArrowNativeType</code></a>) for all types that implement <a href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType"><code>ArrowNativeType</code></a>.</p>
-</div></details><h2 id="required-associated-types" class="section-header">Required Associated Types<a href="#required-associated-types" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedtype.Native" class="method"><a class="src rightside" href="../../../src/arrow_array/types.rs.html#54">source</a><h4 class="code-header">type <a href="#associatedtype.Native" class="associatedtype">Native</a>: <a class="trait" href="../../datatypes/t [...]
-</div></details></div><h2 id="required-associated-consts" class="section-header">Required Associated Constants<a href="#required-associated-consts" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedconstant.DATA_TYPE" class="method"><a class="src rightside" href="../../../src/arrow_array/types.rs.html#57">source</a><h4 class="code-header">const <a href="#associatedconstant.DATA_TYPE" class="constant">DATA_TYPE</a>: <a class="enum"  [...]
-</div></details></div><h2 id="provided-methods" class="section-header">Provided Methods<a href="#provided-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="method.get_byte_width" class="method"><a class="src rightside" href="../../../src/arrow_array/types.rs.html#60">source</a><h4 class="code-header">fn <a href="#method.get_byte_width" class="fn">get_byte_width</a>() -&gt; <a class="primitive" href="https://doc.rust-la [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.default_value" class="method"><a class="src rightside" href="../../../src/arrow_array/types.rs.html#67">source</a><h4 class="code-header">fn <a href="#method.default_value" class="fn">default_value</a>() -&gt; Self::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a></h4></section></su [...]
+</div></details><h2 id="required-associated-types" class="section-header">Required Associated Types<a href="#required-associated-types" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedtype.Native" class="method"><h4 class="code-header">type <a href="#associatedtype.Native" class="associatedtype">Native</a>: <a class="trait" href="../../datatypes/trait.ArrowNativeTypeOp.html" title="trait arrow::datatypes::ArrowNativeTypeOp">Arrow [...]
+</div></details></div><h2 id="required-associated-consts" class="section-header">Required Associated Constants<a href="#required-associated-consts" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedconstant.DATA_TYPE" class="method"><h4 class="code-header">const <a href="#associatedconstant.DATA_TYPE" class="constant">DATA_TYPE</a>: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">Da [...]
+</div></details></div><h2 id="provided-methods" class="section-header">Provided Methods<a href="#provided-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="method.get_byte_width" class="method"><h4 class="code-header">fn <a href="#method.get_byte_width" class="fn">get_byte_width</a>() -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div clas [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.default_value" class="method"><h4 class="code-header">fn <a href="#method.default_value" class="fn">default_value</a>() -&gt; Self::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a></h4></section></summary><div class="docblock"><p>Returns a default value of this primitive type.</p>
 <p>This is useful for aggregate array ops like <code>sum()</code>, <code>mean()</code>.</p>
-</div></details></div><h2 id="object-safety" class="section-header">Object Safety<a href="#object-safety" class="anchor">§</a></h2><div class="object-safety-info">This trait is <b>not</b> <a href="https://doc.rust-lang.org/nightly/reference/items/traits.html#object-safety">object safe</a>.</div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><details class="toggle implementors-toggle"><summary><section  [...]
\ No newline at end of file
+</div></details></div><h2 id="object-safety" class="section-header">Object Safety<a href="#object-safety" class="anchor">§</a></h2><div class="object-safety-info">This trait is <b>not</b> <a href="https://doc.rust-lang.org/nightly/reference/items/traits.html#object-safety">object safe</a>.</div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><details class="toggle implementors-toggle"><summary><section  [...]
\ No newline at end of file
diff --git a/arrow/array/array/trait.OffsetSizeTrait.html b/arrow/array/array/trait.OffsetSizeTrait.html
index e3d7427f560..2548df7f441 100644
--- a/arrow/array/array/trait.OffsetSizeTrait.html
+++ b/arrow/array/array/trait.OffsetSizeTrait.html
@@ -1,10 +1,10 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A type that can be used within a variable-size array to encode offset information"><title>OffsetSizeTrait in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link re [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A type that can be used within a variable-size array to encode offset information"><title>OffsetSizeTrait in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link re [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     const <a href="#associatedconstant.IS_LARGE" class="constant">IS_LARGE</a>: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>;
     const <a href="#associatedconstant.PREFIX" class="constant">PREFIX</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>;
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A type that can be used within a variable-size array to encode offset information</p>
 <p>See <a href="../type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a>, <a href="../type.LargeListArray.html" title="type arrow::array::LargeListArray"><code>LargeListArray</code></a>, <a href="../type.BinaryArray.html" title="type arrow::array::BinaryArray"><code>BinaryArray</code></a>, <a href="../type.LargeBinaryArray.html" title="type arrow::array::LargeBinaryArray"><code>LargeBinaryArray</code></a>,
 <a href="../type.StringArray.html" title="type arrow::array::StringArray"><code>StringArray</code></a> and <a href="../type.LargeStringArray.html" title="type arrow::array::LargeStringArray"><code>LargeStringArray</code></a></p>
-</div></details><h2 id="required-associated-consts" class="section-header">Required Associated Constants<a href="#required-associated-consts" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedconstant.IS_LARGE" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#42">source</a><h4 class="code-header">const <a href="#associatedconstant.IS_LARGE" class="constant">IS_LARGE</a>: <a class="prim [...]
-</div></details><details class="toggle" open><summary><section id="associatedconstant.PREFIX" class="method"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#44">source</a><h4 class="code-header">const <a href="#associatedconstant.PREFIX" class="constant">PREFIX</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section></summary><div class="docblock"><p>Prefix for the offset size</p>
-</div></details></div><h2 id="object-safety" class="section-header">Object Safety<a href="#object-safety" class="anchor">§</a></h2><div class="object-safety-info">This trait is <b>not</b> <a href="https://doc.rust-lang.org/nightly/reference/items/traits.html#object-safety">object safe</a>.</div><h2 id="foreign-impls" class="section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§</a></h2><details class="toggle implementors-toggle"><summary><section id="im [...]
\ No newline at end of file
+</div></details><h2 id="required-associated-consts" class="section-header">Required Associated Constants<a href="#required-associated-consts" class="anchor">§</a></h2><div class="methods"><details class="toggle" open><summary><section id="associatedconstant.IS_LARGE" class="method"><h4 class="code-header">const <a href="#associatedconstant.IS_LARGE" class="constant">IS_LARGE</a>: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section> [...]
+</div></details><details class="toggle" open><summary><section id="associatedconstant.PREFIX" class="method"><h4 class="code-header">const <a href="#associatedconstant.PREFIX" class="constant">PREFIX</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section></summary><div class="docblock"><p>Prefix for the offset size</p>
+</div></details></div><h2 id="object-safety" class="section-header">Object Safety<a href="#object-safety" class="anchor">§</a></h2><div class="object-safety-info">This trait is <b>not</b> <a href="https://doc.rust-lang.org/nightly/reference/items/traits.html#object-safety">object safe</a>.</div><h2 id="foreign-impls" class="section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§</a></h2><details class="toggle implementors-toggle"><summary><section id="im [...]
\ No newline at end of file
diff --git a/arrow/array/array/type.ArrayRef.html b/arrow/array/array/type.ArrayRef.html
index b041b2ea3e2..6ea64287fce 100644
--- a/arrow/array/array/type.ArrayRef.html
+++ b/arrow/array/array/type.ArrayRef.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A reference-counted reference to a generic `Array`"><title>ArrayRef in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2 [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A reference-counted reference to a generic `Array`"><title>ArrayRef in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2 [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct ArrayRef {
     ptr: <a class="struct" href="https://doc.rust-lang.org/nightly/core/ptr/non_null/struct.NonNull.html" title="struct core::ptr::non_null::NonNull">NonNull</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.ArcInner.html" title="struct alloc::sync::ArcInner">ArcInner</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;&gt;,
     phantom: <a class="struct" href="https://doc.rust-lang.org/nightly/core/marker/struct.PhantomData.html" title="struct core::marker::PhantomData">PhantomData</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.ArcInner.html" title="struct alloc::sync::ArcInner">ArcInner</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;&gt;,
diff --git a/arrow/array/array/type.BinaryArray.html b/arrow/array/array/type.BinaryArray.html
index a7360a25565..a90f6805f68 100644
--- a/arrow/array/array/type.BinaryArray.html
+++ b/arrow/array/array/type.BinaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericBinaryArray` of `[u8]` using `i32` offsets"><title>BinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericBinaryArray` of `[u8]` using `i32` offsets"><title>BinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>The byte length of each element is represented by an i32.</p>
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Create a BinaryArray from a vector of byte slices.</p>
diff --git a/arrow/array/array/type.Date32Array.html b/arrow/array/array/type.Date32Array.html
index 105255b9def..876bb9073df 100644
--- a/arrow/array/array/type.Date32Array.html
+++ b/arrow/array/array/type.Date32Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of days since UNIX epoch stored as `i32`"><title>Date32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of days since UNIX epoch stored as `i32`"><title>Date32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/date/struct.NaiveDate.html" title="struct chrono::naive::date::NaiveDate"><code>chrono::NaiveDate</code></a> type and can hold
 values such as <code>2018-11-13</code></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Date32Array {
diff --git a/arrow/array/array/type.Date64Array.html b/arrow/array/array/type.Date64Array.html
index 6864e40a897..e16e2ec5b34 100644
--- a/arrow/array/array/type.Date64Array.html
+++ b/arrow/array/array/type.Date64Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of milliseconds since UNIX epoch stored as `i64`"><title>Date64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of milliseconds since UNIX epoch stored as `i64`"><title>Date64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/date/struct.NaiveDate.html" title="struct chrono::naive::date::NaiveDate"><code>chrono::NaiveDate</code></a> type and can hold
 values such as <code>2018-11-13</code></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Date64Array {
diff --git a/arrow/array/array/type.Decimal128Array.html b/arrow/array/array/type.Decimal128Array.html
index 88c48b1466e..f4b150e29cb 100644
--- a/arrow/array/array/type.Decimal128Array.html
+++ b/arrow/array/array/type.Decimal128Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of 128-bit fixed point decimals"><title>Decimal128Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of 128-bit fixed point decimals"><title>Decimal128Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Decimal256Array.html b/arrow/array/array/type.Decimal256Array.html
index ab7ce0f4c53..d6c263ce7d5 100644
--- a/arrow/array/array/type.Decimal256Array.html
+++ b/arrow/array/array/type.Decimal256Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of 256-bit fixed point decimals"><title>Decimal256Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of 256-bit fixed point decimals"><title>Decimal256Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.DurationMicrosecondArray.html b/arrow/array/array/type.DurationMicrosecondArray.html
index 30607269a8c..b8d59cbf291 100644
--- a/arrow/array/array/type.DurationMicrosecondArray.html
+++ b/arrow/array/array/type.DurationMicrosecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in microseconds"><title>DurationMicrosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in microseconds"><title>DurationMicrosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationMicrosecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
diff --git a/arrow/array/array/type.DurationMillisecondArray.html b/arrow/array/array/type.DurationMillisecondArray.html
index 8f66192d795..6d673ae57d9 100644
--- a/arrow/array/array/type.DurationMillisecondArray.html
+++ b/arrow/array/array/type.DurationMillisecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in milliseconds"><title>DurationMillisecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in milliseconds"><title>DurationMillisecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationMillisecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
diff --git a/arrow/array/array/type.DurationNanosecondArray.html b/arrow/array/array/type.DurationNanosecondArray.html
index b14bb45c3e1..00c64da356c 100644
--- a/arrow/array/array/type.DurationNanosecondArray.html
+++ b/arrow/array/array/type.DurationNanosecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in nanoseconds"><title>DurationNanosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in nanoseconds"><title>DurationNanosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationNanosecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
diff --git a/arrow/array/array/type.DurationSecondArray.html b/arrow/array/array/type.DurationSecondArray.html
index d905fbec040..4504822c160 100644
--- a/arrow/array/array/type.DurationSecondArray.html
+++ b/arrow/array/array/type.DurationSecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in seconds"><title>DurationSecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of elapsed durations in seconds"><title>DurationSecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationSecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
diff --git a/arrow/array/array/type.Float16Array.html b/arrow/array/array/type.Float16Array.html
index ce7764f7f77..7a3bfc171f3 100644
--- a/arrow/array/array/type.Float16Array.html
+++ b/arrow/array/array/type.Float16Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `f16`"><title>Float16Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `f16`"><title>Float16Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Float32Array.html b/arrow/array/array/type.Float32Array.html
index dc712a7694f..242154fd040 100644
--- a/arrow/array/array/type.Float32Array.html
+++ b/arrow/array/array/type.Float32Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `f32`"><title>Float32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `f32`"><title>Float32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Float64Array.html b/arrow/array/array/type.Float64Array.html
index 07d6852a4b4..a40d0878b66 100644
--- a/arrow/array/array/type.Float64Array.html
+++ b/arrow/array/array/type.Float64Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `f64`"><title>Float64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `f64`"><title>Float64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.GenericBinaryArray.html b/arrow/array/array/type.GenericBinaryArray.html
index d54dc6d539d..cb3aff47ac9 100644
--- a/arrow/array/array/type.GenericBinaryArray.html
+++ b/arrow/array/array/type.GenericBinaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericBinaryArray` for storing `[u8]`"><title>GenericBinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericBinaryArray` for storing `[u8]`"><title>GenericBinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct GenericBinaryArray&lt;OffsetSize&gt; {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     value_offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt; as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../dataty [...]
diff --git a/arrow/array/array/type.GenericStringArray.html b/arrow/array/array/type.GenericStringArray.html
index fd196dfb0e1..ba52d0afa27 100644
--- a/arrow/array/array/type.GenericStringArray.html
+++ b/arrow/array/array/type.GenericStringArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericByteArray` for storing `str`"><title>GenericStringArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericByteArray` for storing `str`"><title>GenericStringArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct GenericStringArray&lt;OffsetSize&gt; {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     value_offsets: <a class="struct" href="../../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt; as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../dataty [...]
diff --git a/arrow/array/array/type.Int16Array.html b/arrow/array/array/type.Int16Array.html
index ac9773dec83..5e5af8013bd 100644
--- a/arrow/array/array/type.Int16Array.html
+++ b/arrow/array/array/type.Int16Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i16`"><title>Int16Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i16`"><title>Int16Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Int16DictionaryArray.html b/arrow/array/array/type.Int16DictionaryArray.html
index 9a85072beac..7fd27b61f6d 100644
--- a/arrow/array/array/type.Int16DictionaryArray.html
+++ b/arrow/array/array/type.Int16DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i16`"><title>Int16DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i16`"><title>Int16DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int16DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.Int16RunArray.html b/arrow/array/array/type.Int16RunArray.html
index 16821544be6..4e7861d0d34 100644
--- a/arrow/array/array/type.Int16RunArray.html
+++ b/arrow/array/array/type.Int16RunArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` with `i16` run ends"><title>Int16RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` with `i16` run ends"><title>Int16RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int16RunArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.Int32Array.html b/arrow/array/array/type.Int32Array.html
index 6d5832fb9e2..17e135f4fe3 100644
--- a/arrow/array/array/type.Int32Array.html
+++ b/arrow/array/array/type.Int32Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i32`"><title>Int32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i32`"><title>Int32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Int32DictionaryArray.html b/arrow/array/array/type.Int32DictionaryArray.html
index a4171b9a8b5..64b552fba20 100644
--- a/arrow/array/array/type.Int32DictionaryArray.html
+++ b/arrow/array/array/type.Int32DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i32`"><title>Int32DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i32`"><title>Int32DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int32DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.Int32RunArray.html b/arrow/array/array/type.Int32RunArray.html
index 937a3616cae..e3f6ebdc115 100644
--- a/arrow/array/array/type.Int32RunArray.html
+++ b/arrow/array/array/type.Int32RunArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` with `i32` run ends"><title>Int32RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` with `i32` run ends"><title>Int32RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int32RunArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.Int64Array.html b/arrow/array/array/type.Int64Array.html
index f4b2ef8087e..12ef5e633aa 100644
--- a/arrow/array/array/type.Int64Array.html
+++ b/arrow/array/array/type.Int64Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i64`"><title>Int64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i64`"><title>Int64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Int64DictionaryArray.html b/arrow/array/array/type.Int64DictionaryArray.html
index d010d981b78..ab9d677b73b 100644
--- a/arrow/array/array/type.Int64DictionaryArray.html
+++ b/arrow/array/array/type.Int64DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i64`"><title>Int64DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i64`"><title>Int64DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int64DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.Int64RunArray.html b/arrow/array/array/type.Int64RunArray.html
index d782012b080..b8183e161a2 100644
--- a/arrow/array/array/type.Int64RunArray.html
+++ b/arrow/array/array/type.Int64RunArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` with `i64` run ends"><title>Int64RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `RunArray` with `i64` run ends"><title>Int64RunArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int64RunArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.Int8Array.html b/arrow/array/array/type.Int8Array.html
index 51ba5f643a6..77a7d24ceb3 100644
--- a/arrow/array/array/type.Int8Array.html
+++ b/arrow/array/array/type.Int8Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i8`"><title>Int8Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `i8`"><title>Int8Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Int8DictionaryArray.html b/arrow/array/array/type.Int8DictionaryArray.html
index 437b100228b..7b6cf4d211b 100644
--- a/arrow/array/array/type.Int8DictionaryArray.html
+++ b/arrow/array/array/type.Int8DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i8`"><title>Int8DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `i8`"><title>Int8DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: Int8DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.IntervalDayTimeArray.html b/arrow/array/array/type.IntervalDayTimeArray.html
index f1b33113ee2..d13160779a0 100644
--- a/arrow/array/array/type.IntervalDayTimeArray.html
+++ b/arrow/array/array/type.IntervalDayTimeArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of “calendar” intervals in days and milliseconds"><title>IntervalDayTimeArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preloa [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of “calendar” intervals in days and milliseconds"><title>IntervalDayTimeArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preloa [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>See <a href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType"><code>IntervalDayTimeType</code></a> for details on representation and caveats.</p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalDayTimeArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
diff --git a/arrow/array/array/type.IntervalMonthDayNanoArray.html b/arrow/array/array/type.IntervalMonthDayNanoArray.html
index df624598e4b..89ae0059f55 100644
--- a/arrow/array/array/type.IntervalMonthDayNanoArray.html
+++ b/arrow/array/array/type.IntervalMonthDayNanoArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of “calendar” intervals in  months, days, and nanoseconds."><title>IntervalMonthDayNanoArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><l [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of “calendar” intervals in  months, days, and nanoseconds."><title>IntervalMonthDayNanoArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><l [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>See <a href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType"><code>IntervalMonthDayNanoType</code></a> for details on representation and caveats.</p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalMonthDayNanoArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
diff --git a/arrow/array/array/type.IntervalYearMonthArray.html b/arrow/array/array/type.IntervalYearMonthArray.html
index 5a7a68343b7..d90765936fb 100644
--- a/arrow/array/array/type.IntervalYearMonthArray.html
+++ b/arrow/array/array/type.IntervalYearMonthArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of “calendar” intervals in months"><title>IntervalYearMonthArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of “calendar” intervals in months"><title>IntervalYearMonthArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>See <a href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType"><code>IntervalYearMonthType</code></a> for details on representation and caveats.</p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalYearMonthArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
diff --git a/arrow/array/array/type.LargeBinaryArray.html b/arrow/array/array/type.LargeBinaryArray.html
index 009f5f345ac..5fdaa1139cd 100644
--- a/arrow/array/array/type.LargeBinaryArray.html
+++ b/arrow/array/array/type.LargeBinaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericBinaryArray` of `[u8]` using `i64` offsets"><title>LargeBinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericBinaryArray` of `[u8]` using `i64` offsets"><title>LargeBinaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Create a LargeBinaryArray from a vector of byte slices.</p>
 
diff --git a/arrow/array/array/type.LargeListArray.html b/arrow/array/array/type.LargeListArray.html
index 81834136518..4d5836b9f0f 100644
--- a/arrow/array/array/type.LargeListArray.html
+++ b/arrow/array/array/type.LargeListArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericListArray` of variable size lists, storing offsets as `i64`."><title>LargeListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericListArray` of variable size lists, storing offsets as `i64`."><title>LargeListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct LargeListArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
diff --git a/arrow/array/array/type.LargeStringArray.html b/arrow/array/array/type.LargeStringArray.html
index 0450923a51f..c1806be2aaa 100644
--- a/arrow/array/array/type.LargeStringArray.html
+++ b/arrow/array/array/type.LargeStringArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericStringArray` of `str` using `i64` offsets"><title>LargeStringArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericStringArray` of `str` using `i64` offsets"><title>LargeStringArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.ListArray.html b/arrow/array/array/type.ListArray.html
index 6abcda37033..ea7d6322427 100644
--- a/arrow/array/array/type.ListArray.html
+++ b/arrow/array/array/type.ListArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericListArray` of variable size lists, storing offsets as `i32`."><title>ListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericListArray` of variable size lists, storing offsets as `i32`."><title>ListArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct ListArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
diff --git a/arrow/array/array/type.StringArray.html b/arrow/array/array/type.StringArray.html
index dd733758534..aac2316a417 100644
--- a/arrow/array/array/type.StringArray.html
+++ b/arrow/array/array/type.StringArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericStringArray` of `str` using `i32` offsets"><title>StringArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/w [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `GenericStringArray` of `str` using `i32` offsets"><title>StringArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/w [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.Time32MillisecondArray.html b/arrow/array/array/type.Time32MillisecondArray.html
index 27ef0ce0449..5358822655d 100644
--- a/arrow/array/array/type.Time32MillisecondArray.html
+++ b/arrow/array/array/type.Time32MillisecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of milliseconds since midnight stored as `i32`"><title>Time32MillisecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preloa [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of milliseconds since midnight stored as `i32`"><title>Time32MillisecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preloa [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00.123</code></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Time32MillisecondArray {
diff --git a/arrow/array/array/type.Time32SecondArray.html b/arrow/array/array/type.Time32SecondArray.html
index 9ef93fda5a0..82cf9e47d56 100644
--- a/arrow/array/array/type.Time32SecondArray.html
+++ b/arrow/array/array/type.Time32SecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of seconds since midnight stored as `i32`"><title>Time32SecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of seconds since midnight stored as `i32`"><title>Time32SecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00</code></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Time32SecondArray {
diff --git a/arrow/array/array/type.Time64MicrosecondArray.html b/arrow/array/array/type.Time64MicrosecondArray.html
index 19e7794b37f..8b309ba6db0 100644
--- a/arrow/array/array/type.Time64MicrosecondArray.html
+++ b/arrow/array/array/type.Time64MicrosecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of microseconds since midnight stored as `i64`"><title>Time64MicrosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preloa [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of microseconds since midnight stored as `i64`"><title>Time64MicrosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preloa [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00.123456</code></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Time64MicrosecondArray {
diff --git a/arrow/array/array/type.Time64NanosecondArray.html b/arrow/array/array/type.Time64NanosecondArray.html
index 97899f5b56a..c6d6b31c831 100644
--- a/arrow/array/array/type.Time64NanosecondArray.html
+++ b/arrow/array/array/type.Time64NanosecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of nanoseconds since midnight stored as `i64`"><title>Time64NanosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of nanoseconds since midnight stored as `i64`"><title>Time64NanosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00.123456789</code></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Time64NanosecondArray {
diff --git a/arrow/array/array/type.TimestampMicrosecondArray.html b/arrow/array/array/type.TimestampMicrosecondArray.html
index 44312b35efa..72c1c5be5e9 100644
--- a/arrow/array/array/type.TimestampMicrosecondArray.html
+++ b/arrow/array/array/type.TimestampMicrosecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of microseconds since UNIX epoch stored as `i64`"><title>TimestampMicrosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of microseconds since UNIX epoch stored as `i64`"><title>TimestampMicrosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>See examples for <a href="../type.TimestampSecondArray.html" title="type arrow::array::TimestampSecondArray"><code>TimestampSecondArray</code></a></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct TimestampMicrosecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
diff --git a/arrow/array/array/type.TimestampMillisecondArray.html b/arrow/array/array/type.TimestampMillisecondArray.html
index 52f2f69883c..8f7ee5de062 100644
--- a/arrow/array/array/type.TimestampMillisecondArray.html
+++ b/arrow/array/array/type.TimestampMillisecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of milliseconds since UNIX epoch stored as `i64`"><title>TimestampMillisecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of milliseconds since UNIX epoch stored as `i64`"><title>TimestampMillisecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>See examples for <a href="../type.TimestampSecondArray.html" title="type arrow::array::TimestampSecondArray"><code>TimestampSecondArray</code></a></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct TimestampMillisecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
diff --git a/arrow/array/array/type.TimestampNanosecondArray.html b/arrow/array/array/type.TimestampNanosecondArray.html
index 2ed03f6a1c6..34486c781f7 100644
--- a/arrow/array/array/type.TimestampNanosecondArray.html
+++ b/arrow/array/array/type.TimestampNanosecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of nanoseconds since UNIX epoch stored as `i64`"><title>TimestampNanosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pre [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of nanoseconds since UNIX epoch stored as `i64`"><title>TimestampNanosecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pre [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>See examples for <a href="../type.TimestampSecondArray.html" title="type arrow::array::TimestampSecondArray"><code>TimestampSecondArray</code></a></p>
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct TimestampNanosecondArray {
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
diff --git a/arrow/array/array/type.TimestampSecondArray.html b/arrow/array/array/type.TimestampSecondArray.html
index 762b2af51bf..df384d4afc5 100644
--- a/arrow/array/array/type.TimestampSecondArray.html
+++ b/arrow/array/array/type.TimestampSecondArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of seconds since UNIX epoch stored as `i64`"><title>TimestampSecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of seconds since UNIX epoch stored as `i64`"><title>TimestampSecondArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/datetime/struct.DateTime.html" title="struct chrono::datetime::DateTime"><code>chrono::DateTime</code></a> type and can hold
 values such as <code>1970-05-09 14:25:11 +01:00</code></p>
 <p>See also <a href="../../datatypes/enum.DataType.html#variant.Timestamp" title="variant arrow::datatypes::DataType::Timestamp"><code>Timestamp</code></a>.</p>
diff --git a/arrow/array/array/type.UInt16Array.html b/arrow/array/array/type.UInt16Array.html
index b0e08b249b3..94a8405007e 100644
--- a/arrow/array/array/type.UInt16Array.html
+++ b/arrow/array/array/type.UInt16Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u16`"><title>UInt16Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u16`"><title>UInt16Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.UInt16DictionaryArray.html b/arrow/array/array/type.UInt16DictionaryArray.html
index 8caa4a706a7..4487d381887 100644
--- a/arrow/array/array/type.UInt16DictionaryArray.html
+++ b/arrow/array/array/type.UInt16DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u16`"><title>UInt16DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u16`"><title>UInt16DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: UInt16DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.UInt32Array.html b/arrow/array/array/type.UInt32Array.html
index eb5dce534d7..f3beadad925 100644
--- a/arrow/array/array/type.UInt32Array.html
+++ b/arrow/array/array/type.UInt32Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u32`"><title>UInt32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u32`"><title>UInt32Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.UInt32DictionaryArray.html b/arrow/array/array/type.UInt32DictionaryArray.html
index ccf42b393f3..35b7cdf8ee2 100644
--- a/arrow/array/array/type.UInt32DictionaryArray.html
+++ b/arrow/array/array/type.UInt32DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u32`"><title>UInt32DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u32`"><title>UInt32DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: UInt32DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.UInt64Array.html b/arrow/array/array/type.UInt64Array.html
index b0f746e3d3f..0cd6b29265f 100644
--- a/arrow/array/array/type.UInt64Array.html
+++ b/arrow/array/array/type.UInt64Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u64`"><title>UInt64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u64`"><title>UInt64Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.UInt64DictionaryArray.html b/arrow/array/array/type.UInt64DictionaryArray.html
index 9c24607d3a3..b88cd7b964c 100644
--- a/arrow/array/array/type.UInt64DictionaryArray.html
+++ b/arrow/array/array/type.UInt64DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u64`"><title>UInt64DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u64`"><title>UInt64DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: UInt64DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/array/type.UInt8Array.html b/arrow/array/array/type.UInt8Array.html
index c904830e395..d3f33605c51 100644
--- a/arrow/array/array/type.UInt8Array.html
+++ b/arrow/array/array/type.UInt8Array.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u8`"><title>UInt8Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=".. [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `PrimitiveArray` of `u8`"><title>UInt8Array in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=".. [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
diff --git a/arrow/array/array/type.UInt8DictionaryArray.html b/arrow/array/array/type.UInt8DictionaryArray.html
index a229e4a2aa8..efc2e7ba7dd 100644
--- a/arrow/array/array/type.UInt8DictionaryArray.html
+++ b/arrow/array/array/type.UInt8DictionaryArray.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u8`"><title>UInt8DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" c [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `DictionaryArray` indexed by `u8`"><title>UInt8DictionaryArray in arrow::array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" c [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="example-using-collect"><a class="doc-anchor" href="#example-using-collect">§</a>Example: Using <code>collect</code></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>array: UInt8DictionaryArray = <span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>].into_iter().collect();
diff --git a/arrow/array/builder/fn.make_builder.html b/arrow/array/builder/fn.make_builder.html
index 104dd08326b..e4506759c23 100644
--- a/arrow/array/builder/fn.make_builder.html
+++ b/arrow/array/builder/fn.make_builder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Returns a builder with capacity `capacity` that corresponds to the datatype `DataType` This function is useful to construct arrays from an arbitrary vectors with known/expected schema."><title>make_builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/wo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Returns a builder with capacity `capacity` that corresponds to the datatype `DataType` This function is useful to construct arrays from an arbitrary vectors with known/expected schema."><title>make_builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/wo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     datatype: &amp;<a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Returns a builder with capacity <code>capacity</code> that corresponds to the datatype <cod [...]
diff --git a/arrow/array/builder/index.html b/arrow/array/builder/index.html
index 3fe0c7997c4..a8966193c32 100644
--- a/arrow/array/builder/index.html
+++ b/arrow/array/builder/index.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Defines push-based APIs for constructing arrays"><title>arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Defines push-based APIs for constructing arrays"><title>arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <h2 id="basic-usage"><a class="doc-anchor" href="#basic-usage">§</a>Basic Usage</h2>
 <p>Builders can be used to build simple, non-nested arrays</p>
 
diff --git a/arrow/array/builder/struct.BooleanBufferBuilder.html b/arrow/array/builder/struct.BooleanBufferBuilder.html
index 37e0df43c14..65c3958212a 100644
--- a/arrow/array/builder/struct.BooleanBufferBuilder.html
+++ b/arrow/array/builder/struct.BooleanBufferBuilder.html
@@ -1,39 +1,39 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `BooleanBuffer`"><title>BooleanBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossor [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `BooleanBuffer`"><title>BooleanBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossor [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer"><code>BooleanBuffer</code></a></p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.buffer" class="structfield section-header"><a href="#structfield.buffer" class="anchor field">§</a><code>buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a></code></span><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor fiel [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#38">source</a><h4 class="code-header">pub fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.buffer" class="structfield section-header"><a href="#structfield.buffer" class="anchor field">§</a><code>buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a></code></span><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor fiel [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><h4 class="code-header">pub fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.BooleanBufferBuilder.html" title="struct arrow::array::builder::BooleanBufferBuilder">BooleanBufferBuilder</a></h4></section></summary><div class="docblock"><p>Creates a new <code>BooleanBufferBuilder</code> from <a href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer"><code>MutableBuffer</code></a> of <code>len</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#50">source</a><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of the buffer</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.set_bit" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#56">source</a><h4 class="code-header">pub fn <a href="#method.set_bit" class="fn">set_bit</a>(&amp;mut self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.ht [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.get_bit" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#66">source</a><h4 class="code-header">pub fn <a href="#method.get_bit" class="fn">get_bit</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.htm [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#72">source</a><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns true if empty</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#78">source</a><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of the buffer</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.advance" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#84">source</a><h4 class="code-header">pub fn <a href="#method.advance" class="fn">advance</a>(&amp;mut self, additional: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Advances the buffer by <code>ad [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.truncate" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#97">source</a><h4 class="code-header">pub fn <a href="#method.truncate" class="fn">truncate</a>(&amp;mut self, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Truncates the builder to the given  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of the buffer</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.set_bit" class="method"><h4 class="code-header">pub fn <a href="#method.set_bit" class="fn">set_bit</a>(&amp;mut self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Sets a bit in the buffer at <cod [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.get_bit" class="method"><h4 class="code-header">pub fn <a href="#method.get_bit" class="fn">get_bit</a>(&amp;self, index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Gets a bit in the buffer at <code> [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns true if empty</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of the buffer</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.advance" class="method"><h4 class="code-header">pub fn <a href="#method.advance" class="fn">advance</a>(&amp;mut self, additional: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Advances the buffer by <code>additional</code> bits</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.truncate" class="method"><h4 class="code-header">pub fn <a href="#method.truncate" class="fn">truncate</a>(&amp;mut self, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Truncates the builder to the given length</p>
 <p>If <code>len</code> is greater than the buffer’s current length, this has no effect</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.reserve" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#117">source</a><h4 class="code-header">pub fn <a href="#method.reserve" class="fn">reserve</a>(&amp;mut self, additional: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Reserve space to at least <cod [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.reserve" class="method"><h4 class="code-header">pub fn <a href="#method.reserve" class="fn">reserve</a>(&amp;mut self, additional: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Reserve space to at least <code>additional</code> new bits.
 Capacity will be <code>&gt;= self.len() + additional</code>.
 New bytes are uninitialized and reading them is undefined behavior.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.resize" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#129">source</a><h4 class="code-header">pub fn <a href="#method.resize" class="fn">resize</a>(&amp;mut self, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Resizes the buffer, either truncating it [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.resize" class="method"><h4 class="code-header">pub fn <a href="#method.resize" class="fn">resize</a>(&amp;mut self, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Resizes the buffer, either truncating its contents (with no change in capacity), or
 growing it (potentially reallocating it) and writing <code>false</code> in the newly available bits.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#138">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends a boolean <code>v</code> into the bu [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_n" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#147">source</a><h4 class="code-header">pub fn <a href="#method.append_n" class="fn">append_n</a>(&amp;mut self, additional: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitiv [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#172">source</a><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, slice: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>])</h4></section></summary><div class="docblock"><p>Appends a slice [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_packed_range" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#191">source</a><h4 class="code-header">pub fn <a href="#method.append_packed_range" class="fn">append_packed_range</a>(&amp;mut self, range: <a class="struct" href="https://doc.rust-lang.org/nightly/core/ops/range/struct.Range.html" title="struct core::ops::range::Range">Range</a>&lt;<a [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends a boolean <code>v</code> into the buffer</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_n" class="method"><h4 class="code-header">pub fn <a href="#method.append_n" class="fn">append_n</a>(&amp;mut self, additional: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends n <code>addition [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, slice: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>])</h4></section></summary><div class="docblock"><p>Appends a slice of booleans into the buffer</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_packed_range" class="method"><h4 class="code-header">pub fn <a href="#method.append_packed_range" class="fn">append_packed_range</a>(&amp;mut self, range: <a class="struct" href="https://doc.rust-lang.org/nightly/core/ops/range/struct.Range.html" title="struct core::ops::range::Range">Range</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&g [...]
 <p><code>to_set</code> is a slice of bits packed LSB-first into <code>[u8]</code></p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <code>to_set</code> does not contain <code>ceil(range.end / 8)</code> bytes</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_buffer" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#205">source</a><h4 class="code-header">pub fn <a href="#method.append_buffer" class="fn">append_buffer</a>(&amp;mut self, buffer: &amp;<a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>)</h4></section></summary><div cl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#211">source</a><h4 class="code-header">pub fn <a href="#method.as_slice" class="fn">as_slice</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#216">source</a><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;mut [u8]">ⓘ</a>< [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#222">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Creates a < [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#229">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docbloc [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-BooleanBufferBuilder" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anchor">§</a>< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_buffer" class="method"><h4 class="code-header">pub fn <a href="#method.append_buffer" class="fn">append_buffer</a>(&amp;mut self, buffer: &amp;<a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>)</h4></section></summary><div class="docblock"><p>Append <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::b [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice" class="method"><h4 class="code-header">pub fn <a href="#method.as_slice" class="fn">as_slice</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div class="docblock"><p>Returns the packed bits</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;mut [u8]">ⓘ</a></h4></section></summary><div class="docblock"><p>Returns the packed bits</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Creates a <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer"><cod [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::B [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-BooleanBufferBuilder" class="impl"><a href="#impl-Debug-for-BooleanBufferBuilder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/t [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
@@ -42,8 +42,8 @@ growing it (potentially reallocating it) and writing <code>false</code> in the n
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"&[u8]":"<h3>Notable traits for <code>&amp;[<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u8.html\">u8</a>]</code></h3><pre><code><div class=\"where\">impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Read.html\" title= [...]
\ No newline at end of file
diff --git a/arrow/array/builder/struct.BooleanBuilder.html b/arrow/array/builder/struct.BooleanBuilder.html
index 174856dd3aa..2504369b095 100644
--- a/arrow/array/builder/struct.BooleanBuilder.html
+++ b/arrow/array/builder/struct.BooleanBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `BooleanArray`"><title>BooleanBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `BooleanArray`"><title>BooleanBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     values_builder: <a class="struct" href="struct.BooleanBufferBuilder.html" title="struct arrow::array::builder::BooleanBufferBuilder">BooleanBufferBuilder</a>,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray"><code>BooleanArray</code></a></p>
 <h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <p>Create a <code>BooleanArray</code> from a <code>BooleanBuilder</code></p>
@@ -28,30 +28,30 @@ b.append_value(<span class="bool-val">true</span>);
 <span class="macro">assert_eq!</span>(<span class="bool-val">true</span>, arr.value(<span class="number">3</span>));
 <span class="macro">assert!</span>(arr.is_valid(<span class="number">3</span>));
 <span class="macro">assert!</span>(!arr.is_null(<span class="number">3</span>));</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BooleanBufferBuilder.html" title="struct arrow::array::builder::BooleanBufferBuilder">BooleanBufferBuilder</a></code></span><span id="structfield.null_buffer_builder" class="structfield secti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#77">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.BooleanBuilder.html" title="struct  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#85">source</a><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of this bui [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#91">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends a value of t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#98">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_nulls" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#105">source</a><h4 class="code-header">pub fn <a href="#method.append_nulls" class="fn">append_nulls</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#112">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(&amp;mut self, v: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href=" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#121">source</a><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, v: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>])</h4></section></summary><div class="docblock"><p>Appends a sl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_values" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#130">source</a><h4 class="code-header">pub fn <a href="#method.append_values" class="fn">append_values</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BooleanBufferBuilder.html" title="struct arrow::array::builder::BooleanBufferBuilder">BooleanBufferBuilder</a></code></span><span id="structfield.null_buffer_builder" class="structfield secti [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.BooleanBuilder.html" title="struct arrow::array::builder::BooleanBuilder">BooleanBuilder</a></h4></section></summary><div class="docblock [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of this builder measured in slots of type <code>T</code></p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, v: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends a value of type <code>T</code> into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_nulls" class="method"><h4 class="code-header">pub fn <a href="#method.append_nulls" class="fn">append_nulls</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</code> <code>null</code>s into the builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(&amp;mut self, v: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;)</h4></section></summary><div c [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, v: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>])</h4></section></summary><div class="docblock"><p>Appends a slice of type <code>T</code> into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_values" class="method"><h4 class="code-header">pub fn <a href="#method.append_values" class="fn">append_values</a>(
     &amp;mut self,
     values: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>],
     is_valid: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Appends values from a slice of type <code>T</code> and a validity boolean slice.</p>
 <p>Returns an error if the slices are of different lengths</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#143">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#156">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h4></section></summary><div class="docblock"><p>B [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#170">source</a><h4 class="code-header">pub fn <a href="#method.validity_slice" class="fn">validity_slice</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-BooleanBuilder" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#175">source</a><a href="#impl-ArrayBuilder-for-BooleanBuilder" class="anch [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#182">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#187">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title= [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#192">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summa [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#197">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struc [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/boolean_builder.rs.html#202">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struc [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a> and reset thi [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice" class="method"><h4 class="code-header">pub fn <a href="#method.validity_slice" class="fn">validity_slice</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</h4></section></summary><d [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-BooleanBuilder" class="impl"><a href="#impl-ArrayBuilder-for-BooleanBuilder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrayBuilder.html" title="trait arro [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.BooleanBuilder.html" title="struct [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;&gt;,</div></h4></section></summary><div class='docblock'>Exten [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
@@ -61,8 +61,8 @@ b.append_value(<span class="bool-val">true</span>);
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.BufferBuilder.html b/arrow/array/builder/struct.BufferBuilder.html
index 1bc3e21e6e4..894526df27a 100644
--- a/arrow/array/builder/struct.BufferBuilder.html
+++ b/arrow/array/builder/struct.BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for creating a Buffer object."><title>BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for creating a Buffer object."><title>BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div>{
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -16,8 +16,8 @@ builder.append(<span class="number">45</span>);
 <span class="kw">let </span>buffer = builder.finish();
 
 <span class="macro">assert_eq!</span>(<span class="kw">unsafe </span>{ buffer.typed_data::&lt;u8&gt;() }, <span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">43</span>, <span class="number">44</span>, <span class="number">45</span>]);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.buffer" class="structfield section-header"><a href="#structfield.buffer" class="anchor field">§</a><code>buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a></code></span><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor fiel [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#76">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(capacity: <a class="primitive" href="htt [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.buffer" class="structfield section-header"><a href="#structfield.buffer" class="anchor field">§</a><code>buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a></code></span><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor fiel [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" [...]
 elements of type <code>T</code>.</p>
 <p>The capacity can later be manually adjusted with the
 <a href="struct.BufferBuilder.html#method.reserve" title="method arrow::array::builder::BufferBuilder::reserve"><code>reserve()</code></a> method.
@@ -31,26 +31,26 @@ methods automatically increase the capacity if needed.</p>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 
 <span class="macro">assert!</span>(builder.capacity() &gt;= <span class="number">10</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#87">source</a><h4 class="code-header">pub fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>) -&gt; <a class="struct" href="struct.BufferBuilder [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#108">source</a><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the current number of array elements in the inter [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><h4 class="code-header">pub fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>) -&gt; <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;T&gt;</h4>< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the current number of array elements in the internal buffer.</p>
 <h5 id="example-2"><a class="doc-anchor" href="#example-2">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 builder.append(<span class="number">42</span>);
 
 <span class="macro">assert_eq!</span>(builder.len(), <span class="number">1</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#124">source</a><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether the internal buffer is empty.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns whether the internal buffer is empty.</p>
 <h5 id="example-3"><a class="doc-anchor" href="#example-3">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 builder.append(<span class="number">42</span>);
 
 <span class="macro">assert_eq!</span>(builder.is_empty(), <span class="bool-val">false</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#133">source</a><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the actual capacity (number of ele [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the actual capacity (number of elements) of the internal buffer.</p>
 <p>Note: the internal capacity returned by this method might be larger than
 what you’d expect after setting the capacity in the <code>new()</code> or <code>reserve()</code>
 functions.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.advance" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#156">source</a><h4 class="code-header">pub fn <a href="#method.advance" class="fn">advance</a>(&amp;mut self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Increases the number of elements in the int [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.advance" class="method"><h4 class="code-header">pub fn <a href="#method.advance" class="fn">advance</a>(&amp;mut self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Increases the number of elements in the internal buffer by <code>n</code>
 and resizes the buffer as needed.</p>
 <p>The values of the newly added elements are 0.
 This method is usually used when appending <code>NULL</code> values to the buffer
@@ -61,14 +61,14 @@ as they still require physical memory space.</p>
 builder.advance(<span class="number">2</span>);
 
 <span class="macro">assert_eq!</span>(builder.len(), <span class="number">2</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.reserve" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#174">source</a><h4 class="code-header">pub fn <a href="#method.reserve" class="fn">reserve</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Reserves memory for <em>at least</em> <code [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.reserve" class="method"><h4 class="code-header">pub fn <a href="#method.reserve" class="fn">reserve</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Reserves memory for <em>at least</em> <code>n</code> more elements of type <code>T</code>.</p>
 <h5 id="example-5"><a class="doc-anchor" href="#example-5">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 builder.reserve(<span class="number">10</span>);
 
 <span class="macro">assert!</span>(builder.capacity() &gt;= <span class="number">20</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#192">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, v: T)</h4></section></summary><div class="docblock"><p>Appends a value of type <code>T</code> into the builder,
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, v: T)</h4></section></summary><div class="docblock"><p>Appends a value of type <code>T</code> into the builder,
 growing the internal buffer as needed.</p>
 <h5 id="example-6"><a class="doc-anchor" href="#example-6">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -76,7 +76,7 @@ growing the internal buffer as needed.</p>
 builder.append(<span class="number">42</span>);
 
 <span class="macro">assert_eq!</span>(builder.len(), <span class="number">1</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_n" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#212">source</a><h4 class="code-header">pub fn <a href="#method.append_n" class="fn">append_n</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, v: T)</h4></section></summary><div class="docblock"><p>Appends a value of type <code>T</c [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_n" class="method"><h4 class="code-header">pub fn <a href="#method.append_n" class="fn">append_n</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, v: T)</h4></section></summary><div class="docblock"><p>Appends a value of type <code>T</code> into the builder N times,
 growing the internal buffer as needed.</p>
 <h5 id="example-7"><a class="doc-anchor" href="#example-7">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -84,7 +84,7 @@ growing the internal buffer as needed.</p>
 builder.append_n(<span class="number">10</span>, <span class="number">42</span>);
 
 <span class="macro">assert_eq!</span>(builder.len(), <span class="number">10</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_n_zeroed" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#230">source</a><h4 class="code-header">pub fn <a href="#method.append_n_zeroed" class="fn">append_n_zeroed</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</co [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_n_zeroed" class="method"><h4 class="code-header">pub fn <a href="#method.append_n_zeroed" class="fn">append_n_zeroed</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</code>, zero-initialized values</p>
 <h5 id="example-8"><a class="doc-anchor" href="#example-8">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u32&gt;::new(<span class="number">10</span>);
@@ -92,14 +92,14 @@ builder.append_n_zeroed(<span class="number">3</span>);
 
 <span class="macro">assert_eq!</span>(builder.len(), <span class="number">3</span>);
 <span class="macro">assert_eq!</span>(builder.as_slice(), <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>])</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#248">source</a><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, slice: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>)</h4></section></summary><div class="docblock"><p>Appends a slice of ty [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, slice: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>)</h4></section></summary><div class="docblock"><p>Appends a slice of type <code>T</code>, growing the internal buffer as needed.</p>
 <h5 id="example-9"><a class="doc-anchor" href="#example-9">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">44</span>, <span class="number">46</span>]);
 
 <span class="macro">assert_eq!</span>(builder.len(), <span class="number">3</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#265">source</a><h4 class="code-header">pub fn <a href="#method.as_slice" class="fn">as_slice</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section></summary><div class="docblock"><p>View the contents of this buffer as a s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice" class="method"><h4 class="code-header">pub fn <a href="#method.as_slice" class="fn">as_slice</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section></summary><div class="docblock"><p>View the contents of this buffer as a slice</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;f64&gt;::new(<span class="number">10</span>);
@@ -107,7 +107,7 @@ builder.append(<span class="number">1.3</span>);
 builder.append_n(<span class="number">2</span>, <span class="number">2.3</span>);
 
 <span class="macro">assert_eq!</span>(builder.as_slice(), <span class="kw-2">&amp;</span>[<span class="number">1.3</span>, <span class="number">2.3</span>, <span class="number">2.3</span>]);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#290">source</a><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section></summary><div class="docblock"><p>View the contents o [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section></summary><div class="docblock"><p>View the contents of this buffer as a mutable slice</p>
 <h5 id="example-10"><a class="doc-anchor" href="#example-10">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;f32&gt;::new(<span class="number">10</span>);
@@ -117,7 +117,7 @@ builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">1.</sp
 
 builder.as_slice_mut()[<span class="number">1</span>] = <span class="number">4.2</span>;
 <span class="macro">assert_eq!</span>(builder.as_slice(), <span class="kw-2">&amp;</span>[<span class="number">1.</span>, <span class="number">4.2</span>, <span class="number">3.4</span>]);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.truncate" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#320">source</a><h4 class="code-header">pub fn <a href="#method.truncate" class="fn">truncate</a>(&amp;mut self, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Shorten this BufferBuilder to <code>le [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.truncate" class="method"><h4 class="code-header">pub fn <a href="#method.truncate" class="fn">truncate</a>(&amp;mut self, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Shorten this BufferBuilder to <code>len</code> items</p>
 <p>If <code>len</code> is greater than the builder’s current length, this has no effect</p>
 <h5 id="example-11"><a class="doc-anchor" href="#example-11">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -131,13 +131,13 @@ builder.truncate(<span class="number">2</span>);
 
 builder.append(<span class="number">12</span>);
 <span class="macro">assert_eq!</span>(builder.as_slice(), <span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">44</span>, <span class="number">12</span>]);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_trusted_len_iter" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#329">source</a><h4 class="code-header">pub unsafe fn <a href="#method.append_trusted_len_iter" class="fn">append_trusted_len_iter</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_trusted_len_iter" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.append_trusted_len_iter" class="fn">append_trusted_len_iter</a>(
     &amp;mut self,
     iter: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = T&gt;
 )</h4></section></summary><div class="docblock"><h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>This requires the iterator be a trusted length. This could instead require
 the iterator implement <code>TrustedLen</code> once that is stabilized.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#354">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Resets this builder and returns an i [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Resets this builder and returns an immutable <a href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buff [...]
 <h5 id="example-12"><a class="doc-anchor" href="#example-12">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
@@ -146,15 +146,15 @@ builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</sp
 <span class="kw">let </span>buffer = builder.finish();
 
 <span class="macro">assert_eq!</span>(<span class="kw">unsafe </span>{ buffer.typed_data::&lt;u8&gt;() }, <span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">44</span>, <span class="number">46</span>]);</code></pre></div>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-BufferBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#47">source</a><a href="#impl-Debug-for-BufferBuilder%3CT%3E" class="anchor">§</a><h3 c [...]
-    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/ [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#362">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#368">source</a><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = T&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend">Read more</a></div></details><details class="toggle method-toggle" open><summa [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/buffer/immutable.rs.html#376">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rus [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#164">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#376">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#382">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://do [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-BufferBuilder%3CT%3E" class="impl"><a href="#impl-Debug-for-BufferBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/c [...]
+    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header" [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">default</a> [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend" class="fn">ext [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = T&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend">Read more</a></div></details><details class="toggle method-toggle" open><summa [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(value: <a  [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(value: <a clas [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(value: <a  [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = T&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter">Read more</a></div></details></div></details></div><h2 id="synthetic-implementations" clas [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div></h3></section><section id="impl-Send-for-BufferBuilder%3CT%3E" class="impl"><a href="#impl-Send-for-BufferBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">S [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><section id="impl-UnwindSafe-for-BufferBuilder%3CT%3E" class="impl"><a href="#impl-UnwindSafe-for-BufferBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe::UnwindSafe">U [...]
@@ -167,8 +167,8 @@ builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</sp
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.FixedSizeBinaryBuilder.html b/arrow/array/builder/struct.FixedSizeBinaryBuilder.html
index ab4888c6a24..485fdd2745c 100644
--- a/arrow/array/builder/struct.FixedSizeBinaryBuilder.html
+++ b/arrow/array/builder/struct.FixedSizeBinaryBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `FixedSizeBinaryArray`"><title>FixedSizeBinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2 [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `FixedSizeBinaryArray`"><title>FixedSizeBinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2 [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     value_length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray"><code>FixedSizeBinaryArray</code></a></p>
 
@@ -15,25 +15,25 @@ builder.append_value(<span class="string">b"arrow"</span>).unwrap();
 <span class="macro">assert_eq!</span>(array.value(<span class="number">0</span>), <span class="string">b"hello"</span>);
 <span class="macro">assert!</span>(array.is_null(<span class="number">1</span>));
 <span class="macro">assert_eq!</span>(array.value(<span class="number">2</span>), <span class="string">b"arrow"</span>);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</co [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#58">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, byte_width: <a class="primitive" href="https://doc.rust-lang.o [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</co [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, byte_width: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>) -&gt; <a class="struct" href="struct.FixedSizeBinaryBuilder.html" ti [...]
 that can be appended without reallocating</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#75">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(
     &amp;mut self,
     value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Appends a byte slice into the builder.</p>
 <p>Automatically update the null buffer to delimit the slice appended in as a
 distinct value element.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#90">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Append a null value to the array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#97">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a></h4></section></summary><div class [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#108">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a></h4></section></ [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-FixedSizeBinaryBuilder" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#120">source</a><a href="#impl-ArrayBuilder-for-FixedSize [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#127">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#132">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.ht [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#137">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></secti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#142">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" ti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_binary_builder.rs.html#147">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Append a null value to the array.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBin [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.FixedSizeBinaryArray.html" title="struct arrow::ar [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-FixedSizeBinaryBuilder" class="impl"><a href="#impl-ArrayBuilder-for-FixedSizeBinaryBuilder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrayBuilder.html" t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.FixedSizeBinaryBuilder.html" title [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
@@ -42,8 +42,8 @@ distinct value element.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.FixedSizeListBuilder.html b/arrow/array/builder/struct.FixedSizeListBuilder.html
index d2ed5a6c184..3354ea47340 100644
--- a/arrow/array/builder/struct.FixedSizeListBuilder.html
+++ b/arrow/array/builder/struct.FixedSizeListBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `FixedSizeListArray`"><title>FixedSizeListBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `FixedSizeListArray`"><title>FixedSizeListBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div>{
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     values_builder: T,
     list_len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a></p>
@@ -41,33 +41,33 @@ builder.append(<span class="bool-val">true</span>);
     <span class="kw-2">*</span>list_array.value(<span class="number">3</span>),
     Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">6</span>), <span class="prelude-val">Some</span>(<span class="number">7</span>), <span class="prelude-val">None</span>])
 )</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.null_buffer_builder" class="structfield section-header"><a href="#structfield.null_buffer_builder" class="anchor field">§</a><code>null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a></code></span><span id="structfiel [...]
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#75">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(values_builder: T, value_length: <a class [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.null_buffer_builder" class="structfield section-header"><a href="#structfield.null_buffer_builder" class="anchor field">§</a><code>null_buffer_builder: NullBufferBuilder</code></span><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: T</code></span><s [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(values_builder: T, value_length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>) -&gt; <a class="struct"  [...]
 <code>value_length</code> is the number of values within each array</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#87">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     values_builder: T,
     value_length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
     capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.FixedSizeListBuilder.html" title="struct arrow::array::builder::FixedSizeListBuilder">FixedSizeListBuilder</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Creates a new <a href="struct.FixedSizeListBuilder.html" title="struct arrow::array::builder::FixedSizeListBuilder"><code>FixedSizeListBuilder</code></a> from a given values array builder
 <code>value_length</code> is the number of values within each array
 <code>capacity</code> is the number of items to pre-allocate space for in this builder</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-FixedSizeListBuilder%3CT%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#131-133">source</a><a href="#impl-FixedSizeListBuilder%3CT%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="struct.FixedSizeListBuilder.html" title="struct arrow::array::builder::FixedSizeListBuilder">Fixe [...]
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#139">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;mut self) -&gt;  [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-FixedSizeListBuilder%3CT%3E-1" class="impl"><a href="#impl-FixedSizeListBuilder%3CT%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="struct" href="struct.FixedSizeListBuilder.html" title="struct arrow::array::builder::FixedSizeListBuilder">FixedSizeListBuilder</a>&lt;T&gt;<div class="where">where
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;mut self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut T</a></h4>< [...]
 <p>This mutable reference can be used to append values into the child array builder,
 but you must call <a href="#method.append"><code>append</code></a> to delimit each distinct list value.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#144">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the len [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#150">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Finish the current fix [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#155">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a></h4></section></summary><div class="docbl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#183">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a></h4></section></summary> [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#96-98">source</a><a href="#impl-ArrayBuilder-for-Fixe [...]
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#101">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.A [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#106">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/an [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#111">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#116">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#121">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" titl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#126">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sy [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
-    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_build [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></section></summary><div class="docblock"><p>Returns the length of the list</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Finish the current fixed-length list array slot</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="struct.FixedSizeListBuilder.html" title="struct arrow::array::builder::FixedSizeLis [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="struct.FixedSizeListBuilder.html" title="struct arrow::array::buil [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="impl"><a href="#impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.A [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.FixedSizeListBuilder.html" title=" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
+    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div></h3></section><section id="impl-Send-for-FixedSizeListBuilder%3CT%3E" class="impl"><a href="#impl-Send-for-FixedSizeListBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::m [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><section id="impl-UnwindSafe-for-FixedSizeListBuilder%3CT%3E" class="impl"><a href="#impl-UnwindSafe-for-FixedSizeListBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe: [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe::UnwindSafe">UnwindSafe</a>,</div></h3></section></div><h2 id="blanket-implementations" class="section-header">Blanket Implementations<a href="#blanket-implementations" class="anchor">§</a></h2><div id="blanket-implementations-list"><details class="toggle implementors-toggle"><summary><section id="impl-Any-for-T" class="impl"><a class="src ri [...]
@@ -79,8 +79,8 @@ but you must call <a href="#method.append"><code>append</code></a> to delimit ea
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.GenericByteBuilder.html b/arrow/array/builder/struct.GenericByteBuilder.html
index 403f4deea2d..be0e769336f 100644
--- a/arrow/array/builder/struct.GenericByteBuilder.html
+++ b/arrow/array/builder/struct.GenericByteBuilder.html
@@ -1,13 +1,13 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `GenericByteArray`"><title>GenericByteBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `GenericByteArray`"><title>GenericByteBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div>{
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a></p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code> [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#37">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" hre [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#47">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code> [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" href="struct.GenericByteBuilder.html" title="struct arrow::array::builder::GenericByteBuilder">GenericByteBuild [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     item_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     data_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.GenericByteBuilder.html" title="struct arrow::array::builder::GenericByteBuilder">GenericByteBuilder</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Creates a new <a href="struct.GenericByteBuilder.html" title="struct arrow::array::builder::GenericByteBuilder"><code>GenericByteBuilder</code></a>.</p>
@@ -17,7 +17,7 @@ The size of the preallocated buffer of offsets is the number of items plus one.<
 <li><code>data_capacity</code> is the total number of bytes of data to pre-allocate
 (for all items, not per item).</li>
 </ul>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#62-66">source</a><h4 class="code-header">pub unsafe fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(
     offsets_buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     value_buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     null_buffer: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>&gt;
@@ -25,34 +25,34 @@ The size of the preallocated buffer of offsets is the number of items plus one.<
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>This doesn’t verify buffer contents as it assumes the buffers are from existing and
 valid <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#92">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a cl [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">By [...]
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if the resulting length of <a href="struct.GenericByteBuilder.html#method.values_slice" title="method arrow::array::builder::GenericByteBuilder::values_slice"><code>Self::values_slice</code></a> would exceed <code>T::Offset::MAX</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#100">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
     &amp;mut self,
     value: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArray [...]
 )</h4></section></summary><div class="docblock"><p>Append an <code>Option</code> value into the builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#109">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Append a null value into the builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#115">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary><div class="docb [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#129">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#144">source</a><h4 class="code-header">pub fn <a href="#method.values_slice" class="fn">values_slice</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#149">source</a><h4 class="code-header">pub fn <a href="#method.offsets_slice" class="fn">offsets_slice</a>(&amp;self) -&gt; &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a clas [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#154">source</a><h4 class="code-header">pub fn <a href="#method.validity_slice" class="fn">validity_slice</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="pri [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#159">source</a><h4 class="code-header">pub fn <a href="#method.validity_slice_mut" class="fn">validity_slice_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&am [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#181">source</a><a href="#impl-ArrayBuilder-for-GenericByt [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#183">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#188">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title= [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#193">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#198">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#203">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#208">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html"  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#165">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#176">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="htt [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Append a null value into the builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.GenericByteArray.html" title="struct arrow::array::Ge [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice" class="method"><h4 class="code-header">pub fn <a href="#method.values_slice" class="fn">values_slice</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div class="docblock"><p>Returns the current values buffer as a slice</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets_slice" class="method"><h4 class="code-header">pub fn <a href="#method.offsets_slice" class="fn">offsets_slice</a>(&amp;self) -&gt; &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::d [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice" class="method"><h4 class="code-header">pub fn <a href="#method.validity_slice" class="fn">validity_slice</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</h4></section></summary><d [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice_mut" class="method"><h4 class="code-header">pub fn <a href="#method.validity_slice_mut" class="fn">validity_slice_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</h4></ [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.Array [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-la [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock"><p>Returns the builder  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.GenericByteBuilder.html" title="st [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html#tymethod.fmt" class="fn">fmt</a>(&amp;self, f: &amp;mut <a c [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">default</a>() -&g [...]
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div class= [...]
-    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/ [...]
-    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.write_str" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#253">source</a><a href="#method.write_str" class="anchor">§</a><h4 class="code-header">fn <a href="https://do [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div class= [...]
+    I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/ [...]
+    O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.write_str" class="method trait-impl"><a href="#method.write_str" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html#tymethod.write_str" class="fn">write_str</a>(&amp;mut self, [...]
 succeeded. <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html#tymethod.write_str">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.write_char" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.1.0">1.1.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/fmt/mod.rs.html#166">source</a></span><a href="#method.write_char" class="anchor">§</a><h4 [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div> [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><section id="impl-UnwindSafe-for [...]
@@ -65,8 +65,8 @@ succeeded. <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html#
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div><script type="text/json" id="notable-traits-data">{"&[u8]":"<h3>Notable traits for <code>&amp;[<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u8.html\">u8</a>]</code></h3><pre><code><div class=\"where\">impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Read.html\" title= [...]
\ No newline at end of file
diff --git a/arrow/array/builder/struct.GenericByteDictionaryBuilder.html b/arrow/array/builder/struct.GenericByteDictionaryBuilder.html
index 6696c19e3c2..05282b10289 100644
--- a/arrow/array/builder/struct.GenericByteDictionaryBuilder.html
+++ b/arrow/array/builder/struct.GenericByteDictionaryBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `GenericByteArray`"><title>GenericByteDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `GenericByteArray`"><title>GenericByteDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div>{
     state: RandomState,
@@ -10,10 +10,10 @@
 <p>For example to map a set of byte indices to String values. Note that
 the use of a <code>HashMap</code> here will not scale to very large arrays or
 result in an ordered dictionary.</p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.state" class="structfield section-header"><a href="#structfield.state" class="anchor field">§</a><code>state: RandomState</code></span><span id="structfield.dedup" class="structfield section-header"><a href="#structfield.dedup" class="anchor field">§</a><code>dedup: HashMap&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize. [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.state" class="structfield section-header"><a href="#structfield.state" class="anchor field">§</a><code>state: RandomState</code></span><span id="structfield.dedup" class="structfield section-header"><a href="#structfield.dedup" class="anchor field">§</a><code>dedup: HashMap&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize. [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#67">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class=" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#83-87">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" href="struct.GenericByteDictionaryBuilder.html" title="struct arrow::array::builder::GenericByteDictionaryBuild [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     keys_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     value_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     data_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
@@ -21,7 +21,7 @@ result in an ordered dictionary.</p>
 <p><code>keys_capacity</code>: the number of keys, i.e. length of array to build
 <code>value_capacity</code>: the number of distinct dictionary values, i.e. size of dictionary
 <code>data_capacity</code>: the total number of bytes of all distinct bytes in the dictionary</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_with_dictionary" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#119-122">source</a><h4 class="code-header">pub fn <a href="#method.new_with_dictionary" class="fn">new_with_dictionary</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_with_dictionary" class="method"><h4 class="code-header">pub fn <a href="#method.new_with_dictionary" class="fn">new_with_dictionary</a>(
     keys_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     dictionary_values: &amp;<a class="struct" href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.GenericByteDictionaryBuilder.html" title="struct arrow::array::builder::GenericByteDictionaryBuilder">GenericByteDictionaryBuilder</a>&lt;K, T&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Creates a [...]
@@ -41,43 +41,43 @@ builder.append(<span class="string">"abc"</span>).unwrap();
 <span class="kw">let </span>keys = dictionary_array.keys();
 
 <span class="macro">assert_eq!</span>(keys, <span class="kw-2">&amp;</span>Int16Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">2</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="number">1</span>)]));</code></pre></div>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteDictionaryBuilder%3CK,+T%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#201-204">source</a><a href="#impl-GenericByteDictionaryBuilder%3CK,+T%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;K, T&gt; <a class="struct" href="struct.GenericByteDictionaryBuilder.html" title="struct arrow:: [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteDictionaryBuilder%3CK,+T%3E-1" class="impl"><a href="#impl-GenericByteDictionaryBuilder%3CK,+T%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;K, T&gt; <a class="struct" href="struct.GenericByteDictionaryBuilder.html" title="struct arrow::array::builder::GenericByteDictionaryBuilder">GenericByteDictionaryBuilder</a>&lt;K, T&gt;<div class="where">where
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#211">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(
     &amp;mut self,
     value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;&lt;K as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>, <a class="enum" href= [...]
 if already present in the values array or a new index if the
 value is appended to the values array.</p>
 <p>Returns an error if the new index would overflow the key type.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#247">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&l [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">By [...]
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if the resulting length of the dictionary values array would exceed <code>T::Native::MAX</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#253">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#263">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
     &amp;mut self,
     value: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArray [...]
 )</h4></section></summary><div class="docblock"><p>Append an <code>Option</code> value into the builder</p>
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if the resulting length of the dictionary values array would exceed <code>T::Native::MAX</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#271">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#288">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section>< [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericByteDictionaryBuilder%3CK,+T%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#165-168">source</a><a href="#impl [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Builds the <code>DictionaryArray</code> and reset this builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Builds the <code>DictionaryArray</code> without resetting the builder.</p>
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericByteDictionaryBuilder%3CK,+T%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericByteDictionaryBuilder%3CK,+T%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, T&gt; <a cl [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#171">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#176">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#181">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#186">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#191">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.h [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#196">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="h [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.GenericByteDictionaryBuilder.html" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic [...]
+    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_dictionary_builder.rs.html#56">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">default</a>() -&g [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div class= [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div class= [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/ [...]
     &lt;K as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div> [...]
@@ -93,8 +93,8 @@ value is appended to the values array.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.GenericByteRunBuilder.html b/arrow/array/builder/struct.GenericByteRunBuilder.html
index 81a28c95e34..cfad8c9fd99 100644
--- a/arrow/array/builder/struct.GenericByteRunBuilder.html
+++ b/arrow/array/builder/struct.GenericByteRunBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `GenericByteArray`"><title>GenericByteRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `GenericByteArray`"><title>GenericByteRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     R: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div>{
     run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;,
@@ -33,47 +33,47 @@ builder.append_null();
 
 <span class="macro">assert_eq!</span>(ava.value(<span class="number">0</span>), <span class="string">b"abc"</span>);
 <span class="macro">assert_eq!</span>(ava.value(<span class="number">2</span>), <span class="string">b"def"</span>);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.run_ends_builder" class="structfield section-header"><a href="#structfield.run_ends_builder" class="anchor field">§</a><code>run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;</code></span><span id="structfield.values_builder" class="structfield section [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.run_ends_builder" class="structfield section-header"><a href="#structfield.run_ends_builder" class="anchor field">§</a><code>run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;</code></span><span id="structfield.values_builder" class="structfield section [...]
     R: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#94">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct"  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#109">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" href="struct.GenericByteRunBuilder.html" title="struct arrow::array::builder::GenericByteRunBuilder">GenericByt [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     data_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.GenericByteRunBuilder.html" title="struct arrow::array::builder::GenericByteRunBuilder">GenericByteRunBuilder</a>&lt;R, V&gt;</h4></section></summary><div class="docblock"><p>Creates a new <code>GenericByteRunBuilder</code> with the provided capacity</p>
 <p><code>capacity</code>: the expected number of run-end encoded values.
 <code>data_capacity</code>: the expected number of bytes of run end encoded values</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteRunBuilder%3CR,+V%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#158-161">source</a><a href="#impl-GenericByteRunBuilder%3CR,+V%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="struct" href="struct.GenericByteRunBuilder.html" title="struct arrow::array::builder::GenericByteRu [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericByteRunBuilder%3CR,+V%3E-1" class="impl"><a href="#impl-GenericByteRunBuilder%3CR,+V%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="struct" href="struct.GenericByteRunBuilder.html" title="struct arrow::array::builder::GenericByteRunBuilder">GenericByteRunBuilder</a>&lt;R, V&gt;<div class="where">where
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#164">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
+    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
     &amp;mut self,
     input_value: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.Byt [...]
 )</h4></section></summary><div class="docblock"><p>Appends optional value to the logical array encoded by the RunArray.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#172">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(
     &amp;mut self,
     input_value: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;
 )</h4></section></summary><div class="docblock"><p>Appends value to the logical array encoded by the RunArray.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends null to the logical array encoded by the RunArray.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#198">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Creates the  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends null to the logical array encoded by the RunArray.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Creates the RunArray and resets the builder.
 Panics if RunArray cannot be built.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#216">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Creates the RunArray and without resetting the builder.
 Panics if RunArray cannot be built.</p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#121-124">source</a><a href="#impl-ArrayBuilder-f [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="trait" hr [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#127">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="tr [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#132">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/a [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#137">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.htm [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#143">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></sectio [...]
+    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="h [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.GenericByteRunBuilder.html" title= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of logical array encoded by
 the eventual runs array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#148">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" tit [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#153">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/s [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     R: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a [...]
     R: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#83">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
+    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">default</a>() -&g [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,
-    S: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div class= [...]
+    S: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Native" title="type arrow::datatypes::ByteArrayType::Native">Native</a>&gt;,</div></h3></section></summary><div class= [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;S&gt;&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/ [...]
     &lt;R as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
     &lt;V as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div> [...]
@@ -89,8 +89,8 @@ the eventual runs array.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.GenericListBuilder.html b/arrow/array/builder/struct.GenericListBuilder.html
index 82dd50acf71..bccab3579fa 100644
--- a/arrow/array/builder/struct.GenericListBuilder.html
+++ b/arrow/array/builder/struct.GenericListBuilder.html
@@ -1,9 +1,9 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `GenericListArray`"><title>GenericListBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `GenericListArray`"><title>GenericListBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
     T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div>{
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;OffsetSize&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     values_builder: T,
     field: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;&gt;,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a></p>
@@ -56,31 +56,31 @@ builder.append(<span class="bool-val">true</span>);
   array.value_offsets(),
   <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">7</span>]
 );</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.offsets_builder" class="structfield section-header"><a href="#structfield.offsets_builder" class="anchor field">§</a><code>offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;OffsetSize&gt;</code></span><span id="structfield.null_buffer_builder" class="structfield secti [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.offsets_builder" class="structfield section-header"><a href="#structfield.offsets_builder" class="anchor field">§</a><code>offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;OffsetSize&gt;</code></span><span id="structfield.null_buffer_builder" class="structfield secti [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#105">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(values_builder: T) -&gt; <a class="struct"  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#112">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(values_builder: T) -&gt; <a class="struct" href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder">GenericListBu [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     values_builder: T,
     capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder">GenericListBuilder</a>&lt;OffsetSize, T&gt;</h4></section></summary><div class="docblock"><p>Creates a new <a href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder"><code>GenericListBuilder</code></a> from a given values array builder
 <code>capacity</code> is the number of items to pre-allocate space for in this builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_field" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#129">source</a><h4 class="code-header">pub fn <a href="#method.with_field" class="fn">with_field</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_field" class="method"><h4 class="code-header">pub fn <a href="#method.with_field" class="fn">with_field</a>(
     self,
     field: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;&gt;
 ) -&gt; <a class="struct" href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder">GenericListBuilder</a>&lt;OffsetSize, T&gt;</h4></section></summary><div class="docblock"><p>Override the field passed to <a href="../struct.GenericListArray.html#method.new" title="associated function arrow::array::GenericListArray::new"><code>GenericListArray::new</code></a></p>
 <p>By default a nullable field is created with the name <code>item</code></p>
 <p>Note: <a href="struct.GenericListBuilder.html#method.finish" title="method arrow::array::builder::GenericListBuilder::finish"><code>Self::finish</code></a> and <a href="struct.GenericListBuilder.html#method.finish_cloned" title="method arrow::array::builder::GenericListBuilder::finish_cloned"><code>Self::finish_cloned</code></a> will panic if the
 field’s data type does not match that of <code>T</code></p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericListBuilder%3COffsetSize,+T%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#173-175">source</a><a href="#impl-GenericListBuilder%3COffsetSize,+T%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize, T&gt; <a class="struct" href="struct.GenericListBuilder.html" title="struct arrow::array::builder: [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericListBuilder%3COffsetSize,+T%3E-1" class="impl"><a href="#impl-GenericListBuilder%3COffsetSize,+T%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize, T&gt; <a class="struct" href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder">GenericListBuilder</a>&lt;OffsetSize, T&gt;<div class="where">where
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#181">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;mut self) -&gt; <a  [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;mut self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut T</a></h4>< [...]
 <p>This mutable reference can be used to append values into the child array builder,
 but you must call <a href="#method.append"><code>append</code></a> to delimit each distinct list value.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values_ref" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#186">source</a><h4 class="code-header">pub fn <a href="#method.values_ref" class="fn">values_ref</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a></h4></section></summary><div class="docblock"><p>Returns the chi [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#196">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Finish the current variab [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values_ref" class="method"><h4 class="code-header">pub fn <a href="#method.values_ref" class="fn">values_ref</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a></h4></section></summary><div class="docblock"><p>Returns the child array builder as an immutable reference</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Finish the current variable-length list array slot</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if the length of <a href="struct.GenericListBuilder.html#method.values" title="method arrow::array::builder::GenericListBuilder::values"><code>Self::values</code></a> exceeds <code>OffsetSize::MAX</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#258-261">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>&lt;I, V&gt;(&amp;mut self, i: I)<div class="where">where
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>&lt;I, V&gt;(&amp;mut self, i: I)<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html" title="trait core::iter::traits::collect::Extend">Extend</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,</div></h4></section></summary><div class="docblock"><p>Append a value to this <a href="struct.GenericListBuilder.html" title="struct arrow::array::bui [...]
 
@@ -115,31 +115,31 @@ builder.append(<span class="bool-val">true</span>);
 <span class="macro">assert_eq!</span>(array.value_offsets(), <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">4</span>]);
 <span class="kw">let </span>values = array.values().as_primitive::&lt;Int32Type&gt;();
 <span class="macro">assert_eq!</span>(values, <span class="kw-2">&amp;</span>Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">1</span>), <span class="prelude-val">Some</span>(<span class="number">2</span>), <span class="prelude-val">Some</span>(<span class="number">3</span>), <span class="prelude-val">None</span>]));</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#270">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Append a null to this <a href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuild [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Append a null to this <a href="struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder"><code>GenericListBuilder</code></a></p>
 <p>See <a href="struct.GenericListBuilder.html#method.append_value" title="method arrow::array::builder::GenericListBuilder::append_value"><code>Self::append_value</code></a> for an example use.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#279-282">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>&lt;I, V&gt;(&amp;mut self, i: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;I&gt;) [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>&lt;I, V&gt;(&amp;mut self, i: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;I&gt;)<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html" title="trait core::iter::traits::collect::Extend">Extend</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,</div></h4></section></summary><div class="docblock"><p>Appends an optional value into this <a href="struct.GenericListBuilder.html" title="struct arro [...]
 <p>If <code>Some</code> calls <a href="struct.GenericListBuilder.html#method.append_value" title="method arrow::array::builder::GenericListBuilder::append_value"><code>Self::append_value</code></a> otherwise calls <a href="struct.GenericListBuilder.html#method.append_null" title="method arrow::array::builder::GenericListBuilder::append_null"><code>Self::append_null</code></a></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#291">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;</h4></section></summary><div cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#309">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;</h4></section>< [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#326">source</a><h4 class="code-header">pub fn <a href="#method.offsets_slice" class="fn">offsets_slice</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[OffsetSize]</a></h4></section></summary><div class="docblock"><p [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#137-140">source</a><a href="#impl-ArrayBuilder [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;</h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericLis [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;</h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.GenericListArray.html" title="struct arrow:: [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.offsets_slice" class="method"><h4 class="code-header">pub fn <a href="#method.offsets_slice" class="fn">offsets_slice</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[OffsetSize]</a></h4></section></summary><div class="docblock"><p>Returns the current offsets buffer as a slice</p>
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize, T&gt [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#143">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Arra [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#148">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#153">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#158">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#163">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title=" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#168">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.GenericListBuilder.html" title="st [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     OffsetSize: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
-    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder. [...]
+    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Default">Default</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/gen [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Default">Default</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-heade [...]
     O: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
     B: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html" title="trait core::iter::traits::collect::Extend">Extend</a>&lt;E&gt;,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = E&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#338">source</a><a href="#method.ext [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = E&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/tra [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;V&gt;&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/ [...]
     OffsetSize: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div></h3></section><section id="impl-Send-for-GenericListBuilder%3COffsetSize,+T%3E" class="impl"><a href="#impl-Send-for-GenericListBuilder%3COffsetSize,+T%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize, T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait [...]
@@ -155,8 +155,8 @@ builder.append(<span class="bool-val">true</span>);
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.MapBuilder.html b/arrow/array/builder/struct.MapBuilder.html
index e654952332b..93d3f59e3ab 100644
--- a/arrow/array/builder/struct.MapBuilder.html
+++ b/arrow/array/builder/struct.MapBuilder.html
@@ -1,9 +1,9 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `MapArray`"><title>MapBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../. [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `MapArray`"><title>MapBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../. [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     K: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,
     V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div>{
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     field_names: <a class="struct" href="struct.MapFieldNames.html" title="struct arrow::array::builder::MapFieldNames">MapFieldNames</a>,
     key_builder: K,
     value_builder: V,
@@ -33,32 +33,32 @@ builder.append(<span class="bool-val">false</span>).unwrap();
 <span class="macro">assert_eq!</span>(array.values().as_ref(), <span class="kw-2">&amp;</span>Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>]));
 <span class="macro">assert_eq!</span>(array.keys().as_ref(), <span class="kw-2">&amp;</span>StringArray::from(<span class="macro">vec!</span>[<span class="string">"joe"</span>, <span class="string">"blogs"</span>, <span class="string">"foo"</span>]));
 </code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.offsets_builder" class="structfield section-header"><a href="#structfield.offsets_builder" class="anchor field">§</a><code>offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.offsets_builder" class="structfield section-header"><a href="#structfield.offsets_builder" class="anchor field">§</a><code>offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt [...]
     K: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,
-    V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#89">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
+    V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>(
     field_names: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="struct.MapFieldNames.html" title="struct arrow::array::builder::MapFieldNames">MapFieldNames</a>&gt;,
     key_builder: K,
     value_builder: V
 ) -&gt; <a class="struct" href="struct.MapBuilder.html" title="struct arrow::array::builder::MapBuilder">MapBuilder</a>&lt;K, V&gt;</h4></section></summary><div class="docblock"><p>Creates a new <code>MapBuilder</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#95-100">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     field_names: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="struct.MapFieldNames.html" title="struct arrow::array::builder::MapFieldNames">MapFieldNames</a>&gt;,
     key_builder: K,
     value_builder: V,
     capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.MapBuilder.html" title="struct arrow::array::builder::MapBuilder">MapBuilder</a>&lt;K, V&gt;</h4></section></summary><div class="docblock"><p>Creates a new <code>MapBuilder</code> with capacity</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#113">source</a><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;mut self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut K</a></h4></section></summary><div class="docblock"><p>Returns the key array builder of t [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#118">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;mut self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut V</a></h4></section></summary><div class="docblock"><p>Returns the value array buil [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.entries" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#123">source</a><h4 class="code-header">pub fn <a href="#method.entries" class="fn">entries</a>(&amp;mut self) -&gt; (<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut K</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primiti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#131">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Resu [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.keys" class="method"><h4 class="code-header">pub fn <a href="#method.keys" class="fn">keys</a>(&amp;mut self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut K</a></h4></section></summary><div class="docblock"><p>Returns the key array builder of the map</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;mut self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut V</a></h4></section></summary><div class="docblock"><p>Returns the value array builder of the map</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.entries" class="method"><h4 class="code-header">pub fn <a href="#method.entries" class="fn">entries</a>(&amp;mut self) -&gt; (<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut K</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut V</a>)</h4></section></summary><div class="docblock"><p>Returns both th [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rus [...]
 <p>Returns an error if the key and values builders are in an inconsistent state.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#145">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.MapA [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#158">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h4></section></summary><div class="docblock"><p>Builds the <a hre [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#213">source</a><a href="#impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" cla [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a></p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a> without [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="trait" href="trait.ArrayBuilder [...]
     K: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,
-    V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#223">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#214">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary>< [...]
+    V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class='docblock'>Returns the number of array slots in the builder</div></details><details class [...]
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,
-    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#5 [...]
+    V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a>,</div></h3></section><section id="impl-Send-for-MapBuilder%3CK,+V%3E" class="impl"><a href="#impl-Send-for-MapBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send [...]
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,
@@ -73,8 +73,8 @@ builder.append(<span class="bool-val">false</span>).unwrap();
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.MapFieldNames.html b/arrow/array/builder/struct.MapFieldNames.html
index be900f4e667..bed66ffcc70 100644
--- a/arrow/array/builder/struct.MapFieldNames.html
+++ b/arrow/array/builder/struct.MapFieldNames.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The `Field` names for a `MapArray`"><title>MapFieldNames in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossor [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The `Field` names for a `MapArray`"><title>MapFieldNames in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossor [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     pub entry: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
     pub key: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
     pub value: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
@@ -7,7 +7,7 @@
 </div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.entry" class="structfield section-header"><a href="#structfield.entry" class="anchor field">§</a><code>entry: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><div class="docblock"><p><a href="../../datatypes/struct.Field.html" title="struct arrow::datatyp [...]
 </div><span id="structfield.key" class="structfield section-header"><a href="#structfield.key" class="anchor field">§</a><code>key: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><div class="docblock"><p><a href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field"><code>Field</code></a> name for map key</p>
 </div><span id="structfield.value" class="structfield section-header"><a href="#structfield.value" class="anchor field">§</a><code>value: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><div class="docblock"><p><a href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field"><code>Field</code></a> name for map value</p>
-</div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-MapFieldNames" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#67">source</a><a href="#impl-Clone-for-MapFieldNames" class="anchor">§</a><h3 class="code-header">impl <a class="trait [...]
+</div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-MapFieldNames" class="impl"><a href="#impl-Clone-for-MapFieldNames" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::C [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
@@ -17,8 +17,8 @@
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-ToOwned-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/alloc/borrow.rs.html#83-85">source</a><a href="#impl-ToOwned-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html" title="trait alloc::borrow::ToOwned">ToOwned</a> for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associate [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.NullBuilder.html b/arrow/array/builder/struct.NullBuilder.html
index c10d2286583..8cf279335ee 100644
--- a/arrow/array/builder/struct.NullBuilder.html
+++ b/arrow/array/builder/struct.NullBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `NullArray`"><title>NullBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=".. [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `NullArray`"><title>NullBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=".. [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.NullArray.html" title="struct arrow::array::NullArray"><code>NullArray</code></a></p>
 <h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
@@ -16,22 +16,22 @@ b.append_empty_values(<span class="number">3</span>);
 
 <span class="macro">assert_eq!</span>(<span class="number">8</span>, arr.len());
 <span class="macro">assert_eq!</span>(<span class="number">0</span>, arr.null_count());</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><h2 id="implementations" class="section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#63">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.NullBuilder.html" title="struct arrow: [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#68">source</a><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of this builde [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#74">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_nulls" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#80">source</a><h4 class="code-header">pub fn <a href="#method.append_nulls" class="fn">append_nulls</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</code [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_empty_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#86">source</a><h4 class="code-header">pub fn <a href="#method.append_empty_value" class="fn">append_empty_value</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_empty_values" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#92">source</a><h4 class="code-header">pub fn <a href="#method.append_empty_values" class="fn">append_empty_values</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#97">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.N [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#106">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a></h4></section></summary><div class="docblock"><p>Builds the <a [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-NullBuilder" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#115">source</a><a href="#impl-ArrayBuilder-for-NullBuilder" class="anchor">§</a> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#122">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#127">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="st [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#132">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary> [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#137">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct a [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/null_builder.rs.html#142">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.A [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><h2 id="implementations" class="section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.NullBuilder.html" title="struct arrow::array::builder::NullBuilder">NullBuilder</a></h4></section></summary><div class="docblock"><p>Crea [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of this builder measured in slots of type <code>T</code></p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_nulls" class="method"><h4 class="code-header">pub fn <a href="#method.append_nulls" class="fn">append_nulls</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</code> <code>null</code>s into the builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_empty_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_empty_value" class="fn">append_empty_value</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_empty_values" class="method"><h4 class="code-header">pub fn <a href="#method.append_empty_values" class="fn">append_empty_values</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</code> <code>null</code>s into the builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a> and reset this builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a></h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a> without resett [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-NullBuilder" class="impl"><a href="#impl-ArrayBuilder-for-NullBuilder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::arr [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.NullBuilder.html" title="struct ar [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
@@ -40,8 +40,8 @@ b.append_empty_values(<span class="number">3</span>);
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.PrimitiveBuilder.html b/arrow/array/builder/struct.PrimitiveBuilder.html
index 9d88e8eb231..9e4ba81902f 100644
--- a/arrow/array/builder/struct.PrimitiveBuilder.html
+++ b/arrow/array/builder/struct.PrimitiveBuilder.html
@@ -1,74 +1,74 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `PrimitiveArray`"><title>PrimitiveBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `PrimitiveArray`"><title>PrimitiveBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div>{
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a></p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow: [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#143">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class= [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#148">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="st [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#157-160">source</a><h4 class="code-header">pub fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow: [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">Primi [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;T&gt;</h4></section></summary><div  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_buffer" class="method"><h4 class="code-header">pub fn <a href="#method.new_from_buffer" class="fn">new_from_buffer</a>(
     values_buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     null_buffer: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>&gt;
 ) -&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Creates a new primitive array builder from buffers</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_data_type" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#183">source</a><h4 class="code-header">pub fn <a href="#method.with_data_type" class="fn">with_data_type</a>(self, data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>) -&gt; <a class="struct" href="struct.Primitiv [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_data_type" class="method"><h4 class="code-header">pub fn <a href="#method.with_data_type" class="fn">with_data_type</a>(self, data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>) -&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;T&gt;</h4>< [...]
 data type of the generated array.</p>
 <p>This method allows overriding the data type, to allow specifying timezones
 for <a href="../../datatypes/enum.DataType.html#variant.Timestamp" title="variant arrow::datatypes::DataType::Timestamp"><code>DataType::Timestamp</code></a> or precision and scale for <a href="../../datatypes/enum.DataType.html#variant.Decimal128" title="variant arrow::datatypes::DataType::Decimal128"><code>DataType::Decimal128</code></a> and <a href="../../datatypes/enum.DataType.html#variant.Decimal256" title="variant arrow::datatypes::DataType::Decimal256"><code>DataType::Decimal256< [...]
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>This method panics if <code>data_type</code> is not <a href="../struct.PrimitiveArray.html#method.is_compatible" title="associated function arrow::array::PrimitiveArray::is_compatible">PrimitiveArray::is_compatible</a></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#194">source</a><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of this  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#200">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, v: &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a c [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#207">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_nulls" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#214">source</a><h4 class="code-header">pub fn <a href="#method.append_nulls" class="fn">append_nulls</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#221">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(&amp;mut self, v: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#230">source</a><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, v: &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt; [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_values" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#241">source</a><h4 class="code-header">pub fn <a href="#method.append_values" class="fn">append_values</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.capacity" class="method"><h4 class="code-header">pub fn <a href="#method.capacity" class="fn">capacity</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the capacity of this builder measured in slots of type <code>T</code></p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, v: &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_nulls" class="method"><h4 class="code-header">pub fn <a href="#method.append_nulls" class="fn">append_nulls</a>(&amp;mut self, n: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)</h4></section></summary><div class="docblock"><p>Appends <code>n</code> no. of null’s into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(&amp;mut self, v: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"> [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_slice" class="method"><h4 class="code-header">pub fn <a href="#method.append_slice" class="fn">append_slice</a>(&amp;mut self, v: &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" ti [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_values" class="method"><h4 class="code-header">pub fn <a href="#method.append_values" class="fn">append_values</a>(
     &amp;mut self,
     values: &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>],
     is_valid: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>]
 )</h4></section></summary><div class="docblock"><p>Appends values from a slice of type <code>T</code> and a validity boolean slice</p>
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if <code>values</code> and <code>is_valid</code> have different lengths</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_trusted_len_iter" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#257">source</a><h4 class="code-header">pub unsafe fn <a href="#method.append_trusted_len_iter" class="fn">append_trusted_len_iter</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_trusted_len_iter" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.append_trusted_len_iter" class="fn">append_trusted_len_iter</a>(
     &amp;mut self,
     iter: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes [...]
 )</h4></section></summary><div class="docblock"><p>Appends values from a trusted length iterator.</p>
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>This requires the iterator be a trusted length. This could instead require
 the iterator implement <code>TrustedLen</code> once that is stabilized.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#269">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>B [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#282">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div clas [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#296">source</a><h4 class="code-header">pub fn <a href="#method.values_slice" class="fn">values_slice</a>(&amp;self) -&gt; &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;: [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#301">source</a><h4 class="code-header">pub fn <a href="#method.values_slice_mut" class="fn">values_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPr [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#306">source</a><h4 class="code-header">pub fn <a href="#method.validity_slice" class="fn">validity_slice</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primiti [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#311">source</a><h4 class="code-header">pub fn <a href="#method.validity_slice_mut" class="fn">validity_slice_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;mu [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.slices_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#316">source</a><h4 class="code-header">pub fn <a href="#method.slices_mut" class="fn">slices_mut</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>Primi [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;</h4></section></summary><div class="docblock"><p>Builds the <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveA [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice" class="method"><h4 class="code-header">pub fn <a href="#method.values_slice" class="fn">values_slice</a>(&amp;self) -&gt; &amp;[&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" tit [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice_mut" class="method"><h4 class="code-header">pub fn <a href="#method.values_slice_mut" class="fn">values_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice" class="method"><h4 class="code-header">pub fn <a href="#method.validity_slice" class="fn">validity_slice</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</h4></section></summary><d [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.validity_slice_mut" class="method"><h4 class="code-header">pub fn <a href="#method.validity_slice_mut" class="fn">validity_slice_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</h4></ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.slices_mut" class="method"><h4 class="code-header">pub fn <a href="#method.slices_mut" class="fn">slices_mut</a>(
     &amp;mut self
 ) -&gt; (&amp;mut [&lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>], <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;mut  [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveBuilder%3CP%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#324">source</a><a href="#impl-PrimitiveBuilder%3CP%3E" class="anchor">§</a><h3 class="code-header">impl&lt;P&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;P&gt;<div  [...]
-    P: <a class="trait" href="../../datatypes/trait.DecimalType.html" title="trait arrow::datatypes::DecimalType">DecimalType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.with_precision_and_scale" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#326">source</a><h4 class="code-header">pub fn <a href="#method.with_precision_and_scale" class="fn">with [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveBuilder%3CP%3E" class="impl"><a href="#impl-PrimitiveBuilder%3CP%3E" class="anchor">§</a><h3 class="code-header">impl&lt;P&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;P&gt;<div class="where">where
+    P: <a class="trait" href="../../datatypes/trait.DecimalType.html" title="trait arrow::datatypes::DecimalType">DecimalType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.with_precision_and_scale" class="method"><h4 class="code-header">pub fn <a href="#method.with_precision_and_scale" class="fn">with_precision_and_scale</a>(
     self,
     precision: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>,
     scale: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;P&gt;, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</h4></section></summary><div class="docblock"><p>Sets the precision and scale</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveBuilder%3CP%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#335">source</a><a href="#impl-PrimitiveBuilder%3CP%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;P&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;P&gt;< [...]
-    P: <a class="trait" href="../../datatypes/trait.ArrowTimestampType.html" title="trait arrow::datatypes::ArrowTimestampType">ArrowTimestampType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.with_timezone" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#337">source</a><h4 class="code-header">pub fn <a href="#method.with_timezone" class="fn">with_ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone_opt" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#342">source</a><h4 class="code-header">pub fn <a href="#method.with_timezone_opt" class="fn">with_timezone_opt</a>&lt;S&gt;(self, timezone: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;S&gt;) [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveBuilder%3CP%3E-1" class="impl"><a href="#impl-PrimitiveBuilder%3CP%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;P&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;P&gt;<div class="where">where
+    P: <a class="trait" href="../../datatypes/trait.ArrowTimestampType.html" title="trait arrow::datatypes::ArrowTimestampType">ArrowTimestampType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.with_timezone" class="method"><h4 class="code-header">pub fn <a href="#method.with_timezone" class="fn">with_timezone</a>(self, timezone: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_timezone_opt" class="method"><h4 class="code-header">pub fn <a href="#method.with_timezone_opt" class="fn">with_timezone_opt</a>&lt;S&gt;(self, timezone: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;S&gt;) -&gt; <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::Primiti [...]
     S: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class="docblock"><p>Sets an optional timezone</p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#103">source</a><a href="#impl-ArrayBuilder-for-PrimitiveBuilder [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#105">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#110">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trai [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#115">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" titl [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#120">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></sum [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#125">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="str [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#130">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/str [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="impl"><a href="#impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.ArrayBuil [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.PrimitiveBuilder.html" title="stru [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#136">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn < [...]
-    P: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#352">source</a><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a  [...]
+    &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">de [...]
+    P: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend" class [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;P as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a  [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
     &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><sectio [...]
@@ -81,8 +81,8 @@ the iterator implement <code>TrustedLen</code> once that is stabilized.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html b/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html
index b18b58ba7a6..1e5ccd73d09 100644
--- a/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html
+++ b/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html
@@ -1,10 +1,10 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `PrimitiveArray`"><title>PrimitiveDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `PrimitiveArray`"><title>PrimitiveDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div>{
     keys_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
     values_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;V&gt;,
-    map: <a class="struct" href="https://doc.rust-lang.org/nightly/std/collections/hash/map/struct.HashMap.html" title="struct std::collections::hash::map::HashMap">HashMap</a>&lt;<a class="struct" href="../../../arrow_array/builder/primitive_dictionary_builder/struct.Value.html" title="struct arrow_array::builder::primitive_dictionary_builder::Value">Value</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveT [...]
+    map: <a class="struct" href="https://doc.rust-lang.org/nightly/std/collections/hash/map/struct.HashMap.html" title="struct std::collections::hash::map::HashMap">HashMap</a>&lt;Value&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitive [...]
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray</code></a> of <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a></p>
 <h2 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -30,65 +30,65 @@
  <span class="macro">assert!</span>(!array.is_null(<span class="number">2</span>));
 
  <span class="macro">assert_eq!</span>(avs, <span class="kw-2">&amp;</span>[<span class="number">12345678</span>, <span class="number">22345678</span>]);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.keys_builder" class="structfield section-header"><a href="#structfield.keys_builder" class="anchor field">§</a><code>keys_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;</code></span><span id="structfield.values_builder" class="structfield section-header"><a  [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.keys_builder" class="structfield section-header"><a href="#structfield.keys_builder" class="anchor field">§</a><code>keys_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;</code></span><span id="structfield.values_builder" class="structfield section-header"><a  [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#107">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_empty_builders" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#120-123">source</a><h4 class="code-header">pub fn <a href="#method.new_from_empty_builders" class="fn">new_from_empty_builders</a>(
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" href="struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::builder::PrimitiveDict [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_empty_builders" class="method"><h4 class="code-header">pub fn <a href="#method.new_from_empty_builders" class="fn">new_from_empty_builders</a>(
     keys_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
     values_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;V&gt;
 ) -&gt; <a class="struct" href="struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::builder::PrimitiveDictionaryBuilder">PrimitiveDictionaryBuilder</a>&lt;K, V&gt;</h4></section></summary><div class="docblock"><p>Creates a new <code>PrimitiveDictionaryBuilder</code> from the provided keys and values builders.</p>
 <h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>This method panics if <code>keys_builder</code> or <code>values_builder</code> is not empty.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_builders" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#140-143">source</a><h4 class="code-header">pub unsafe fn <a href="#method.new_from_builders" class="fn">new_from_builders</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_from_builders" class="method"><h4 class="code-header">pub unsafe fn <a href="#method.new_from_builders" class="fn">new_from_builders</a>(
     keys_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
     values_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;V&gt;
 ) -&gt; <a class="struct" href="struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::builder::PrimitiveDictionaryBuilder">PrimitiveDictionaryBuilder</a>&lt;K, V&gt;</h4></section></summary><div class="docblock"><p>Creates a new <code>PrimitiveDictionaryBuilder</code> from existing <code>PrimitiveBuilder</code>s of keys and values.</p>
 <h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>caller must ensure that the passed in builders are valid for DictionaryArray.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#163">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(
     keys_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     values_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::builder::PrimitiveDictionaryBuilder">PrimitiveDictionaryBuilder</a>&lt;K, V&gt;</h4></section></summary><div class="docblock"><p>Creates a new <code>PrimitiveDictionaryBuilder</code> with the provided capacities</p>
 <p><code>keys_capacity</code>: the number of keys, i.e. length of array to build
 <code>values_capacity</code>: the number of distinct dictionary values, i.e. size of dictionary</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveDictionaryBuilder%3CK,+V%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#208-211">source</a><a href="#impl-PrimitiveDictionaryBuilder%3CK,+V%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="struct" href="struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::bui [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveDictionaryBuilder%3CK,+V%3E-1" class="impl"><a href="#impl-PrimitiveDictionaryBuilder%3CK,+V%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="struct" href="struct.PrimitiveDictionaryBuilder.html" title="struct arrow::array::builder::PrimitiveDictionaryBuilder">PrimitiveDictionaryBuilder</a>&lt;K, V&gt;<div class="where">where
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#217">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(
     &amp;mut self,
     value: &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;&lt;K as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>, <a class="enum" href= [...]
 if already present in the values array or a new index if the
 value is appended to the values array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#239">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveTyp [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" titl [...]
 <h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if the resulting length of the dictionary values array would exceed <code>T::Native::MAX</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#245">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#255">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null slot into the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
     &amp;mut self,
     value: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;
 )</h4></section></summary><div class="docblock"><p>Append an <code>Option</code> value into the builder</p>
 <h5 id="panics-2"><a class="doc-anchor" href="#panics-2">§</a>Panics</h5>
 <p>Panics if the resulting length of the dictionary values array would exceed <code>T::Native::MAX</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#263">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class=" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#281">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></sum [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#297">source</a><h4 class="code-header">pub fn <a href="#method.values_slice" class="fn">values_slice</a>(&amp;self) -&gt; &amp;[&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveTy [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#302">source</a><h4 class="code-header">pub fn <a href="#method.values_slice_mut" class="fn">values_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveTy [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#172-175">source</a><a href="#impl-Array [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Builds the <code>DictionaryArray</code> and reset this builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;</h4></section></summary><div class="docblock"><p>Builds the <code>DictionaryArray</code> without resetting the builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice" class="method"><h4 class="code-header">pub fn <a href="#method.values_slice" class="fn">values_slice</a>(&amp;self) -&gt; &amp;[&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" tit [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.values_slice_mut" class="method"><h4 class="code-header">pub fn <a href="#method.values_slice_mut" class="fn">values_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associ [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class= [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#178">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-hea [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#183">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/co [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#188">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#193">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></se [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#198">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#203">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/all [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.PrimitiveDictionaryBuilder.html" t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of array slots in the builder</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
+    &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#96">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-he [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">de [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    P: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#311">source</a><a href="#method.extend" class="anchor">§</a><h4 class="code-hea [...]
+    P: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend" class [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;P as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a  [...]
     &lt;K as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
     &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
@@ -104,8 +104,8 @@ value is appended to the values array.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.PrimitiveRunBuilder.html b/arrow/array/builder/struct.PrimitiveRunBuilder.html
index 76d20d406ab..07d67ed2a23 100644
--- a/arrow/array/builder/struct.PrimitiveRunBuilder.html
+++ b/arrow/array/builder/struct.PrimitiveRunBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `PrimitiveArray`"><title>PrimitiveRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `PrimitiveArray`"><title>PrimitiveRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div>{
     run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;,
@@ -33,40 +33,40 @@ builder.append_value(<span class="number">5678</span>);
 </span><span class="kw">let </span>ava: <span class="kw-2">&amp;</span>UInt32Array = av.as_primitive::&lt;UInt32Type&gt;();
 
 <span class="macro">assert_eq!</span>(ava, <span class="kw-2">&amp;</span>UInt32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">1234</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="number">5678</span>)]));</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.run_ends_builder" class="structfield section-header"><a href="#structfield.run_ends_builder" class="anchor field">§</a><code>run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;</code></span><span id="structfield.values_builder" class="structfield section [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.run_ends_builder" class="structfield section-header"><a href="#structfield.run_ends_builder" class="anchor field">§</a><code>run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;</code></span><span id="structfield.values_builder" class="structfield section [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#89">source</a><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#102">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.PrimitiveRunBuilder.html" ti [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.new" class="method"><h4 class="code-header">pub fn <a href="#method.new" class="fn">new</a>() -&gt; <a class="struct" href="struct.PrimitiveRunBuilder.html" title="struct arrow::array::builder::PrimitiveRunBuilder" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity" class="fn">with_capacity</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.PrimitiveRunBuilder.html" title="struct arrow::array::builder::PrimitiveRunBuilder">PrimitiveRunBuilder</a>&lt;R, V&gt;</h4></section></s [...]
 <p><code>capacity</code>: the expected number of run-end encoded values.</p>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveRunBuilder%3CR,+V%3E-1" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#150-153">source</a><a href="#impl-PrimitiveRunBuilder%3CR,+V%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="struct" href="struct.PrimitiveRunBuilder.html" title="struct arrow::array::builder::PrimitiveRunBuilder">P [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PrimitiveRunBuilder%3CR,+V%3E-1" class="impl"><a href="#impl-PrimitiveRunBuilder%3CR,+V%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="struct" href="struct.PrimitiveRunBuilder.html" title="struct arrow::array::builder::PrimitiveRunBuilder">PrimitiveRunBuilder</a>&lt;R, V&gt;<div class="where">where
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#156">source</a><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">a [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.append_option" class="method"><h4 class="code-header">pub fn <a href="#method.append_option" class="fn">append_option</a>(
     &amp;mut self,
     value: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;
 )</h4></section></summary><div class="docblock"><p>Appends optional value to the logical array encoded by the RunArray.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#171">source</a><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&g [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#176">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends null to the logical array encoded by the run-ends array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#182">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Creates the Run [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_value" class="method"><h4 class="code-header">pub fn <a href="#method.append_value" class="fn">append_value</a>(&amp;mut self, value: &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" titl [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends null to the logical array encoded by the run-ends array.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Creates the RunArray and resets the builder.
 Panics if RunArray cannot be built.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#198">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock">< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docblock"><p>Creates the RunArray and without resetting the builder.
 Panics if RunArray cannot be built.</p>
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#113-116">source</a><a href="#impl-ArrayBuilder-for-Pr [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="trait" href=" [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#119">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#124">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#129">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html"  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#135">source</a><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section>< [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.PrimitiveRunBuilder.html" title="s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method trait-impl"><a href="#method.len" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the length of logical array encoded by
 the eventual runs array.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#140">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title= [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#145">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     R: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a> + <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
-    &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
+    &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" title="trait core::fmt::Debug">Debug</a>,</div></h3></section></summary><di [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#78">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">f [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.default" class="method trait-impl"><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" class="fn">de [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#253">source</a><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend" class [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a  [...]
     &lt;R as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
     &lt;V as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe" [...]
@@ -82,8 +82,8 @@ the eventual runs array.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
-    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a class="src rightside" href="../../../src/arrow_buffer/alloc/mod.rs.html#33">source</a><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
+    V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Allocation-for-T" class="impl"><a href="#impl-Allocation-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../../alloc/trait.Allocation.html" title="trait arrow::allo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</div></h3></section><section id="impl-Ungil-fo [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.StructBuilder.html b/arrow/array/builder/struct.StructBuilder.html
index 972f0be64af..896247351dc 100644
--- a/arrow/array/builder/struct.StructBuilder.html
+++ b/arrow/array/builder/struct.StructBuilder.html
@@ -1,42 +1,42 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `StructArray`"><title>StructBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `StructArray`"><title>StructBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>,
     field_builders: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>&gt;&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a></p>
 <p>Note that callers should make sure that methods of all the child field builders are
 properly called to maintain the consistency of the data structure.</p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.fields" class="structfield section-header"><a href="#structfield.fields" class="anchor field">§</a><code>fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a></code></span><span id="structfield.field_builders" class="structfield section-header"><a href="#structfield.field_builders" class="anch [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.fields" class="structfield section-header"><a href="#structfield.fields" class="anchor field">§</a><code>fields: <a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a></code></span><span id="structfield.field_builders" class="structfield section-header"><a href="#structfield.field_builders" class="anch [...]
     fields: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>&gt;,
     field_builders: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>&gt;&gt;
 ) -&gt; <a class="struct" href="struct.StructBuilder.html" title="struct arrow::array::builder::StructBuilder">StructBuilder</a></h4></section></summary><div class="docblock"><p>Creates a new <code>StructBuilder</code></p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.from_fields" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#214">source</a><h4 class="code-header">pub fn <a href="#method.from_fields" class="fn">from_fields</a>(fields: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="../../datatypes/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.field_builder" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#226">source</a><h4 class="code-header">pub fn <a href="#method.field_builder" class="fn">field_builder</a>&lt;T&gt;(&amp;mut self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/n [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.from_fields" class="method"><h4 class="code-header">pub fn <a href="#method.from_fields" class="fn">from_fields</a>(fields: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;<a class="struct" href="../../datatypes/struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>&gt;, capacity: <a class="primit [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.field_builder" class="method"><h4 class="code-header">pub fn <a href="#method.field_builder" class="fn">field_builder</a>&lt;T&gt;(&amp;mut self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primiti [...]
     T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h4></section></summary><div class="docblock"><p>Returns a mutable reference to the child field builder at index <code>i</code>.
 Result will be <code>None</code> if the input type <code>T</code> provided doesn’t match the actual
 field builder’s type.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.num_fields" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#231">source</a><h4 class="code-header">pub fn <a href="#method.num_fields" class="fn">num_fields</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of fiel [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#238">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends an element (either null [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.num_fields" class="method"><h4 class="code-header">pub fn <a href="#method.num_fields" class="fn">num_fields</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number of fields for the struct this builder is building.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>(&amp;mut self, is_valid: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>)</h4></section></summary><div class="docblock"><p>Appends an element (either null or non-null) to the struct. The actual elements
 should be appended for each child sub-array in a consistent way.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#244">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null element to the struct.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#249">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Builds the <code>Struc [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#261">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Build [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-StructBuilder" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#45">source</a><a href="#impl-ArrayBuilder-for-StructBuilder" class="anchor"> [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Appends a null element to the struct.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Builds the <code>StructArray</code> and reset this builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class="docblock"><p>Builds the <code>StructArray</code> without resetting the builder.</p>
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-StructBuilder" class="impl"><a href="#impl-ArrayBuilder-for-StructBuilder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow: [...]
 <p>Note that this always return the first child field builder’s length, and it is
 the caller’s responsibility to maintain the consistency that all the child field
 builder should have the equal number of elements.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#56">source</a><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct  [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#61">source</a><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct. [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#70">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait cor [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish-1" class="method trait-impl"><a href="#method.finish-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::arra [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned-1" class="method trait-impl"><a href="#method.finish_cloned-1" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html"  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock"><p>Returns the builder  [...]
 <p>This is most useful when one wants to call non-mutable APIs on a specific builder
 type. In this case, one can first cast this into a <code>Any</code>, and then use
 <code>downcast_ref</code> to get a reference on the specific builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#79">source</a><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.An [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_any_mut" class="method trait-impl"><a href="#method.as_any_mut" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock" [...]
 <p>This is most useful when one wants to call mutable APIs on a specific builder
 type. In this case, one can first cast this into a <code>Any</code>, and then use
 <code>downcast_mut</code> to get a reference on the specific builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/struct_builder.rs.html#84">source</a><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="s [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></s [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.into_box_any" class="method trait-impl"><a href="#method.into_box_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="struct" href="struct.StructBuilder.html" title="struct  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method trait-impl"><a href="#method.is_empty" class="anchor">§</a><h4 class="code-header">fn <a href="trait.ArrayBuilder.html#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class='docblock'>Returns whether number of array slots is zero</div></details>< [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
@@ -45,7 +45,7 @@ type. In this case, one can first cast this into a <code>Any</code>, and then us
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details><section id="impl-Ungil-for-T" class="impl"><a href="#impl-Ungil-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; Ungil for T<div class="where">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,</div></h3></section></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/struct.UnionBuilder.html b/arrow/array/builder/struct.UnionBuilder.html
index 792dd604512..76925eb6c98 100644
--- a/arrow/array/builder/struct.UnionBuilder.html
+++ b/arrow/array/builder/struct.UnionBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `UnionArray`"><title>UnionBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `UnionArray`"><title>UnionBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
-    fields: <a class="struct" href="https://doc.rust-lang.org/nightly/std/collections/hash/map/struct.HashMap.html" title="struct std::collections::hash::map::HashMap">HashMap</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>, <a class="struct" href="../../../arrow_array/builder/union_builder/struct.FieldData.html" title="struct arrow_array::builder::union_builder::FieldData">FieldData</a>&gt;,
+    fields: <a class="struct" href="https://doc.rust-lang.org/nightly/std/collections/hash/map/struct.HashMap.html" title="struct std::collections::hash::map::HashMap">HashMap</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>, FieldData&gt;,
     type_id_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;,
     value_offset_builder: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;&gt;,
     initial_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -38,25 +38,25 @@ builder.append::&lt;Int32Type&gt;(<span class="string">"a"</span>, <span class="
 <span class="macro">assert_eq!</span>(union.value_offset(<span class="number">0</span>), <span class="number">0</span>);
 <span class="macro">assert_eq!</span>(union.value_offset(<span class="number">1</span>), <span class="number">1</span>);
 <span class="macro">assert_eq!</span>(union.value_offset(<span class="number">2</span>), <span class="number">2</span>);</code></pre></div>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><span id="structfield.fields" class="structfield section-header"><a href="#structfield.fields" class="anchor field">§</a><code>fields: <a class=" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.new_sparse" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#160">source</a><h4 class="code-header">pub fn <a href="#method.new_sparse" class="fn">new_sparse</a>() -&gt; <a class="struct" href="struct.UnionBuilder.html" title="struct arrow::array::builder::UnionBuilder">UnionBuilder</a></h4></section></summary><div class="docblock"><p>Creates a new s [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity_dense" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#165">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity_dense" class="fn">with_capacity_dense</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.UnionBuilder.html" [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity_sparse" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#176">source</a><h4 class="code-header">pub fn <a href="#method.with_capacity_sparse" class="fn">with_capacity_sparse</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.UnionBuilder.ht [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#194-197">source</a><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>&lt;T&gt;(&amp;mut self, type_name: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" href="https://doc.rust-lang [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a><code>len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></code></span><span id="structfield.fields" class="structfield section-header"><a href="#structfield.fields" class="anchor field">§</a><code>fields: <a class=" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.new_sparse" class="method"><h4 class="code-header">pub fn <a href="#method.new_sparse" class="fn">new_sparse</a>() -&gt; <a class="struct" href="struct.UnionBuilder.html" title="struct arrow::array::builder::UnionBuilder">UnionBuilder</a></h4></section></summary><div class="docblock"><p>Creates a new sparse array builder.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity_dense" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity_dense" class="fn">with_capacity_dense</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.UnionBuilder.html" title="struct arrow::array::builder::UnionBuilder">UnionBuilder</a></h4></section></summary><div cla [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.with_capacity_sparse" class="method"><h4 class="code-header">pub fn <a href="#method.with_capacity_sparse" class="fn">with_capacity_sparse</a>(capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="struct" href="struct.UnionBuilder.html" title="struct arrow::array::builder::UnionBuilder">UnionBuilder</a></h4></section></summary><div  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append_null" class="method"><h4 class="code-header">pub fn <a href="#method.append_null" class="fn">append_null</a>&lt;T&gt;(&amp;mut self, type_name: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="prim [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class="docblock"><p>Appends a null to this builder, encoding the null in the array
 of the <code>type_name</code> child / field.</p>
 <p>Since <code>UnionArray</code> encodes nulls as an entry in its children
 (it doesn’t have a validity bitmap itself), and where the null
 is part of the final array, appending a NULL requires
 specifying which field (child) to use.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#203-207">source</a><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>&lt;T&gt;(
+</div></details><details class="toggle method-toggle" open><summary><section id="method.append" class="method"><h4 class="code-header">pub fn <a href="#method.append" class="fn">append</a>&lt;T&gt;(
     &amp;mut self,
     type_name: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>,
     v: &lt;T as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="../../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;<div class="where">where
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h4></section></summary><div class="docblock"><p>Appends a value to this builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.build" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#277">source</a><h4 class="code-header">pub fn <a href="#method.build" class="fn">build</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.UnionArray.html" title="s [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-UnionBuilder" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/union_builder.rs.html#140">source</a><a href="#impl-Debug-for-UnionBuilder" class="anchor">§</a><h3 class=" [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.build" class="method"><h4 class="code-header">pub fn <a href="#method.build" class="fn">build</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../struct.UnionArray.html" title="struct arrow::array::UnionArray">UnionArray</a>, <a class="enum" href="../../error/enum.ArrowError.htm [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-Debug-for-UnionBuilder" class="impl"><a href="#impl-Debug-for-UnionBuilder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html" [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#210">source</a><a href="#method.borrow" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.borrow_mut" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/borrow.rs.html#217">source</a><a href="#method.borrow_mut" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
@@ -65,6 +65,6 @@ specifying which field (child) to use.</p>
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
 </div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#804-806">source</a><a href="#impl-TryFrom%3CU%3E-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T, U&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;U [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class= [...]
-    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype. [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" cl [...]
+    U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Erro [...]
     V: MultiLane&lt;T&gt;,</div></h3></section></summary><div class="impl-items"><section id="method.vzip" class="method trait-impl"><a href="#method.vzip" class="anchor">§</a><h4 class="code-header">fn <a class="fn">vzip</a>(self) -&gt; V</h4></section></div></details></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/trait.ArrayBuilder.html b/arrow/array/builder/trait.ArrayBuilder.html
index c45d865e779..ef610098c47 100644
--- a/arrow/array/builder/trait.ArrayBuilder.html
+++ b/arrow/array/builder/trait.ArrayBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Trait for dealing with different array builders at runtime"><title>ArrayBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" ty [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Trait for dealing with different array builders at runtime"><title>ArrayBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" ty [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     // Required methods
     fn <a href="#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>;
 <span class="item-spacer"></span>    fn <a href="#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;;
@@ -52,32 +52,32 @@ data_builders[<span class="number">2</span>]
         .value(<span class="number">0</span>),
     <span class="string">"🍎"
 </span>);</code></pre></div>
-</div></details><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.len" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#237">source</a><h4 class="code-header">fn <a href="#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/ [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.finish" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#245">source</a><h4 class="code-header">fn <a href="#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait a [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.finish_cloned" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#248">source</a><h4 class="code-header">fn <a href="#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.htm [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.as_any" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#255">source</a><h4 class="code-header">fn <a href="#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock"><p>Return [...]
+</div></details><h2 id="required-methods" class="section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.len" class="method"><h4 class="code-header">fn <a href="#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns th [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.finish" class="method"><h4 class="code-header">fn <a href="#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docblock"><p>Builds t [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.finish_cloned" class="method"><h4 class="code-header">fn <a href="#tymethod.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>&gt;</h4></section></summary><div class="docb [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.as_any" class="method"><h4 class="code-header">fn <a href="#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock"><p>Returns the builder as a non-mutable <code>Any</code> reference.</p>
 <p>This is most useful when one wants to call non-mutable APIs on a specific builder
 type. In this case, one can first cast this into a <code>Any</code>, and then use
 <code>downcast_ref</code> to get a reference on the specific builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.as_any_mut" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#262">source</a><h4 class="code-header">fn <a href="#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class= [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.as_any_mut" class="method"><h4 class="code-header">fn <a href="#tymethod.as_any_mut" class="fn">as_any_mut</a>(&amp;mut self) -&gt; &amp;mut (dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section></summary><div class="docblock"><p>Returns the builder as a mutable <code>Any</code> reference.</p>
 <p>This is most useful when one wants to call mutable APIs on a specific builder
 type. In this case, one can first cast this into a <code>Any</code>, and then use
 <code>downcast_mut</code> to get a reference on the specific builder.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.into_box_any" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#265">source</a><h4 class="code-header">fn <a href="#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;Self&gt;) -&gt; <a class="struct" href="https://doc.rust- [...]
-</div></details></div><h2 id="provided-methods" class="section-header">Provided Methods<a href="#provided-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#240">source</a><h4 class="code-header">fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang [...]
-</div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-Box%3Cdyn+ArrayBuilder%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/mod.rs.html#268">source</a><a href="#impl-ArrayBuilder-for-Box%3Cdyn+ArrayBuilder%3E" class="anchor">§< [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.into_box_any" class="method"><h4 class="code-header">fn <a href="#tymethod.into_box_any" class="fn">into_box_any</a>(self: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;Self&gt;) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;d [...]
+</div></details></div><h2 id="provided-methods" class="section-header">Provided Methods<a href="#provided-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><h4 class="code-header">fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock [...]
+</div></details></div><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-implementations" class="anchor">§</a></h2><div id="trait-implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-ArrayBuilder-for-Box%3Cdyn+ArrayBuilder%3E" class="impl"><a href="#impl-ArrayBuilder-for-Box%3Cdyn+ArrayBuilder%3E" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrayBuilder.html" title="trai [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/map_builder.rs.html#213">source</a><a href="#impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="trait" href="trait.ArrayBuilder.html" tit [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-MapBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a class="struct" href="struct. [...]
     K: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,
-    V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section><section id="impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_dictionary_builder.rs.html#172-175">source</a><a href="#impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="tr [...]
+    V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div></h3></section><section id="impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-PrimitiveDictionaryBuilder%3CK,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K, V&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a class="str [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_list_builder.rs.html#137-140">source</a><a href="#impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="anchor">§</a><h3 class="code-header">impl&l [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericListBuilder%3COffsetSize,+T%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize, T&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBui [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section><section id="impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_byte_run_builder.rs.html#121-124">source</a><a href="#impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="trait" [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section><section id="impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericByteRunBuilder%3CR,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a class="str [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_run_builder.rs.html#113-116">source</a><a href="#impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="trait" hr [...]
+    V: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="impl"><a href="#impl-ArrayBuilder-for-PrimitiveRunBuilder%3CR,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R, V&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a class="str [...]
     R: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
-    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/fixed_size_list_builder.rs.html#96-98">source</a><a href="#impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="t [...]
-    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section><section id="impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/generic_bytes_builder.rs.html#181">source</a><a href="#impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.ArrayBuil [...]
-    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/builder/primitive_builder.rs.html#103">source</a><a href="#impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.ArrayBuilder. [...]
+    V: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="impl"><a href="#impl-ArrayBuilder-for-FixedSizeListBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a cl [...]
+    T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> + 'static,</div></h3></section><section id="impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="impl"><a href="#impl-ArrayBuilder-for-GenericByteBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a class="struct" href="stru [...]
+    T: <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section><section id="impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="impl"><a href="#impl-ArrayBuilder-for-PrimitiveBuilder%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a> for <a class="struct" href="stru [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></div><script src="../../../trait.impl/arrow_array/builder/trait.ArrayBuilder.js" data-ignore-extern-crates="arrow_array,alloc" async></script></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/builder/type.BinaryBuilder.html b/arrow/array/builder/type.BinaryBuilder.html
index 06df566810e..3dba240d081 100644
--- a/arrow/array/builder/type.BinaryBuilder.html
+++ b/arrow/array/builder/type.BinaryBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `BinaryArray`"><title>BinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `BinaryArray`"><title>BinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct BinaryBuilder {
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
+    null_buffer_builder: NullBufferBuilder,
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.BinaryDictionaryBuilder.html b/arrow/array/builder/type.BinaryDictionaryBuilder.html
index 8621f2db6df..bd9344d1011 100644
--- a/arrow/array/builder/type.BinaryDictionaryBuilder.html
+++ b/arrow/array/builder/type.BinaryDictionaryBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `BinaryArray`"><title>BinaryDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" typ [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `BinaryArray`"><title>BinaryDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" typ [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create a dictionary array indexed by bytes whose values are binary.
 // It can thus hold up to 256 distinct binary values.
diff --git a/arrow/array/builder/type.BinaryRunBuilder.html b/arrow/array/builder/type.BinaryRunBuilder.html
index fc58f7d81c0..5d77457bda9 100644
--- a/arrow/array/builder/type.BinaryRunBuilder.html
+++ b/arrow/array/builder/type.BinaryRunBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `BinaryArray`"><title>BinaryRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `BinaryArray`"><title>BinaryRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create a run-end encoded array with run-end indexes data type as `i16`.
 // The encoded data is binary values.
diff --git a/arrow/array/builder/type.Date32BufferBuilder.html b/arrow/array/builder/type.Date32BufferBuilder.html
index ac7e47e570c..89fc6736899 100644
--- a/arrow/array/builder/type.Date32BufferBuilder.html
+++ b/arrow/array/builder/type.Date32BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 32-bit date type."><title>Date32BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 32-bit date type."><title>Date32BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Date32BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Date32Builder.html b/arrow/array/builder/type.Date32Builder.html
index 8e5ffe91579..eee14da4ed3 100644
--- a/arrow/array/builder/type.Date32Builder.html
+++ b/arrow/array/builder/type.Date32Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 32-bit date array builder."><title>Date32Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin h [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 32-bit date array builder."><title>Date32Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin h [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Date32Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Date64BufferBuilder.html b/arrow/array/builder/type.Date64BufferBuilder.html
index b8932e4aa17..27d7a4e6e8d 100644
--- a/arrow/array/builder/type.Date64BufferBuilder.html
+++ b/arrow/array/builder/type.Date64BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 64-bit date type."><title>Date64BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 64-bit date type."><title>Date64BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Date64BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Date64Builder.html b/arrow/array/builder/type.Date64Builder.html
index 967590b2e43..b6f66c63b06 100644
--- a/arrow/array/builder/type.Date64Builder.html
+++ b/arrow/array/builder/type.Date64Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 64-bit date array builder."><title>Date64Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin h [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 64-bit date array builder."><title>Date64Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin h [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Date64Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Decimal128BufferBuilder.html b/arrow/array/builder/type.Decimal128BufferBuilder.html
index 0c2fcf0ed8e..b6ac3fbef2b 100644
--- a/arrow/array/builder/type.Decimal128BufferBuilder.html
+++ b/arrow/array/builder/type.Decimal128BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 128-bit decimal type."><title>Decimal128BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 128-bit decimal type."><title>Decimal128BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Decimal128BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Decimal128Builder.html b/arrow/array/builder/type.Decimal128Builder.html
index a0a3650e4af..4767aa58b60 100644
--- a/arrow/array/builder/type.Decimal128Builder.html
+++ b/arrow/array/builder/type.Decimal128Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A decimal 128 array builder"><title>Decimal128Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A decimal 128 array builder"><title>Decimal128Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Decimal128Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>&gt;</ [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>&gt;</ [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Decimal256BufferBuilder.html b/arrow/array/builder/type.Decimal256BufferBuilder.html
index 2406d3e302d..39c80777938 100644
--- a/arrow/array/builder/type.Decimal256BufferBuilder.html
+++ b/arrow/array/builder/type.Decimal256BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 256-bit decimal type."><title>Decimal256BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 256-bit decimal type."><title>Decimal256BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Decimal256BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Decimal256Builder.html b/arrow/array/builder/type.Decimal256Builder.html
index 1ee7eb984cd..14ed8be5eb0 100644
--- a/arrow/array/builder/type.Decimal256Builder.html
+++ b/arrow/array/builder/type.Decimal256Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A decimal 256 array builder"><title>Decimal256Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A decimal 256 array builder"><title>Decimal256Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Decimal256Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="struct" href="../../datatypes/struct.i256.html" title="struct arrow::datatypes::i256">i256</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="struct" href="../../datatypes/struct.i256.html" title="struct arrow::datatypes::i256">i256 [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="struct" href="../../datatypes/struct.i256.html" title="struct arrow::datatypes::i256">i256 [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html b/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html
index 6f4e2d8aeb8..8e1766c7413 100644
--- a/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of microseconds unit."><title>DurationMicrosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of microseconds unit."><title>DurationMicrosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationMicrosecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.DurationMicrosecondBuilder.html b/arrow/array/builder/type.DurationMicrosecondBuilder.html
index 83fc8b39f92..542ac21cd08 100644
--- a/arrow/array/builder/type.DurationMicrosecondBuilder.html
+++ b/arrow/array/builder/type.DurationMicrosecondBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in microseconds array builder."><title>DurationMicrosecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in microseconds array builder."><title>DurationMicrosecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationMicrosecondBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.DurationMillisecondBufferBuilder.html b/arrow/array/builder/type.DurationMillisecondBufferBuilder.html
index 7918b21b866..35f1f775c44 100644
--- a/arrow/array/builder/type.DurationMillisecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationMillisecondBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of milliseconds unit."><title>DurationMillisecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of milliseconds unit."><title>DurationMillisecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationMillisecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.DurationMillisecondBuilder.html b/arrow/array/builder/type.DurationMillisecondBuilder.html
index d17abb20351..b6660001958 100644
--- a/arrow/array/builder/type.DurationMillisecondBuilder.html
+++ b/arrow/array/builder/type.DurationMillisecondBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in milliseconds array builder."><title>DurationMillisecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font"  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in milliseconds array builder."><title>DurationMillisecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font"  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationMillisecondBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.DurationNanosecondBufferBuilder.html b/arrow/array/builder/type.DurationNanosecondBufferBuilder.html
index 4aaeb811929..29fd8931d5e 100644
--- a/arrow/array/builder/type.DurationNanosecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationNanosecondBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of nanoseconds unit."><title>DurationNanosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of nanoseconds unit."><title>DurationNanosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationNanosecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.DurationNanosecondBuilder.html b/arrow/array/builder/type.DurationNanosecondBuilder.html
index 4744d68e44b..8edb9b2c90f 100644
--- a/arrow/array/builder/type.DurationNanosecondBuilder.html
+++ b/arrow/array/builder/type.DurationNanosecondBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in nanoseconds array builder."><title>DurationNanosecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" ty [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in nanoseconds array builder."><title>DurationNanosecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" ty [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationNanosecondBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.DurationSecondBufferBuilder.html b/arrow/array/builder/type.DurationSecondBufferBuilder.html
index c1dae399824..fa4b54e6bc6 100644
--- a/arrow/array/builder/type.DurationSecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationSecondBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of second unit."><title>DurationSecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for elaspsed time of second unit."><title>DurationSecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fon [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationSecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.DurationSecondBuilder.html b/arrow/array/builder/type.DurationSecondBuilder.html
index da3a135a99f..19e8dffa2b2 100644
--- a/arrow/array/builder/type.DurationSecondBuilder.html
+++ b/arrow/array/builder/type.DurationSecondBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in seconds array builder."><title>DurationSecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An elapsed time in seconds array builder."><title>DurationSecondBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct DurationSecondBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Float16BufferBuilder.html b/arrow/array/builder/type.Float16BufferBuilder.html
index 59ac804bbb8..df766d725f5 100644
--- a/arrow/array/builder/type.Float16BufferBuilder.html
+++ b/arrow/array/builder/type.Float16BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 16-bit floating point type."><title>Float16BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 16-bit floating point type."><title>Float16BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Float16BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Float16Builder.html b/arrow/array/builder/type.Float16Builder.html
index d0adc019ff9..4e9b879bfdd 100644
--- a/arrow/array/builder/type.Float16Builder.html
+++ b/arrow/array/builder/type.Float16Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 16-bit floating point array builder."><title>Float16Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 16-bit floating point array builder."><title>Float16Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Float16Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="struct" href="https://docs.rs/half/2.3.1/half/binary16/struct.f16.html" title="struct half::binary16::f16">f16</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="struct" href="https://docs.rs/half/2.3.1/half/binary16/struct.f16.html" title="struct half [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="struct" href="https://docs.rs/half/2.3.1/half/binary16/struct.f16.html" title="struct half [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Float32BufferBuilder.html b/arrow/array/builder/type.Float32BufferBuilder.html
index 47e50d92eae..40b4a9d7344 100644
--- a/arrow/array/builder/type.Float32BufferBuilder.html
+++ b/arrow/array/builder/type.Float32BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 32-bit floating point type."><title>Float32BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 32-bit floating point type."><title>Float32BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Float32BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Float32Builder.html b/arrow/array/builder/type.Float32Builder.html
index c49a15a7c17..5145c5ebc72 100644
--- a/arrow/array/builder/type.Float32Builder.html
+++ b/arrow/array/builder/type.Float32Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 32-bit floating point array builder."><title>Float32Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 32-bit floating point array builder."><title>Float32Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Float32Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.f32.html">f32</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.f32.html">f32</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.f32.html">f32</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Float64BufferBuilder.html b/arrow/array/builder/type.Float64BufferBuilder.html
index df8200fbd3e..c024105a66f 100644
--- a/arrow/array/builder/type.Float64BufferBuilder.html
+++ b/arrow/array/builder/type.Float64BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 64-bit floating point type."><title>Float64BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for 64-bit floating point type."><title>Float64BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Float64BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Float64Builder.html b/arrow/array/builder/type.Float64Builder.html
index 429a3327c45..76e9a778c8d 100644
--- a/arrow/array/builder/type.Float64Builder.html
+++ b/arrow/array/builder/type.Float64Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 64-bit floating point array builder."><title>Float64Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A 64-bit floating point array builder."><title>Float64Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Float64Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.f64.html">f64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.f64.html">f64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.f64.html">f64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.GenericBinaryBuilder.html b/arrow/array/builder/type.GenericBinaryBuilder.html
index c11fab49b67..beef844235c 100644
--- a/arrow/array/builder/type.GenericBinaryBuilder.html
+++ b/arrow/array/builder/type.GenericBinaryBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Array builder for `GenericBinaryArray`"><title>GenericBinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/wof [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Array builder for `GenericBinaryArray`"><title>GenericBinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/wof [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct GenericBinaryBuilder&lt;O&gt; {
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;O&gt; as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait [...]
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
+    null_buffer_builder: NullBufferBuilder,
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.GenericStringBuilder.html b/arrow/array/builder/type.GenericStringBuilder.html
index 3fa701272e2..dbde5bb2128 100644
--- a/arrow/array/builder/type.GenericStringBuilder.html
+++ b/arrow/array/builder/type.GenericStringBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Array builder for `GenericStringArray`"><title>GenericStringBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/wof [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Array builder for `GenericStringArray`"><title>GenericStringBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/wof [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <p>Values can be appended using <a href="struct.GenericByteBuilder.html#method.append_value" title="method arrow::array::builder::GenericByteBuilder::append_value"><code>GenericByteBuilder::append_value</code></a>, and nulls with
 <a href="struct.GenericByteBuilder.html#method.append_null" title="method arrow::array::builder::GenericByteBuilder::append_null"><code>GenericByteBuilder::append_null</code></a> as normal.</p>
 <p>Additionally implements <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write"><code>std::fmt::Write</code></a> with any written data included in the next
@@ -24,5 +24,5 @@ builder.append_value(<span class="string">""</span>);
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct GenericStringBuilder&lt;O&gt; {
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;O&gt; as <a class="trait" href="../../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait [...]
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
+    null_buffer_builder: NullBufferBuilder,
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Int16BufferBuilder.html b/arrow/array/builder/type.Int16BufferBuilder.html
index 662c270c2e4..e182e27b315 100644
--- a/arrow/array/builder/type.Int16BufferBuilder.html
+++ b/arrow/array/builder/type.Int16BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 16-bit integer type."><title>Int16BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 16-bit integer type."><title>Int16BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int16BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Int16Builder.html b/arrow/array/builder/type.Int16Builder.html
index 54252fc79e3..6c831873c7a 100644
--- a/arrow/array/builder/type.Int16Builder.html
+++ b/arrow/array/builder/type.Int16Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 16-bit integer array builder."><title>Int16Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 16-bit integer array builder."><title>Int16Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int16Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i16.html">i16</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i16.html">i16</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i16.html">i16</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Int32BufferBuilder.html b/arrow/array/builder/type.Int32BufferBuilder.html
index 6f7577fe0bd..7ef573cc67e 100644
--- a/arrow/array/builder/type.Int32BufferBuilder.html
+++ b/arrow/array/builder/type.Int32BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 32-bit integer type."><title>Int32BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 32-bit integer type."><title>Int32BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int32BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Int32Builder.html b/arrow/array/builder/type.Int32Builder.html
index 9d022165a47..5110abe210c 100644
--- a/arrow/array/builder/type.Int32Builder.html
+++ b/arrow/array/builder/type.Int32Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 32-bit integer array builder."><title>Int32Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 32-bit integer array builder."><title>Int32Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int32Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Int64BufferBuilder.html b/arrow/array/builder/type.Int64BufferBuilder.html
index 91404a9e6e4..7c2520576e0 100644
--- a/arrow/array/builder/type.Int64BufferBuilder.html
+++ b/arrow/array/builder/type.Int64BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 64-bit integer type."><title>Int64BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fo [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 64-bit integer type."><title>Int64BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="fo [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int64BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Int64Builder.html b/arrow/array/builder/type.Int64Builder.html
index 0553b176c25..2695c5cfc93 100644
--- a/arrow/array/builder/type.Int64Builder.html
+++ b/arrow/array/builder/type.Int64Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 64-bit integer array builder."><title>Int64Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 64-bit integer array builder."><title>Int64Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cros [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int64Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.Int8BufferBuilder.html b/arrow/array/builder/type.Int8BufferBuilder.html
index b5b0d307914..c3a11315a79 100644
--- a/arrow/array/builder/type.Int8BufferBuilder.html
+++ b/arrow/array/builder/type.Int8BufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 8-bit integer type."><title>Int8BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for signed 8-bit integer type."><title>Int8BufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int8BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.Int8Builder.html b/arrow/array/builder/type.Int8Builder.html
index a83271fed18..8cbe84175b1 100644
--- a/arrow/array/builder/type.Int8Builder.html
+++ b/arrow/array/builder/type.Int8Builder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 8-bit integer array builder."><title>Int8Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A signed 8-bit integer array builder."><title>Int8Builder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct Int8Builder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;</code [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;</code [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html b/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html
index 6a7aec2d8c1..d4384927026 100644
--- a/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html
+++ b/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for “calendar” interval in days and milliseconds."><title>IntervalDayTimeBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for “calendar” interval in days and milliseconds."><title>IntervalDayTimeBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalDayTimeBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.IntervalDayTimeBuilder.html b/arrow/array/builder/type.IntervalDayTimeBuilder.html
index dbb887db805..d540ce0e226 100644
--- a/arrow/array/builder/type.IntervalDayTimeBuilder.html
+++ b/arrow/array/builder/type.IntervalDayTimeBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A “calendar” interval in days and milliseconds array builder."><title>IntervalDayTimeBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A “calendar” interval in days and milliseconds array builder."><title>IntervalDayTimeBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalDayTimeBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html b/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html
index 5a36c766641..ecfddf8eeca 100644
--- a/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html
+++ b/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder “calendar” interval in months, days, and nanoseconds."><title>IntervalMonthDayNanoBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2">< [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder “calendar” interval in months, days, and nanoseconds."><title>IntervalMonthDayNanoBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2">< [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalMonthDayNanoBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html b/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html
index fabd3b3a02e..b95ea4c6e25 100644
--- a/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html
+++ b/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A “calendar” interval in months, days, and nanoseconds array builder."><title>IntervalMonthDayNanoBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link  [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A “calendar” interval in months, days, and nanoseconds array builder."><title>IntervalMonthDayNanoBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link  [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalMonthDayNanoBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>&gt;</ [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>&gt;</ [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html b/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html
index 61e0c27a916..0924b625239 100644
--- a/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html
+++ b/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for “calendar” interval in months."><title>IntervalYearMonthBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Buffer builder for “calendar” interval in months."><title>IntervalYearMonthBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalYearMonthBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/array/builder/type.IntervalYearMonthBuilder.html b/arrow/array/builder/type.IntervalYearMonthBuilder.html
index d4c1261e21d..237cc341bfe 100644
--- a/arrow/array/builder/type.IntervalYearMonthBuilder.html
+++ b/arrow/array/builder/type.IntervalYearMonthBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A “calendar” interval in months array builder."><title>IntervalYearMonthBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" ty [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A “calendar” interval in months array builder."><title>IntervalYearMonthBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" ty [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct IntervalYearMonthBuilder {
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     data_type: <a class="enum" href="../../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</co [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.values_builder" class="structfield section-header"><a href="#structfield.values_builder" class="anchor field">§</a><code>values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;</co [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.LargeBinaryBuilder.html b/arrow/array/builder/type.LargeBinaryBuilder.html
index e77ec5aa5b7..1b843aca94d 100644
--- a/arrow/array/builder/type.LargeBinaryBuilder.html
+++ b/arrow/array/builder/type.LargeBinaryBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `LargeBinaryArray`"><title>LargeBinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `LargeBinaryArray`"><title>LargeBinaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct LargeBinaryBuilder {
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
+    null_buffer_builder: NullBufferBuilder,
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.value_builder" class="structfield section-header"><a href="#structfield.value_builder" class="anchor field">§</a><code>value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;</code></ [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html b/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html
index 16b1345f931..5f6efe41126 100644
--- a/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html
+++ b/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `LargeBinaryArray`"><title>LargeBinaryDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as= [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `DictionaryArray` of `LargeBinaryArray`"><title>LargeBinaryDictionaryBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as= [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct LargeBinaryDictionaryBuilder&lt;K&gt; {
     state: RandomState,
     dedup: HashMap&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;,
diff --git a/arrow/array/builder/type.LargeBinaryRunBuilder.html b/arrow/array/builder/type.LargeBinaryRunBuilder.html
index 086d2cdf840..5e0ab121bb5 100644
--- a/arrow/array/builder/type.LargeBinaryRunBuilder.html
+++ b/arrow/array/builder/type.LargeBinaryRunBuilder.html
@@ -1,5 +1,5 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `LargeBinaryArray`"><title>LargeBinaryRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `RunArray` of `LargeBinaryArray`"><title>LargeBinaryRunBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="f [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct LargeBinaryRunBuilder&lt;K&gt; {
     run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
     values_builder: <a class="struct" href="struct.GenericByteBuilder.html" title="struct arrow::array::builder::GenericByteBuilder">GenericByteBuilder</a>&lt;<a class="struct" href="../../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;&gt;,
diff --git a/arrow/array/builder/type.LargeListBuilder.html b/arrow/array/builder/type.LargeListBuilder.html
index f256ae086ae..c3e34033868 100644
--- a/arrow/array/builder/type.LargeListBuilder.html
+++ b/arrow/array/builder/type.LargeListBuilder.html
@@ -1,8 +1,8 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `LargeListArray`"><title>LargeListBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `LargeListArray`"><title>LargeListBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigi [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct LargeListBuilder&lt;T&gt; {
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
+    null_buffer_builder: NullBufferBuilder,
     values_builder: T,
     field: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;&gt;,
-}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.offsets_builder" class="structfield section-header"><a href="#structfield.offsets_builder" class="anchor field">§</a><code>offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;< [...]
\ No newline at end of file
+}</code></pre><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.offsets_builder" class="structfield section-header"><a href="#structfield.offsets_builder" class="anchor field">§</a><code>offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;< [...]
\ No newline at end of file
diff --git a/arrow/array/builder/type.LargeStringBuilder.html b/arrow/array/builder/type.LargeStringBuilder.html
index 7a211b0a8f3..895434c9dbf 100644
--- a/arrow/array/builder/type.LargeStringBuilder.html
+++ b/arrow/array/builder/type.LargeStringBuilder.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `LargeStringArray`"><title>LargeStringBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
-    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Builder for `LargeStringArray`"><title>LargeStringBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crosso [...]
+    <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 </div></details><h2 id="aliased-type" class="section-header">Aliased Type<a href="#aliased-type" class="anchor">§</a></h2><pre class="rust item-decl"><code>struct LargeStringBuilder {
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::builder::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;,
-    null_buffer_builder: <a class="struct" href="../../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
... 82054 lines suppressed ...