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/01/22 11:02:34 UTC

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

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 467f045408 deploy: ce589325d87b7ba55d3af74ad77f7cee9ff3c95b
467f045408 is described below

commit 467f045408ff3be1951caebef15128775ff56599
Author: tustvold <tu...@users.noreply.github.com>
AuthorDate: Mon Jan 22 11:02:24 2024 +0000

    deploy: ce589325d87b7ba55d3af74ad77f7cee9ff3c95b
---
 arrow/all.html                                     |   2 +-
 arrow/alloc/constant.ALIGNMENT.html                |   2 +-
 arrow/alloc/index.html                             |   4 +-
 arrow/alloc/trait.Allocation.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/index.html                       |  10 +-
 arrow/array/array/struct.BooleanArray.html         |  32 +-
 arrow/array/array/struct.DictionaryArray.html      |  40 +-
 arrow/array/array/struct.FixedSizeBinaryArray.html |  40 +-
 arrow/array/array/struct.FixedSizeListArray.html   |  32 +-
 arrow/array/array/struct.GenericByteArray.html     |  66 +-
 arrow/array/array/struct.GenericListArray.html     |  28 +-
 arrow/array/array/struct.MapArray.html             |  20 +-
 arrow/array/array/struct.NativeAdapter.html        |  16 +-
 arrow/array/array/struct.NullArray.html            |  16 +-
 arrow/array/array/struct.PrimitiveArray.html       | 166 ++--
 arrow/array/array/struct.RunArray.html             |  20 +-
 arrow/array/array/struct.StructArray.html          |  28 +-
 arrow/array/array/struct.TypedDictionaryArray.html |  12 +-
 arrow/array/array/struct.TypedRunArray.html        |  12 +-
 arrow/array/array/struct.UnionArray.html           |  28 +-
 arrow/array/array/trait.AnyDictionaryArray.html    |   4 +-
 arrow/array/array/trait.Array.html                 |  28 +-
 arrow/array/array/trait.ArrayAccessor.html         |   8 +-
 arrow/array/array/trait.ArrowPrimitiveType.html    |   2 +-
 arrow/array/array/trait.OffsetSizeTrait.html       |   2 +-
 arrow/array/array/type.ArrayRef.html               |   2 +-
 arrow/array/array/type.BinaryArray.html            |   4 +-
 arrow/array/array/type.Date32Array.html            |   2 +-
 arrow/array/array/type.Date64Array.html            |   2 +-
 arrow/array/array/type.Decimal128Array.html        |   4 +-
 arrow/array/array/type.Decimal256Array.html        |   4 +-
 .../array/array/type.DurationMicrosecondArray.html |   2 +-
 .../array/array/type.DurationMillisecondArray.html |   2 +-
 .../array/array/type.DurationNanosecondArray.html  |   2 +-
 arrow/array/array/type.DurationSecondArray.html    |   2 +-
 arrow/array/array/type.Float16Array.html           |   6 +-
 arrow/array/array/type.Float32Array.html           |   4 +-
 arrow/array/array/type.Float64Array.html           |   4 +-
 arrow/array/array/type.GenericBinaryArray.html     |   2 +-
 arrow/array/array/type.GenericStringArray.html     |   2 +-
 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   |   2 +-
 .../array/type.IntervalMonthDayNanoArray.html      |   2 +-
 arrow/array/array/type.IntervalYearMonthArray.html |   2 +-
 arrow/array/array/type.LargeBinaryArray.html       |   4 +-
 arrow/array/array/type.LargeListArray.html         |   2 +-
 arrow/array/array/type.LargeStringArray.html       |   4 +-
 arrow/array/array/type.ListArray.html              |   2 +-
 arrow/array/array/type.StringArray.html            |   4 +-
 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/array/type.TimestampNanosecondArray.html |   2 +-
 arrow/array/array/type.TimestampSecondArray.html   |   8 +-
 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           |   2 +-
 arrow/array/builder/index.html                     |  12 +-
 .../array/builder/struct.BooleanBufferBuilder.html |  14 +-
 arrow/array/builder/struct.BooleanBuilder.html     |  14 +-
 arrow/array/builder/struct.BufferBuilder.html      |  44 +-
 .../builder/struct.FixedSizeBinaryBuilder.html     |  12 +-
 .../array/builder/struct.FixedSizeListBuilder.html |  12 +-
 arrow/array/builder/struct.GenericByteBuilder.html |  16 +-
 .../struct.GenericByteDictionaryBuilder.html       |  18 +-
 .../builder/struct.GenericByteRunBuilder.html      |  14 +-
 arrow/array/builder/struct.GenericListBuilder.html |  16 +-
 arrow/array/builder/struct.MapBuilder.html         |  12 +-
 arrow/array/builder/struct.MapFieldNames.html      |  12 +-
 arrow/array/builder/struct.NullBuilder.html        |  14 +-
 arrow/array/builder/struct.PrimitiveBuilder.html   |  18 +-
 .../builder/struct.PrimitiveDictionaryBuilder.html |  22 +-
 .../array/builder/struct.PrimitiveRunBuilder.html  |  14 +-
 arrow/array/builder/struct.StructBuilder.html      |  12 +-
 arrow/array/builder/struct.UnionBuilder.html       |  12 +-
 arrow/array/builder/trait.ArrayBuilder.html        |   4 +-
 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 +-
 .../array/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 +-
 .../array/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 +-
 .../array/builder/type.LargeBinaryRunBuilder.html  |   2 +-
 arrow/array/builder/type.LargeListBuilder.html     |   2 +-
 arrow/array/builder/type.LargeStringBuilder.html   |   2 +-
 .../builder/type.LargeStringDictionaryBuilder.html |   2 +-
 .../array/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 +-
 .../array/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/cast/fn.as_boolean_array.html          |   4 +-
 arrow/array/cast/fn.as_decimal_array.html          |   2 +-
 arrow/array/cast/fn.as_dictionary_array.html       |   4 +-
 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        |   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           |   2 +-
 arrow/array/cast/fn.as_union_array.html            |   2 +-
 arrow/array/cast/fn.downcast_array.html            |   4 +-
 arrow/array/cast/index.html                        |   4 +-
 arrow/array/cast/trait.AsArray.html                |   2 +-
 arrow/array/enum.BufferSpec.html                   |  12 +-
 arrow/array/enum.Capacities.html                   |  12 +-
 arrow/array/ffi/fn.export_array_into_raw.html      |   4 +-
 arrow/array/ffi/index.html                         |   4 +-
 arrow/array/fn.as_boolean_array.html               |   4 +-
 arrow/array/fn.as_decimal_array.html               |   2 +-
 arrow/array/fn.as_dictionary_array.html            |   4 +-
 arrow/array/fn.as_fixed_size_list_array.html       |   2 +-
 arrow/array/fn.as_generic_binary_array.html        |   2 +-
 arrow/array/fn.as_generic_list_array.html          |   2 +-
 arrow/array/fn.as_large_list_array.html            |   2 +-
 arrow/array/fn.as_largestring_array.html           |   2 +-
 arrow/array/fn.as_list_array.html                  |   2 +-
 arrow/array/fn.as_map_array.html                   |   2 +-
 arrow/array/fn.as_null_array.html                  |   2 +-
 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                |   2 +-
 arrow/array/fn.as_union_array.html                 |   2 +-
 arrow/array/fn.build_compare.html                  |   4 +-
 arrow/array/fn.downcast_array.html                 |   4 +-
 arrow/array/fn.export_array_into_raw.html          |   4 +-
 arrow/array/fn.layout.html                         |   2 +-
 arrow/array/fn.make_array.html                     |   2 +-
 arrow/array/fn.make_builder.html                   |   2 +-
 arrow/array/fn.new_empty_array.html                |   2 +-
 arrow/array/fn.new_null_array.html                 |   2 +-
 arrow/array/index.html                             |  12 +-
 arrow/array/iterator/index.html                    |   4 +-
 arrow/array/iterator/struct.ArrayIter.html         |  16 +-
 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 +-
 .../array/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/run_iterator/index.html                |   4 +-
 arrow/array/run_iterator/struct.RunArrayIter.html  |  14 +-
 arrow/array/struct.ArrayData.html                  |  42 +-
 arrow/array/struct.ArrayDataBuilder.html           |  14 +-
 arrow/array/struct.ArrayIter.html                  |  16 +-
 arrow/array/struct.BooleanArray.html               |  32 +-
 arrow/array/struct.BooleanBufferBuilder.html       |  14 +-
 arrow/array/struct.BooleanBuilder.html             |  14 +-
 arrow/array/struct.BufferBuilder.html              |  44 +-
 arrow/array/struct.DataTypeLayout.html             |  12 +-
 arrow/array/struct.DictionaryArray.html            |  40 +-
 arrow/array/struct.FixedSizeBinaryArray.html       |  40 +-
 arrow/array/struct.FixedSizeBinaryBuilder.html     |  12 +-
 arrow/array/struct.FixedSizeListArray.html         |  32 +-
 arrow/array/struct.FixedSizeListBuilder.html       |  12 +-
 arrow/array/struct.GenericByteArray.html           |  66 +-
 arrow/array/struct.GenericByteBuilder.html         |  16 +-
 .../array/struct.GenericByteDictionaryBuilder.html |  18 +-
 arrow/array/struct.GenericByteRunBuilder.html      |  14 +-
 arrow/array/struct.GenericListArray.html           |  28 +-
 arrow/array/struct.GenericListBuilder.html         |  16 +-
 arrow/array/struct.MapArray.html                   |  20 +-
 arrow/array/struct.MapBuilder.html                 |  12 +-
 arrow/array/struct.MapFieldNames.html              |  12 +-
 arrow/array/struct.MutableArrayData.html           |  20 +-
 arrow/array/struct.NativeAdapter.html              |  16 +-
 arrow/array/struct.NullArray.html                  |  16 +-
 arrow/array/struct.NullBuilder.html                |  14 +-
 arrow/array/struct.PrimitiveArray.html             | 166 ++--
 arrow/array/struct.PrimitiveBuilder.html           |  18 +-
 arrow/array/struct.PrimitiveDictionaryBuilder.html |  22 +-
 arrow/array/struct.PrimitiveRunBuilder.html        |  14 +-
 arrow/array/struct.RecordBatch.html                |  30 +-
 arrow/array/struct.RecordBatchIterator.html        |  16 +-
 arrow/array/struct.RecordBatchOptions.html         |  12 +-
 arrow/array/struct.RunArray.html                   |  20 +-
 arrow/array/struct.Scalar.html                     |  16 +-
 arrow/array/struct.StructArray.html                |  28 +-
 arrow/array/struct.StructBuilder.html              |  12 +-
 arrow/array/struct.TypedDictionaryArray.html       |  12 +-
 arrow/array/struct.TypedRunArray.html              |  12 +-
 arrow/array/struct.UnionArray.html                 |  28 +-
 arrow/array/struct.UnionBuilder.html               |  12 +-
 .../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 +-
 .../array/temporal_conversions/fn.as_datetime.html |   2 +-
 .../fn.as_datetime_with_timezone.html              |   2 +-
 .../array/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.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        |   4 +-
 arrow/array/timezone/index.html                    |   4 +-
 arrow/array/timezone/struct.Tz.html                |  12 +-
 arrow/array/timezone/struct.TzOffset.html          |  14 +-
 arrow/array/trait.AnyDictionaryArray.html          |   4 +-
 arrow/array/trait.Array.html                       |  28 +-
 arrow/array/trait.ArrayAccessor.html               |   8 +-
 arrow/array/trait.ArrayBuilder.html                |   4 +-
 arrow/array/trait.ArrowNativeTypeOp.html           |   2 +-
 arrow/array/trait.ArrowNumericType.html            |   2 +-
 arrow/array/trait.ArrowPrimitiveType.html          |   2 +-
 arrow/array/trait.AsArray.html                     |   2 +-
 arrow/array/trait.Datum.html                       |   2 +-
 arrow/array/trait.OffsetSizeTrait.html             |   2 +-
 arrow/array/trait.RecordBatchReader.html           |   2 +-
 arrow/array/trait.RecordBatchWriter.html           |   2 +-
 arrow/array/type.ArrayDataRef.html                 |   2 +-
 arrow/array/type.ArrayRef.html                     |   2 +-
 arrow/array/type.BinaryArray.html                  |   4 +-
 arrow/array/type.BinaryBuilder.html                |   2 +-
 arrow/array/type.BinaryDictionaryBuilder.html      |   2 +-
 arrow/array/type.BinaryRunBuilder.html             |   2 +-
 arrow/array/type.BooleanIter.html                  |   2 +-
 arrow/array/type.Date32Array.html                  |   2 +-
 arrow/array/type.Date32BufferBuilder.html          |   2 +-
 arrow/array/type.Date32Builder.html                |   2 +-
 arrow/array/type.Date64Array.html                  |   2 +-
 arrow/array/type.Date64BufferBuilder.html          |   2 +-
 arrow/array/type.Date64Builder.html                |   2 +-
 arrow/array/type.Decimal128Array.html              |   4 +-
 arrow/array/type.Decimal128BufferBuilder.html      |   2 +-
 arrow/array/type.Decimal128Builder.html            |   2 +-
 arrow/array/type.Decimal256Array.html              |   4 +-
 arrow/array/type.Decimal256BufferBuilder.html      |   2 +-
 arrow/array/type.Decimal256Builder.html            |   2 +-
 arrow/array/type.DurationMicrosecondArray.html     |   2 +-
 .../type.DurationMicrosecondBufferBuilder.html     |   2 +-
 arrow/array/type.DurationMicrosecondBuilder.html   |   2 +-
 arrow/array/type.DurationMillisecondArray.html     |   2 +-
 .../type.DurationMillisecondBufferBuilder.html     |   2 +-
 arrow/array/type.DurationMillisecondBuilder.html   |   2 +-
 arrow/array/type.DurationNanosecondArray.html      |   2 +-
 .../type.DurationNanosecondBufferBuilder.html      |   2 +-
 arrow/array/type.DurationNanosecondBuilder.html    |   2 +-
 arrow/array/type.DurationSecondArray.html          |   2 +-
 arrow/array/type.DurationSecondBufferBuilder.html  |   2 +-
 arrow/array/type.DurationSecondBuilder.html        |   2 +-
 arrow/array/type.DynComparator.html                |   2 +-
 arrow/array/type.FixedSizeBinaryIter.html          |   2 +-
 arrow/array/type.FixedSizeListIter.html            |   2 +-
 arrow/array/type.Float16Array.html                 |   6 +-
 arrow/array/type.Float16BufferBuilder.html         |   2 +-
 arrow/array/type.Float16Builder.html               |   2 +-
 arrow/array/type.Float32Array.html                 |   4 +-
 arrow/array/type.Float32BufferBuilder.html         |   2 +-
 arrow/array/type.Float32Builder.html               |   2 +-
 arrow/array/type.Float64Array.html                 |   4 +-
 arrow/array/type.Float64BufferBuilder.html         |   2 +-
 arrow/array/type.Float64Builder.html               |   2 +-
 arrow/array/type.GenericBinaryArray.html           |   2 +-
 arrow/array/type.GenericBinaryBuilder.html         |   2 +-
 arrow/array/type.GenericBinaryIter.html            |   2 +-
 arrow/array/type.GenericListArrayIter.html         |   2 +-
 arrow/array/type.GenericStringArray.html           |   2 +-
 arrow/array/type.GenericStringBuilder.html         |   2 +-
 arrow/array/type.GenericStringIter.html            |   2 +-
 arrow/array/type.Int16Array.html                   |   4 +-
 arrow/array/type.Int16BufferBuilder.html           |   2 +-
 arrow/array/type.Int16Builder.html                 |   2 +-
 arrow/array/type.Int16DictionaryArray.html         |   4 +-
 arrow/array/type.Int16RunArray.html                |   4 +-
 arrow/array/type.Int32Array.html                   |   4 +-
 arrow/array/type.Int32BufferBuilder.html           |   2 +-
 arrow/array/type.Int32Builder.html                 |   2 +-
 arrow/array/type.Int32DictionaryArray.html         |   4 +-
 arrow/array/type.Int32RunArray.html                |   4 +-
 arrow/array/type.Int64Array.html                   |   4 +-
 arrow/array/type.Int64BufferBuilder.html           |   2 +-
 arrow/array/type.Int64Builder.html                 |   2 +-
 arrow/array/type.Int64DictionaryArray.html         |   4 +-
 arrow/array/type.Int64RunArray.html                |   4 +-
 arrow/array/type.Int8Array.html                    |   4 +-
 arrow/array/type.Int8BufferBuilder.html            |   2 +-
 arrow/array/type.Int8Builder.html                  |   2 +-
 arrow/array/type.Int8DictionaryArray.html          |   4 +-
 arrow/array/type.IntervalDayTimeArray.html         |   2 +-
 arrow/array/type.IntervalDayTimeBufferBuilder.html |   2 +-
 arrow/array/type.IntervalDayTimeBuilder.html       |   2 +-
 arrow/array/type.IntervalMonthDayNanoArray.html    |   2 +-
 .../type.IntervalMonthDayNanoBufferBuilder.html    |   2 +-
 arrow/array/type.IntervalMonthDayNanoBuilder.html  |   2 +-
 arrow/array/type.IntervalYearMonthArray.html       |   2 +-
 .../array/type.IntervalYearMonthBufferBuilder.html |   2 +-
 arrow/array/type.IntervalYearMonthBuilder.html     |   2 +-
 arrow/array/type.LargeBinaryArray.html             |   4 +-
 arrow/array/type.LargeBinaryBuilder.html           |   2 +-
 arrow/array/type.LargeBinaryDictionaryBuilder.html |   2 +-
 arrow/array/type.LargeBinaryRunBuilder.html        |   2 +-
 arrow/array/type.LargeListArray.html               |   2 +-
 arrow/array/type.LargeListBuilder.html             |   2 +-
 arrow/array/type.LargeStringArray.html             |   4 +-
 arrow/array/type.LargeStringBuilder.html           |   2 +-
 arrow/array/type.LargeStringDictionaryBuilder.html |   2 +-
 arrow/array/type.LargeStringRunBuilder.html        |   2 +-
 arrow/array/type.ListArray.html                    |   2 +-
 arrow/array/type.ListBuilder.html                  |   2 +-
 arrow/array/type.MapArrayIter.html                 |   2 +-
 arrow/array/type.PrimitiveIter.html                |   2 +-
 arrow/array/type.StringArray.html                  |   4 +-
 arrow/array/type.StringBuilder.html                |   2 +-
 arrow/array/type.StringDictionaryBuilder.html      |   2 +-
 arrow/array/type.StringRunBuilder.html             |   2 +-
 arrow/array/type.Time32MillisecondArray.html       |   2 +-
 .../array/type.Time32MillisecondBufferBuilder.html |   2 +-
 arrow/array/type.Time32MillisecondBuilder.html     |   2 +-
 arrow/array/type.Time32SecondArray.html            |   2 +-
 arrow/array/type.Time32SecondBufferBuilder.html    |   2 +-
 arrow/array/type.Time32SecondBuilder.html          |   2 +-
 arrow/array/type.Time64MicrosecondArray.html       |   2 +-
 .../array/type.Time64MicrosecondBufferBuilder.html |   2 +-
 arrow/array/type.Time64MicrosecondBuilder.html     |   2 +-
 arrow/array/type.Time64NanosecondArray.html        |   2 +-
 .../array/type.Time64NanosecondBufferBuilder.html  |   2 +-
 arrow/array/type.Time64NanosecondBuilder.html      |   2 +-
 arrow/array/type.TimestampMicrosecondArray.html    |   2 +-
 .../type.TimestampMicrosecondBufferBuilder.html    |   2 +-
 arrow/array/type.TimestampMicrosecondBuilder.html  |   2 +-
 arrow/array/type.TimestampMillisecondArray.html    |   2 +-
 .../type.TimestampMillisecondBufferBuilder.html    |   2 +-
 arrow/array/type.TimestampMillisecondBuilder.html  |   2 +-
 arrow/array/type.TimestampNanosecondArray.html     |   2 +-
 .../type.TimestampNanosecondBufferBuilder.html     |   2 +-
 arrow/array/type.TimestampNanosecondBuilder.html   |   2 +-
 arrow/array/type.TimestampSecondArray.html         |   8 +-
 arrow/array/type.TimestampSecondBufferBuilder.html |   2 +-
 arrow/array/type.TimestampSecondBuilder.html       |   2 +-
 arrow/array/type.UInt16Array.html                  |   4 +-
 arrow/array/type.UInt16BufferBuilder.html          |   2 +-
 arrow/array/type.UInt16Builder.html                |   2 +-
 arrow/array/type.UInt16DictionaryArray.html        |   4 +-
 arrow/array/type.UInt32Array.html                  |   4 +-
 arrow/array/type.UInt32BufferBuilder.html          |   2 +-
 arrow/array/type.UInt32Builder.html                |   2 +-
 arrow/array/type.UInt32DictionaryArray.html        |   4 +-
 arrow/array/type.UInt64Array.html                  |   4 +-
 arrow/array/type.UInt64BufferBuilder.html          |   2 +-
 arrow/array/type.UInt64Builder.html                |   2 +-
 arrow/array/type.UInt64DictionaryArray.html        |   4 +-
 arrow/array/type.UInt8Array.html                   |   4 +-
 arrow/array/type.UInt8BufferBuilder.html           |   2 +-
 arrow/array/type.UInt8Builder.html                 |   2 +-
 arrow/array/type.UInt8DictionaryArray.html         |   4 +-
 .../fn.validate_decimal_precision_and_scale.html   |   2 +-
 arrow/array/types/index.html                       |   6 +-
 arrow/array/types/struct.BooleanType.html          |  12 +-
 arrow/array/types/struct.Date32Type.html           |  28 +-
 arrow/array/types/struct.Date64Type.html           |  28 +-
 arrow/array/types/struct.Decimal128Type.html       |  12 +-
 arrow/array/types/struct.Decimal256Type.html       |  12 +-
 .../types/struct.DurationMicrosecondType.html      |  12 +-
 .../types/struct.DurationMillisecondType.html      |  12 +-
 .../array/types/struct.DurationNanosecondType.html |  12 +-
 arrow/array/types/struct.DurationSecondType.html   |  12 +-
 arrow/array/types/struct.Float16Type.html          |  12 +-
 arrow/array/types/struct.Float32Type.html          |  12 +-
 arrow/array/types/struct.Float64Type.html          |  12 +-
 arrow/array/types/struct.GenericBinaryType.html    |  12 +-
 arrow/array/types/struct.GenericStringType.html    |  12 +-
 arrow/array/types/struct.Int16Type.html            |  12 +-
 arrow/array/types/struct.Int32Type.html            |  12 +-
 arrow/array/types/struct.Int64Type.html            |  12 +-
 arrow/array/types/struct.Int8Type.html             |  12 +-
 arrow/array/types/struct.IntervalDayTimeType.html  |  20 +-
 .../types/struct.IntervalMonthDayNanoType.html     |  20 +-
 .../array/types/struct.IntervalYearMonthType.html  |  16 +-
 .../array/types/struct.Time32MillisecondType.html  |  12 +-
 arrow/array/types/struct.Time32SecondType.html     |  12 +-
 .../array/types/struct.Time64MicrosecondType.html  |  12 +-
 arrow/array/types/struct.Time64NanosecondType.html |  12 +-
 .../types/struct.TimestampMicrosecondType.html     |  24 +-
 .../types/struct.TimestampMillisecondType.html     |  24 +-
 .../types/struct.TimestampNanosecondType.html      |  24 +-
 arrow/array/types/struct.TimestampSecondType.html  |  24 +-
 arrow/array/types/struct.UInt16Type.html           |  12 +-
 arrow/array/types/struct.UInt32Type.html           |  12 +-
 arrow/array/types/struct.UInt64Type.html           |  12 +-
 arrow/array/types/struct.UInt8Type.html            |  12 +-
 .../array/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/buffer/fn.bitwise_bin_op_helper.html         |   2 +-
 arrow/buffer/fn.bitwise_quaternary_op_helper.html  |   2 +-
 arrow/buffer/fn.bitwise_unary_op_helper.html       |   2 +-
 arrow/buffer/fn.buffer_bin_and.html                |   2 +-
 arrow/buffer/fn.buffer_bin_and_not.html            |   2 +-
 arrow/buffer/fn.buffer_bin_or.html                 |   2 +-
 arrow/buffer/fn.buffer_bin_xor.html                |   2 +-
 arrow/buffer/fn.buffer_unary_not.html              |   2 +-
 arrow/buffer/index.html                            |   6 +-
 arrow/buffer/struct.BooleanBuffer.html             |  26 +-
 arrow/buffer/struct.Buffer.html                    | 438 +++++-----
 arrow/buffer/struct.MutableBuffer.html             | 901 ++++++++++-----------
 arrow/buffer/struct.NullBuffer.html                |  16 +-
 arrow/buffer/struct.OffsetBuffer.html              | 418 +++++-----
 arrow/buffer/struct.RunEndBuffer.html              |  20 +-
 arrow/buffer/struct.ScalarBuffer.html              | 430 +++++-----
 arrow/compute/fn.and.html                          |   6 +-
 arrow/compute/fn.and_kleene.html                   |   8 +-
 arrow/compute/fn.and_not.html                      |   6 +-
 arrow/compute/fn.binary.html                       |   4 +-
 arrow/compute/fn.binary_mut.html                   |   4 +-
 arrow/compute/fn.bit_and.html                      |   2 +-
 arrow/compute/fn.bit_or.html                       |   2 +-
 arrow/compute/fn.bit_xor.html                      |   2 +-
 arrow/compute/fn.bool_and.html                     |   2 +-
 arrow/compute/fn.bool_or.html                      |   2 +-
 arrow/compute/fn.build_filter.html                 |   2 +-
 arrow/compute/fn.can_cast_types.html               |   2 +-
 arrow/compute/fn.cast.html                         |   2 +-
 arrow/compute/fn.cast_with_options.html            |   4 +-
 arrow/compute/fn.concat.html                       |   2 +-
 arrow/compute/fn.concat_batches.html               |   2 +-
 arrow/compute/fn.day.html                          |   2 +-
 arrow/compute/fn.day_dyn.html                      |   2 +-
 arrow/compute/fn.doy.html                          |   2 +-
 arrow/compute/fn.doy_dyn.html                      |   2 +-
 arrow/compute/fn.filter.html                       |   4 +-
 arrow/compute/fn.filter_record_batch.html          |   2 +-
 arrow/compute/fn.hour.html                         |   2 +-
 arrow/compute/fn.hour_dyn.html                     |   2 +-
 arrow/compute/fn.interleave.html                   |   2 +-
 arrow/compute/fn.is_not_null.html                  |   6 +-
 arrow/compute/fn.is_null.html                      |   6 +-
 .../fn.lexicographical_partition_ranges.html       |   2 +-
 arrow/compute/fn.lexsort.html                      |   2 +-
 arrow/compute/fn.lexsort_to_indices.html           |   2 +-
 arrow/compute/fn.max.html                          |   2 +-
 arrow/compute/fn.max_array.html                    |   2 +-
 arrow/compute/fn.max_binary.html                   |   2 +-
 arrow/compute/fn.max_boolean.html                  |   2 +-
 arrow/compute/fn.max_string.html                   |   2 +-
 arrow/compute/fn.microsecond.html                  |   2 +-
 arrow/compute/fn.microsecond_dyn.html              |   2 +-
 arrow/compute/fn.millisecond.html                  |   2 +-
 arrow/compute/fn.millisecond_dyn.html              |   2 +-
 arrow/compute/fn.min.html                          |   2 +-
 arrow/compute/fn.min_array.html                    |   2 +-
 arrow/compute/fn.min_binary.html                   |   2 +-
 arrow/compute/fn.min_boolean.html                  |   2 +-
 arrow/compute/fn.min_string.html                   |   2 +-
 arrow/compute/fn.minute.html                       |   2 +-
 arrow/compute/fn.minute_dyn.html                   |   2 +-
 arrow/compute/fn.month.html                        |   2 +-
 arrow/compute/fn.month_dyn.html                    |   2 +-
 arrow/compute/fn.multiply_fixed_point.html         |   2 +-
 arrow/compute/fn.multiply_fixed_point_checked.html |   2 +-
 arrow/compute/fn.multiply_fixed_point_dyn.html     |   2 +-
 arrow/compute/fn.nanosecond.html                   |   2 +-
 arrow/compute/fn.nanosecond_dyn.html               |   2 +-
 arrow/compute/fn.not.html                          |   6 +-
 arrow/compute/fn.nullif.html                       |   2 +-
 arrow/compute/fn.num_days_from_monday.html         |   2 +-
 arrow/compute/fn.num_days_from_monday_dyn.html     |   2 +-
 arrow/compute/fn.num_days_from_sunday.html         |   2 +-
 arrow/compute/fn.num_days_from_sunday_dyn.html     |   2 +-
 arrow/compute/fn.or.html                           |   6 +-
 arrow/compute/fn.or_kleene.html                    |   8 +-
 arrow/compute/fn.partial_sort.html                 |   2 +-
 arrow/compute/fn.partition.html                    |   6 +-
 arrow/compute/fn.prep_null_mask_filter.html        |   2 +-
 arrow/compute/fn.quarter.html                      |   2 +-
 arrow/compute/fn.quarter_dyn.html                  |   2 +-
 arrow/compute/fn.rank.html                         |   2 +-
 arrow/compute/fn.regexp_is_match_utf8.html         |   2 +-
 arrow/compute/fn.regexp_is_match_utf8_scalar.html  |   2 +-
 arrow/compute/fn.regexp_match.html                 |   2 +-
 arrow/compute/fn.second.html                       |   2 +-
 arrow/compute/fn.second_dyn.html                   |   2 +-
 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              |   2 +-
 arrow/compute/fn.sum.html                          |   2 +-
 arrow/compute/fn.sum_array.html                    |   2 +-
 arrow/compute/fn.sum_array_checked.html            |   2 +-
 arrow/compute/fn.sum_checked.html                  |   2 +-
 arrow/compute/fn.take.html                         |   8 +-
 arrow/compute/fn.try_binary.html                   |   4 +-
 arrow/compute/fn.try_binary_mut.html               |   4 +-
 arrow/compute/fn.try_unary.html                    |   2 +-
 arrow/compute/fn.try_unary_dyn.html                |   2 +-
 arrow/compute/fn.try_unary_mut.html                |   2 +-
 arrow/compute/fn.unary.html                        |   2 +-
 arrow/compute/fn.unary_dyn.html                    |   2 +-
 arrow/compute/fn.unary_mut.html                    |   2 +-
 ...fn.using_chrono_tz_and_utc_naive_date_time.html |   2 +-
 arrow/compute/fn.week.html                         |   2 +-
 arrow/compute/fn.week_dyn.html                     |   2 +-
 arrow/compute/fn.year.html                         |   2 +-
 arrow/compute/fn.year_dyn.html                     |   2 +-
 arrow/compute/index.html                           |   8 +-
 arrow/compute/kernels/aggregate/fn.bit_and.html    |   2 +-
 arrow/compute/kernels/aggregate/fn.bit_or.html     |   2 +-
 arrow/compute/kernels/aggregate/fn.bit_xor.html    |   2 +-
 arrow/compute/kernels/aggregate/fn.bool_and.html   |   2 +-
 arrow/compute/kernels/aggregate/fn.bool_or.html    |   2 +-
 arrow/compute/kernels/aggregate/fn.max.html        |   2 +-
 arrow/compute/kernels/aggregate/fn.max_array.html  |   2 +-
 arrow/compute/kernels/aggregate/fn.max_binary.html |   2 +-
 .../compute/kernels/aggregate/fn.max_boolean.html  |   2 +-
 arrow/compute/kernels/aggregate/fn.max_string.html |   2 +-
 arrow/compute/kernels/aggregate/fn.min.html        |   2 +-
 arrow/compute/kernels/aggregate/fn.min_array.html  |   2 +-
 arrow/compute/kernels/aggregate/fn.min_binary.html |   2 +-
 .../compute/kernels/aggregate/fn.min_boolean.html  |   2 +-
 arrow/compute/kernels/aggregate/fn.min_string.html |   2 +-
 arrow/compute/kernels/aggregate/fn.sum.html        |   2 +-
 arrow/compute/kernels/aggregate/fn.sum_array.html  |   2 +-
 .../kernels/aggregate/fn.sum_array_checked.html    |   2 +-
 .../compute/kernels/aggregate/fn.sum_checked.html  |   2 +-
 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      |   2 +-
 arrow/compute/kernels/arity/fn.try_unary_dyn.html  |   2 +-
 arrow/compute/kernels/arity/fn.try_unary_mut.html  |   2 +-
 arrow/compute/kernels/arity/fn.unary.html          |   2 +-
 arrow/compute/kernels/arity/fn.unary_dyn.html      |   2 +-
 arrow/compute/kernels/arity/fn.unary_mut.html      |   2 +-
 arrow/compute/kernels/arity/index.html             |   4 +-
 arrow/compute/kernels/bitwise/fn.bitwise_and.html  |   2 +-
 .../kernels/bitwise/fn.bitwise_and_not.html        |   2 +-
 .../kernels/bitwise/fn.bitwise_and_scalar.html     |   2 +-
 arrow/compute/kernels/bitwise/fn.bitwise_not.html  |   2 +-
 arrow/compute/kernels/bitwise/fn.bitwise_or.html   |   2 +-
 .../kernels/bitwise/fn.bitwise_or_scalar.html      |   2 +-
 .../kernels/bitwise/fn.bitwise_shift_left.html     |   2 +-
 .../bitwise/fn.bitwise_shift_left_scalar.html      |   2 +-
 .../kernels/bitwise/fn.bitwise_shift_right.html    |   2 +-
 .../bitwise/fn.bitwise_shift_right_scalar.html     |   2 +-
 arrow/compute/kernels/bitwise/fn.bitwise_xor.html  |   2 +-
 .../kernels/bitwise/fn.bitwise_xor_scalar.html     |   2 +-
 arrow/compute/kernels/bitwise/index.html           |   4 +-
 arrow/compute/kernels/boolean/fn.and.html          |   6 +-
 arrow/compute/kernels/boolean/fn.and_kleene.html   |   8 +-
 arrow/compute/kernels/boolean/fn.and_not.html      |   6 +-
 arrow/compute/kernels/boolean/fn.is_not_null.html  |   6 +-
 arrow/compute/kernels/boolean/fn.is_null.html      |   6 +-
 arrow/compute/kernels/boolean/fn.not.html          |   6 +-
 arrow/compute/kernels/boolean/fn.or.html           |   6 +-
 arrow/compute/kernels/boolean/fn.or_kleene.html    |   8 +-
 arrow/compute/kernels/boolean/index.html           |   4 +-
 arrow/compute/kernels/cast/fn.can_cast_types.html  |   2 +-
 arrow/compute/kernels/cast/fn.cast.html            |   2 +-
 .../compute/kernels/cast/fn.cast_with_options.html |   4 +-
 arrow/compute/kernels/cast/index.html              |   4 +-
 arrow/compute/kernels/cast/struct.CastOptions.html |  12 +-
 .../kernels/cast_utils/fn.parse_decimal.html       |   2 +-
 .../cast_utils/fn.parse_interval_day_time.html     |   2 +-
 .../fn.parse_interval_month_day_nano.html          |   2 +-
 .../cast_utils/fn.parse_interval_year_month.html   |   2 +-
 .../kernels/cast_utils/fn.string_to_datetime.html  |   2 +-
 .../cast_utils/fn.string_to_time_nanoseconds.html  |   4 +-
 .../cast_utils/fn.string_to_timestamp_nanos.html   |   6 +-
 arrow/compute/kernels/cast_utils/index.html        |   8 +-
 arrow/compute/kernels/cast_utils/trait.Parser.html |   2 +-
 .../kernels/cast_utils/type.MonthDayNano.html      |   2 +-
 arrow/compute/kernels/cmp/fn.distinct.html         |   2 +-
 arrow/compute/kernels/cmp/fn.eq.html               |   2 +-
 arrow/compute/kernels/cmp/fn.gt.html               |   2 +-
 arrow/compute/kernels/cmp/fn.gt_eq.html            |   2 +-
 arrow/compute/kernels/cmp/fn.lt.html               |   2 +-
 arrow/compute/kernels/cmp/fn.lt_eq.html            |   2 +-
 arrow/compute/kernels/cmp/fn.neq.html              |   2 +-
 arrow/compute/kernels/cmp/fn.not_distinct.html     |   2 +-
 arrow/compute/kernels/cmp/index.html               |   4 +-
 arrow/compute/kernels/comparison/fn.contains.html  |   2 +-
 arrow/compute/kernels/comparison/fn.ends_with.html |   2 +-
 arrow/compute/kernels/comparison/fn.eq.html        |   2 +-
 arrow/compute/kernels/comparison/fn.eq_binary.html |   2 +-
 .../kernels/comparison/fn.eq_binary_scalar.html    |   2 +-
 arrow/compute/kernels/comparison/fn.eq_bool.html   |   2 +-
 .../kernels/comparison/fn.eq_bool_scalar.html      |   2 +-
 arrow/compute/kernels/comparison/fn.eq_dyn.html    |   4 +-
 .../comparison/fn.eq_dyn_binary_scalar.html        |   2 +-
 .../kernels/comparison/fn.eq_dyn_bool_scalar.html  |   2 +-
 .../kernels/comparison/fn.eq_dyn_scalar.html       |   2 +-
 .../kernels/comparison/fn.eq_dyn_utf8_scalar.html  |   2 +-
 arrow/compute/kernels/comparison/fn.eq_scalar.html |   2 +-
 arrow/compute/kernels/comparison/fn.eq_utf8.html   |   2 +-
 .../kernels/comparison/fn.eq_utf8_scalar.html      |   2 +-
 arrow/compute/kernels/comparison/fn.gt.html        |   2 +-
 arrow/compute/kernels/comparison/fn.gt_binary.html |   2 +-
 .../kernels/comparison/fn.gt_binary_scalar.html    |   2 +-
 arrow/compute/kernels/comparison/fn.gt_bool.html   |   2 +-
 .../kernels/comparison/fn.gt_bool_scalar.html      |   2 +-
 arrow/compute/kernels/comparison/fn.gt_dyn.html    |   4 +-
 .../comparison/fn.gt_dyn_binary_scalar.html        |   2 +-
 .../kernels/comparison/fn.gt_dyn_bool_scalar.html  |   2 +-
 .../kernels/comparison/fn.gt_dyn_scalar.html       |   2 +-
 .../kernels/comparison/fn.gt_dyn_utf8_scalar.html  |   2 +-
 arrow/compute/kernels/comparison/fn.gt_eq.html     |   2 +-
 .../kernels/comparison/fn.gt_eq_binary.html        |   2 +-
 .../kernels/comparison/fn.gt_eq_binary_scalar.html |   2 +-
 .../compute/kernels/comparison/fn.gt_eq_bool.html  |   2 +-
 .../kernels/comparison/fn.gt_eq_bool_scalar.html   |   2 +-
 arrow/compute/kernels/comparison/fn.gt_eq_dyn.html |   4 +-
 .../comparison/fn.gt_eq_dyn_binary_scalar.html     |   2 +-
 .../comparison/fn.gt_eq_dyn_bool_scalar.html       |   2 +-
 .../kernels/comparison/fn.gt_eq_dyn_scalar.html    |   2 +-
 .../comparison/fn.gt_eq_dyn_utf8_scalar.html       |   2 +-
 .../kernels/comparison/fn.gt_eq_scalar.html        |   2 +-
 .../compute/kernels/comparison/fn.gt_eq_utf8.html  |   2 +-
 .../kernels/comparison/fn.gt_eq_utf8_scalar.html   |   2 +-
 arrow/compute/kernels/comparison/fn.gt_scalar.html |   2 +-
 arrow/compute/kernels/comparison/fn.gt_utf8.html   |   2 +-
 .../kernels/comparison/fn.gt_utf8_scalar.html      |   2 +-
 arrow/compute/kernels/comparison/fn.ilike.html     |   2 +-
 arrow/compute/kernels/comparison/fn.in_list.html   |   2 +-
 .../kernels/comparison/fn.in_list_utf8.html        |   2 +-
 arrow/compute/kernels/comparison/fn.like.html      |   2 +-
 arrow/compute/kernels/comparison/fn.lt.html        |   2 +-
 arrow/compute/kernels/comparison/fn.lt_binary.html |   2 +-
 .../kernels/comparison/fn.lt_binary_scalar.html    |   2 +-
 arrow/compute/kernels/comparison/fn.lt_bool.html   |   2 +-
 .../kernels/comparison/fn.lt_bool_scalar.html      |   2 +-
 arrow/compute/kernels/comparison/fn.lt_dyn.html    |   4 +-
 .../comparison/fn.lt_dyn_binary_scalar.html        |   2 +-
 .../kernels/comparison/fn.lt_dyn_bool_scalar.html  |   2 +-
 .../kernels/comparison/fn.lt_dyn_scalar.html       |   2 +-
 .../kernels/comparison/fn.lt_dyn_utf8_scalar.html  |   2 +-
 arrow/compute/kernels/comparison/fn.lt_eq.html     |   2 +-
 .../kernels/comparison/fn.lt_eq_binary.html        |   2 +-
 .../kernels/comparison/fn.lt_eq_binary_scalar.html |   2 +-
 .../compute/kernels/comparison/fn.lt_eq_bool.html  |   2 +-
 .../kernels/comparison/fn.lt_eq_bool_scalar.html   |   2 +-
 arrow/compute/kernels/comparison/fn.lt_eq_dyn.html |   4 +-
 .../comparison/fn.lt_eq_dyn_binary_scalar.html     |   2 +-
 .../comparison/fn.lt_eq_dyn_bool_scalar.html       |   2 +-
 .../kernels/comparison/fn.lt_eq_dyn_scalar.html    |   2 +-
 .../comparison/fn.lt_eq_dyn_utf8_scalar.html       |   2 +-
 .../kernels/comparison/fn.lt_eq_scalar.html        |   2 +-
 .../compute/kernels/comparison/fn.lt_eq_utf8.html  |   2 +-
 .../kernels/comparison/fn.lt_eq_utf8_scalar.html   |   2 +-
 arrow/compute/kernels/comparison/fn.lt_scalar.html |   2 +-
 arrow/compute/kernels/comparison/fn.lt_utf8.html   |   2 +-
 .../kernels/comparison/fn.lt_utf8_scalar.html      |   2 +-
 arrow/compute/kernels/comparison/fn.neq.html       |   2 +-
 .../compute/kernels/comparison/fn.neq_binary.html  |   2 +-
 .../kernels/comparison/fn.neq_binary_scalar.html   |   2 +-
 arrow/compute/kernels/comparison/fn.neq_bool.html  |   2 +-
 .../kernels/comparison/fn.neq_bool_scalar.html     |   2 +-
 arrow/compute/kernels/comparison/fn.neq_dyn.html   |   4 +-
 .../comparison/fn.neq_dyn_binary_scalar.html       |   2 +-
 .../kernels/comparison/fn.neq_dyn_bool_scalar.html |   2 +-
 .../kernels/comparison/fn.neq_dyn_scalar.html      |   2 +-
 .../kernels/comparison/fn.neq_dyn_utf8_scalar.html |   2 +-
 .../compute/kernels/comparison/fn.neq_scalar.html  |   2 +-
 arrow/compute/kernels/comparison/fn.neq_utf8.html  |   2 +-
 .../kernels/comparison/fn.neq_utf8_scalar.html     |   2 +-
 arrow/compute/kernels/comparison/fn.nilike.html    |   2 +-
 arrow/compute/kernels/comparison/fn.nlike.html     |   2 +-
 .../comparison/fn.regexp_is_match_utf8.html        |   2 +-
 .../comparison/fn.regexp_is_match_utf8_scalar.html |   2 +-
 .../compute/kernels/comparison/fn.starts_with.html |   2 +-
 arrow/compute/kernels/comparison/fn.unary_cmp.html |   2 +-
 arrow/compute/kernels/comparison/index.html        |   4 +-
 arrow/compute/kernels/concat/fn.concat.html        |   2 +-
 .../compute/kernels/concat/fn.concat_batches.html  |   2 +-
 arrow/compute/kernels/concat/index.html            |   4 +-
 .../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/compute/kernels/concat_elements/index.html   |   4 +-
 arrow/compute/kernels/filter/fn.build_filter.html  |   2 +-
 arrow/compute/kernels/filter/fn.filter.html        |   4 +-
 .../kernels/filter/fn.filter_record_batch.html     |   2 +-
 .../kernels/filter/fn.prep_null_mask_filter.html   |   2 +-
 arrow/compute/kernels/filter/index.html            |   8 +-
 .../kernels/filter/struct.FilterBuilder.html       |  12 +-
 .../kernels/filter/struct.FilterPredicate.html     |  12 +-
 .../kernels/filter/struct.SlicesIterator.html      |  16 +-
 arrow/compute/kernels/filter/type.Filter.html      |   2 +-
 arrow/compute/kernels/fn.cast.html                 |   2 +-
 arrow/compute/kernels/index.html                   |   6 +-
 .../compute/kernels/interleave/fn.interleave.html  |   2 +-
 arrow/compute/kernels/interleave/index.html        |   4 +-
 arrow/compute/kernels/length/fn.bit_length.html    |   2 +-
 arrow/compute/kernels/length/fn.length.html        |   2 +-
 arrow/compute/kernels/length/index.html            |   4 +-
 arrow/compute/kernels/nullif/fn.nullif.html        |   2 +-
 arrow/compute/kernels/nullif/index.html            |   4 +-
 arrow/compute/kernels/numeric/fn.add.html          |   2 +-
 arrow/compute/kernels/numeric/fn.add_wrapping.html |   2 +-
 arrow/compute/kernels/numeric/fn.div.html          |   2 +-
 arrow/compute/kernels/numeric/fn.mul.html          |   2 +-
 arrow/compute/kernels/numeric/fn.mul_wrapping.html |   2 +-
 arrow/compute/kernels/numeric/fn.neg.html          |   2 +-
 arrow/compute/kernels/numeric/fn.neg_wrapping.html |   2 +-
 arrow/compute/kernels/numeric/fn.rem.html          |   2 +-
 arrow/compute/kernels/numeric/fn.sub.html          |   2 +-
 arrow/compute/kernels/numeric/fn.sub_wrapping.html |   2 +-
 arrow/compute/kernels/numeric/index.html           |   4 +-
 .../fn.lexicographical_partition_ranges.html       |   2 +-
 arrow/compute/kernels/partition/fn.partition.html  |   6 +-
 arrow/compute/kernels/partition/index.html         |   4 +-
 .../kernels/partition/struct.Partitions.html       |  12 +-
 arrow/compute/kernels/rank/fn.rank.html            |   2 +-
 arrow/compute/kernels/rank/index.html              |   4 +-
 .../kernels/regexp/fn.regexp_is_match_utf8.html    |   2 +-
 .../regexp/fn.regexp_is_match_utf8_scalar.html     |   2 +-
 arrow/compute/kernels/regexp/fn.regexp_match.html  |   2 +-
 arrow/compute/kernels/regexp/index.html            |   4 +-
 arrow/compute/kernels/sort/fn.lexsort.html         |   2 +-
 .../kernels/sort/fn.lexsort_to_indices.html        |   2 +-
 arrow/compute/kernels/sort/fn.partial_sort.html    |   2 +-
 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 |   2 +-
 arrow/compute/kernels/sort/index.html              |   6 +-
 .../sort/struct.LexicographicalComparator.html     |  12 +-
 arrow/compute/kernels/sort/struct.SortColumn.html  |  12 +-
 arrow/compute/kernels/sort/struct.SortOptions.html |  12 +-
 arrow/compute/kernels/substring/fn.substring.html  |  10 +-
 .../kernels/substring/fn.substring_by_char.html    |   8 +-
 arrow/compute/kernels/substring/index.html         |   4 +-
 arrow/compute/kernels/take/fn.take.html            |   8 +-
 arrow/compute/kernels/take/index.html              |   4 +-
 arrow/compute/kernels/take/struct.TakeOptions.html |  12 +-
 arrow/compute/kernels/temporal/fn.day.html         |   2 +-
 arrow/compute/kernels/temporal/fn.day_dyn.html     |   2 +-
 arrow/compute/kernels/temporal/fn.doy.html         |   2 +-
 arrow/compute/kernels/temporal/fn.doy_dyn.html     |   2 +-
 arrow/compute/kernels/temporal/fn.hour.html        |   2 +-
 arrow/compute/kernels/temporal/fn.hour_dyn.html    |   2 +-
 arrow/compute/kernels/temporal/fn.microsecond.html |   2 +-
 .../kernels/temporal/fn.microsecond_dyn.html       |   2 +-
 arrow/compute/kernels/temporal/fn.millisecond.html |   2 +-
 .../kernels/temporal/fn.millisecond_dyn.html       |   2 +-
 arrow/compute/kernels/temporal/fn.minute.html      |   2 +-
 arrow/compute/kernels/temporal/fn.minute_dyn.html  |   2 +-
 arrow/compute/kernels/temporal/fn.month.html       |   2 +-
 arrow/compute/kernels/temporal/fn.month_dyn.html   |   2 +-
 arrow/compute/kernels/temporal/fn.nanosecond.html  |   2 +-
 .../kernels/temporal/fn.nanosecond_dyn.html        |   2 +-
 .../kernels/temporal/fn.num_days_from_monday.html  |   2 +-
 .../temporal/fn.num_days_from_monday_dyn.html      |   2 +-
 .../kernels/temporal/fn.num_days_from_sunday.html  |   2 +-
 .../temporal/fn.num_days_from_sunday_dyn.html      |   2 +-
 arrow/compute/kernels/temporal/fn.quarter.html     |   2 +-
 arrow/compute/kernels/temporal/fn.quarter_dyn.html |   2 +-
 arrow/compute/kernels/temporal/fn.second.html      |   2 +-
 arrow/compute/kernels/temporal/fn.second_dyn.html  |   2 +-
 ...fn.using_chrono_tz_and_utc_naive_date_time.html |   2 +-
 arrow/compute/kernels/temporal/fn.week.html        |   2 +-
 arrow/compute/kernels/temporal/fn.week_dyn.html    |   2 +-
 arrow/compute/kernels/temporal/fn.year.html        |   2 +-
 arrow/compute/kernels/temporal/fn.year_dyn.html    |   2 +-
 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              |  12 +-
 arrow/compute/struct.FilterBuilder.html            |  12 +-
 arrow/compute/struct.FilterPredicate.html          |  12 +-
 .../compute/struct.LexicographicalComparator.html  |  12 +-
 arrow/compute/struct.Partitions.html               |  12 +-
 arrow/compute/struct.SlicesIterator.html           |  16 +-
 arrow/compute/struct.SortColumn.html               |  12 +-
 arrow/compute/struct.SortOptions.html              |  12 +-
 arrow/compute/struct.TakeOptions.html              |  12 +-
 arrow/compute/type.Filter.html                     |   2 +-
 .../constant.DECIMAL128_MAX_PRECISION.html         |   2 +-
 arrow/datatypes/constant.DECIMAL128_MAX_SCALE.html |   2 +-
 .../constant.DECIMAL256_MAX_PRECISION.html         |   2 +-
 arrow/datatypes/constant.DECIMAL256_MAX_SCALE.html |   2 +-
 .../datatypes/constant.DECIMAL_DEFAULT_SCALE.html  |   2 +-
 .../constant.MAX_DECIMAL_FOR_EACH_PRECISION.html   |   2 +-
 .../constant.MIN_DECIMAL_FOR_EACH_PRECISION.html   |   2 +-
 arrow/datatypes/enum.DataType.html                 |  28 +-
 arrow/datatypes/enum.IntervalUnit.html             |  12 +-
 arrow/datatypes/enum.TimeUnit.html                 |  12 +-
 arrow/datatypes/enum.UnionMode.html                |  12 +-
 .../fn.validate_decimal256_precision.html          |   2 +-
 arrow/datatypes/fn.validate_decimal_precision.html |   2 +-
 .../fn.validate_decimal_precision_and_scale.html   |   2 +-
 arrow/datatypes/index.html                         |  10 +-
 arrow/datatypes/struct.BooleanType.html            |  12 +-
 arrow/datatypes/struct.Date32Type.html             |  28 +-
 arrow/datatypes/struct.Date64Type.html             |  28 +-
 arrow/datatypes/struct.Decimal128Type.html         |  12 +-
 arrow/datatypes/struct.Decimal256Type.html         |  12 +-
 .../datatypes/struct.DurationMicrosecondType.html  |  12 +-
 .../datatypes/struct.DurationMillisecondType.html  |  12 +-
 arrow/datatypes/struct.DurationNanosecondType.html |  12 +-
 arrow/datatypes/struct.DurationSecondType.html     |  12 +-
 arrow/datatypes/struct.Field.html                  |  20 +-
 arrow/datatypes/struct.Fields.html                 | 414 +++++-----
 arrow/datatypes/struct.Float16Type.html            |  12 +-
 arrow/datatypes/struct.Float32Type.html            |  12 +-
 arrow/datatypes/struct.Float64Type.html            |  12 +-
 arrow/datatypes/struct.GenericBinaryType.html      |  12 +-
 arrow/datatypes/struct.GenericStringType.html      |  12 +-
 arrow/datatypes/struct.Int16Type.html              |  12 +-
 arrow/datatypes/struct.Int32Type.html              |  12 +-
 arrow/datatypes/struct.Int64Type.html              |  12 +-
 arrow/datatypes/struct.Int8Type.html               |  12 +-
 arrow/datatypes/struct.IntervalDayTimeType.html    |  20 +-
 .../datatypes/struct.IntervalMonthDayNanoType.html |  20 +-
 arrow/datatypes/struct.IntervalYearMonthType.html  |  16 +-
 arrow/datatypes/struct.Schema.html                 |  20 +-
 arrow/datatypes/struct.SchemaBuilder.html          |  24 +-
 arrow/datatypes/struct.Time32MillisecondType.html  |  12 +-
 arrow/datatypes/struct.Time32SecondType.html       |  12 +-
 arrow/datatypes/struct.Time64MicrosecondType.html  |  12 +-
 arrow/datatypes/struct.Time64NanosecondType.html   |  12 +-
 .../datatypes/struct.TimestampMicrosecondType.html |  24 +-
 .../datatypes/struct.TimestampMillisecondType.html |  24 +-
 .../datatypes/struct.TimestampNanosecondType.html  |  24 +-
 arrow/datatypes/struct.TimestampSecondType.html    |  24 +-
 arrow/datatypes/struct.UInt16Type.html             |  12 +-
 arrow/datatypes/struct.UInt32Type.html             |  12 +-
 arrow/datatypes/struct.UInt64Type.html             |  12 +-
 arrow/datatypes/struct.UInt8Type.html              |  12 +-
 arrow/datatypes/struct.UnionFields.html            |  12 +-
 arrow/datatypes/struct.i256.html                   |  20 +-
 arrow/datatypes/trait.ArrowDictionaryKeyType.html  |   2 +-
 arrow/datatypes/trait.ArrowNativeType.html         |   8 +-
 arrow/datatypes/trait.ArrowNativeTypeOp.html       |   2 +-
 arrow/datatypes/trait.ArrowNumericType.html        |   2 +-
 arrow/datatypes/trait.ArrowPrimitiveType.html      |   2 +-
 arrow/datatypes/trait.ArrowTemporalType.html       |   2 +-
 arrow/datatypes/trait.ArrowTimestampType.html      |   2 +-
 arrow/datatypes/trait.ByteArrayType.html           |   2 +-
 arrow/datatypes/trait.DecimalType.html             |   2 +-
 arrow/datatypes/trait.RunEndIndexType.html         |   2 +-
 arrow/datatypes/trait.ToByteSlice.html             |   2 +-
 arrow/datatypes/type.BinaryType.html               |   2 +-
 arrow/datatypes/type.FieldRef.html                 |   2 +-
 arrow/datatypes/type.LargeBinaryType.html          |   2 +-
 arrow/datatypes/type.LargeUtf8Type.html            |   2 +-
 arrow/datatypes/type.SchemaRef.html                |   2 +-
 arrow/datatypes/type.Utf8Type.html                 |   2 +-
 arrow/error/enum.ArrowError.html                   |  16 +-
 arrow/error/index.html                             |   4 +-
 arrow/error/type.Result.html                       |   2 +-
 arrow/ffi/fn.bit_width.html                        |   2 +-
 arrow/ffi/fn.create_buffer.html                    |   6 +-
 arrow/ffi/fn.from_ffi.html                         |   4 +-
 arrow/ffi/fn.from_ffi_and_data_type.html           |   4 +-
 arrow/ffi/fn.to_ffi.html                           |   2 +-
 arrow/ffi/index.html                               |   6 +-
 arrow/ffi/struct.FFI_ArrowArray.html               |  16 +-
 arrow/ffi/struct.FFI_ArrowSchema.html              |  22 +-
 arrow/ffi/struct.Flags.html                        |  26 +-
 arrow/ffi/struct.ImportedArrowArray.html           |  12 +-
 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    |   4 +-
 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                        |   6 +-
 .../ffi_stream/struct.ArrowArrayStreamReader.html  |  16 +-
 arrow/ffi_stream/struct.ExportedArrayStream.html   |  12 +-
 arrow/ffi_stream/struct.FFI_ArrowArrayStream.html  |  14 +-
 arrow/ffi_stream/struct.StreamPrivateData.html     |  12 +-
 arrow/index.html                                   |  24 +-
 arrow/macro.downcast_dictionary_array.html         |   2 +-
 arrow/macro.downcast_primitive_array.html          |   2 +-
 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                           |   6 +-
 arrow/pyarrow/struct.ArrowException.html           |  50 +-
 arrow/pyarrow/struct.PyArrowType.html              |  12 +-
 arrow/pyarrow/trait.FromPyArrow.html               |   2 +-
 arrow/pyarrow/trait.IntoPyArrow.html               |   2 +-
 arrow/pyarrow/trait.ToPyArrow.html                 |   2 +-
 arrow/pyarrow/type.PyArrowException.html           |   2 +-
 arrow/record_batch/index.html                      |   6 +-
 arrow/record_batch/struct.RecordBatch.html         |  30 +-
 arrow/record_batch/struct.RecordBatchIterator.html |  16 +-
 arrow/record_batch/struct.RecordBatchOptions.html  |  12 +-
 arrow/record_batch/trait.RecordBatchReader.html    |   2 +-
 arrow/record_batch/trait.RecordBatchWriter.html    |   2 +-
 .../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/temporal_conversions/fn.as_date.html         |   2 +-
 arrow/temporal_conversions/fn.as_datetime.html     |   2 +-
 .../fn.as_datetime_with_timezone.html              |   2 +-
 arrow/temporal_conversions/fn.as_duration.html     |   2 +-
 arrow/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.time32ms_to_time.html  |   2 +-
 arrow/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 +-
 arrow/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/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                            |   4 +-
 arrow/tensor/struct.Tensor.html                    |  12 +-
 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                   |   4 +-
 arrow/util/bit_chunk_iterator/index.html           |   4 +-
 .../struct.BitChunkIterator.html                   |  14 +-
 .../util/bit_chunk_iterator/struct.BitChunks.html  |  12 +-
 .../struct.UnalignedBitChunk.html                  |  12 +-
 .../type.UnalignedBitChunkIterator.html            |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 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               |   2 +-
 arrow/util/bit_mask/index.html                     |   4 +-
 arrow/util/bit_util/fn.ceil.html                   |   2 +-
 arrow/util/bit_util/fn.get_bit.html                |   2 +-
 arrow/util/bit_util/fn.get_bit_raw.html            |   4 +-
 .../bit_util/fn.round_upto_multiple_of_64.html     |   2 +-
 arrow/util/bit_util/fn.round_upto_power_of_2.html  |   2 +-
 arrow/util/bit_util/fn.set_bit.html                |   2 +-
 arrow/util/bit_util/fn.set_bit_raw.html            |   4 +-
 arrow/util/bit_util/fn.unset_bit.html              |   2 +-
 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                     |   4 +-
 arrow/util/display/enum.DurationFormat.html        |  12 +-
 arrow/util/display/fn.array_value_to_string.html   |   2 +-
 arrow/util/display/fn.lexical_to_string.html       |   2 +-
 arrow/util/display/index.html                      |   4 +-
 arrow/util/display/struct.ArrayFormatter.html      |  12 +-
 arrow/util/display/struct.FormatOptions.html       |  12 +-
 arrow/util/display/struct.ValueFormatter.html      |  12 +-
 arrow/util/index.html                              |   4 +-
 arrow/util/pretty/fn.pretty_format_batches.html    |   2 +-
 .../fn.pretty_format_batches_with_options.html     |   2 +-
 arrow/util/pretty/fn.pretty_format_columns.html    |   2 +-
 .../fn.pretty_format_columns_with_options.html     |   2 +-
 arrow/util/pretty/fn.print_batches.html            |   2 +-
 arrow/util/pretty/fn.print_columns.html            |   2 +-
 arrow/util/pretty/index.html                       |   4 +-
 arrow/util/string_writer/index.html                |   4 +-
 arrow/util/string_writer/struct.StringWriter.html  |  12 +-
 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                    |   4 +-
 arrow/util/test_util/struct.BadIterator.html       |  14 +-
 .../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                   |   6 +-
 arrow_arith/aggregate/macro.bit_operation.html     |   2 +-
 arrow_arith/aggregate/struct.MaxAccumulator.html   |  12 +-
 arrow_arith/aggregate/struct.MinAccumulator.html   |  12 +-
 arrow_arith/aggregate/struct.SumAccumulator.html   |  12 +-
 .../aggregate/trait.NumericAccumulator.html        |   2 +-
 arrow_arith/all.html                               |   2 +-
 arrow_arith/arity/fn.binary.html                   |   4 +-
 arrow_arith/arity/fn.binary_mut.html               |   4 +-
 arrow_arith/arity/fn.try_binary.html               |   4 +-
 arrow_arith/arity/fn.try_binary_mut.html           |   4 +-
 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                       |   4 +-
 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                     |   4 +-
 arrow_arith/boolean/fn.and.html                    |   6 +-
 arrow_arith/boolean/fn.and_kleene.html             |   8 +-
 arrow_arith/boolean/fn.and_not.html                |   6 +-
 arrow_arith/boolean/fn.binary_boolean_kernel.html  |   2 +-
 arrow_arith/boolean/fn.is_not_null.html            |   6 +-
 arrow_arith/boolean/fn.is_null.html                |   6 +-
 arrow_arith/boolean/fn.not.html                    |   6 +-
 arrow_arith/boolean/fn.or.html                     |   6 +-
 arrow_arith/boolean/fn.or_kleene.html              |   8 +-
 arrow_arith/boolean/index.html                     |   4 +-
 arrow_arith/index.html                             |   4 +-
 arrow_arith/numeric/enum.Op.html                   |  14 +-
 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                     |   4 +-
 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/fn.as_datetime_with_op.html   |   2 +-
 arrow_arith/temporal/fn.as_time_with_op.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 +-
 .../fn.extract_component_from_datetime_array.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 +-
 arrow_arith/temporal/fn.time_fraction_dyn.html     |   2 +-
 .../temporal/fn.time_fraction_internal.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                    |   4 +-
 .../temporal/macro.return_compute_error_with.html  |   2 +-
 arrow_arith/temporal/trait.ChronoDateExt.html      |   2 +-
 arrow_array/all.html                               |   2 +-
 arrow_array/arithmetic/index.html                  |   4 +-
 .../arithmetic/macro.native_type_float_op.html     |   2 +-
 arrow_array/arithmetic/macro.native_type_op.html   |   2 +-
 .../arithmetic/trait.ArrowNativeTypeOp.html        |   2 +-
 arrow_array/array/binary_array/index.html          |   4 +-
 .../array/binary_array/type.BinaryArray.html       |   4 +-
 .../binary_array/type.GenericBinaryArray.html      |   6 +-
 .../array/binary_array/type.LargeBinaryArray.html  |   4 +-
 arrow_array/array/boolean_array/index.html         |   4 +-
 .../array/boolean_array/struct.BooleanArray.html   |  32 +-
 arrow_array/array/byte_array/index.html            |   4 +-
 .../array/byte_array/struct.GenericByteArray.html  |  40 +-
 arrow_array/array/dictionary_array/index.html      |   4 +-
 .../dictionary_array/struct.DictionaryArray.html   |  38 +-
 .../struct.TypedDictionaryArray.html               |  12 +-
 .../dictionary_array/trait.AnyDictionaryArray.html |   4 +-
 .../type.Int16DictionaryArray.html                 |   4 +-
 .../type.Int32DictionaryArray.html                 |   4 +-
 .../type.Int64DictionaryArray.html                 |   4 +-
 .../dictionary_array/type.Int8DictionaryArray.html |   4 +-
 .../type.UInt16DictionaryArray.html                |   4 +-
 .../type.UInt32DictionaryArray.html                |   4 +-
 .../type.UInt64DictionaryArray.html                |   4 +-
 .../type.UInt8DictionaryArray.html                 |   4 +-
 .../array/fixed_size_binary_array/index.html       |   4 +-
 .../struct.FixedSizeBinaryArray.html               |  40 +-
 arrow_array/array/fixed_size_list_array/index.html |   4 +-
 .../struct.FixedSizeListArray.html                 |  28 +-
 arrow_array/array/fn.get_offsets.html              |   4 +-
 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                       |   8 +-
 arrow_array/array/list_array/index.html            |   6 +-
 .../array/list_array/struct.GenericListArray.html  |  24 +-
 .../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             |   4 +-
 arrow_array/array/map_array/struct.MapArray.html   |  20 +-
 arrow_array/array/null_array/index.html            |   4 +-
 arrow_array/array/null_array/struct.NullArray.html |  16 +-
 arrow_array/array/primitive_array/index.html       |   4 +-
 .../macro.def_from_for_primitive.html              |   2 +-
 .../macro.def_numeric_from_vec.html                |   2 +-
 .../primitive_array/struct.NativeAdapter.html      |  14 +-
 .../primitive_array/struct.PrimitiveArray.html     | 102 +--
 .../array/primitive_array/type.Date32Array.html    |   2 +-
 .../array/primitive_array/type.Date64Array.html    |   2 +-
 .../primitive_array/type.Decimal128Array.html      |   4 +-
 .../primitive_array/type.Decimal256Array.html      |   4 +-
 .../type.DurationMicrosecondArray.html             |   2 +-
 .../type.DurationMillisecondArray.html             |   2 +-
 .../type.DurationNanosecondArray.html              |   2 +-
 .../primitive_array/type.DurationSecondArray.html  |   2 +-
 .../array/primitive_array/type.Float16Array.html   |   6 +-
 .../array/primitive_array/type.Float32Array.html   |   4 +-
 .../array/primitive_array/type.Float64Array.html   |   4 +-
 .../array/primitive_array/type.Int16Array.html     |   4 +-
 .../array/primitive_array/type.Int32Array.html     |   4 +-
 .../array/primitive_array/type.Int64Array.html     |   4 +-
 .../array/primitive_array/type.Int8Array.html      |   4 +-
 .../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 |   8 +-
 .../array/primitive_array/type.UInt16Array.html    |   4 +-
 .../array/primitive_array/type.UInt32Array.html    |   4 +-
 .../array/primitive_array/type.UInt64Array.html    |   4 +-
 .../array/primitive_array/type.UInt8Array.html     |   4 +-
 arrow_array/array/run_array/index.html             |   4 +-
 arrow_array/array/run_array/struct.RunArray.html   |  18 +-
 .../array/run_array/struct.TypedRunArray.html      |  16 +-
 .../array/run_array/type.Int16RunArray.html        |   4 +-
 .../array/run_array/type.Int32RunArray.html        |   4 +-
 .../array/run_array/type.Int64RunArray.html        |   4 +-
 arrow_array/array/string_array/index.html          |   4 +-
 .../string_array/type.GenericStringArray.html      |   8 +-
 .../array/string_array/type.LargeStringArray.html  |   4 +-
 .../array/string_array/type.StringArray.html       |   4 +-
 arrow_array/array/struct.BooleanArray.html         |  32 +-
 arrow_array/array/struct.DictionaryArray.html      |  38 +-
 arrow_array/array/struct.FixedSizeBinaryArray.html |  40 +-
 arrow_array/array/struct.FixedSizeListArray.html   |  28 +-
 arrow_array/array/struct.GenericByteArray.html     |  40 +-
 arrow_array/array/struct.GenericListArray.html     |  24 +-
 arrow_array/array/struct.MapArray.html             |  20 +-
 arrow_array/array/struct.NativeAdapter.html        |  14 +-
 arrow_array/array/struct.NullArray.html            |  16 +-
 arrow_array/array/struct.PrimitiveArray.html       | 102 +--
 arrow_array/array/struct.RunArray.html             |  18 +-
 arrow_array/array/struct.StructArray.html          |  28 +-
 arrow_array/array/struct.TypedDictionaryArray.html |  12 +-
 arrow_array/array/struct.TypedRunArray.html        |  16 +-
 arrow_array/array/struct.UnionArray.html           |  28 +-
 arrow_array/array/struct_array/index.html          |   4 +-
 .../array/struct_array/struct.StructArray.html     |  28 +-
 arrow_array/array/trait.AnyDictionaryArray.html    |   4 +-
 arrow_array/array/trait.Array.html                 |  26 +-
 arrow_array/array/trait.ArrayAccessor.html         |   8 +-
 arrow_array/array/trait.OffsetSizeTrait.html       |   2 +-
 arrow_array/array/type.ArrayRef.html               |   2 +-
 arrow_array/array/type.BinaryArray.html            |   4 +-
 arrow_array/array/type.Date32Array.html            |   2 +-
 arrow_array/array/type.Date64Array.html            |   2 +-
 arrow_array/array/type.Decimal128Array.html        |   4 +-
 arrow_array/array/type.Decimal256Array.html        |   4 +-
 .../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           |   6 +-
 arrow_array/array/type.Float32Array.html           |   4 +-
 arrow_array/array/type.Float64Array.html           |   4 +-
 arrow_array/array/type.GenericBinaryArray.html     |   6 +-
 arrow_array/array/type.GenericStringArray.html     |   8 +-
 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   |   2 +-
 .../array/type.IntervalMonthDayNanoArray.html      |   2 +-
 arrow_array/array/type.IntervalYearMonthArray.html |   2 +-
 arrow_array/array/type.LargeBinaryArray.html       |   4 +-
 arrow_array/array/type.LargeListArray.html         |   2 +-
 arrow_array/array/type.LargeStringArray.html       |   4 +-
 arrow_array/array/type.ListArray.html              |   2 +-
 arrow_array/array/type.StringArray.html            |   4 +-
 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   |   8 +-
 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/array/union_array/index.html           |   4 +-
 .../array/union_array/struct.UnionArray.html       |  28 +-
 arrow_array/builder/boolean_builder/index.html     |   4 +-
 .../boolean_builder/struct.BooleanBuilder.html     |  14 +-
 arrow_array/builder/buffer_builder/index.html      |   4 +-
 .../buffer_builder/struct.BufferBuilder.html       |  40 +-
 .../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   |   4 +-
 .../struct.FixedSizeBinaryBuilder.html             |  12 +-
 .../builder/fixed_size_list_builder/index.html     |   4 +-
 .../struct.FixedSizeListBuilder.html               |  12 +-
 arrow_array/builder/fn.make_builder.html           |   2 +-
 .../builder/generic_byte_run_builder/index.html    |   4 +-
 .../struct.GenericByteRunBuilder.html              |  14 +-
 .../type.BinaryRunBuilder.html                     |   2 +-
 .../type.LargeBinaryRunBuilder.html                |   2 +-
 .../type.LargeStringRunBuilder.html                |   2 +-
 .../type.StringRunBuilder.html                     |   2 +-
 .../builder/generic_bytes_builder/index.html       |   4 +-
 .../struct.GenericByteBuilder.html                 |  16 +-
 .../type.GenericBinaryBuilder.html                 |   2 +-
 .../type.GenericStringBuilder.html                 |   2 +-
 .../fn.get_bytes.html                              |   2 +-
 .../generic_bytes_dictionary_builder/index.html    |   4 +-
 .../struct.GenericByteDictionaryBuilder.html       |  18 +-
 .../type.BinaryDictionaryBuilder.html              |   2 +-
 .../type.LargeBinaryDictionaryBuilder.html         |   2 +-
 .../type.LargeStringDictionaryBuilder.html         |   2 +-
 .../type.StringDictionaryBuilder.html              |   2 +-
 .../builder/generic_list_builder/index.html        |   4 +-
 .../struct.GenericListBuilder.html                 |  18 +-
 arrow_array/builder/index.html                     |  12 +-
 arrow_array/builder/map_builder/index.html         |   4 +-
 .../builder/map_builder/struct.MapBuilder.html     |  12 +-
 .../builder/map_builder/struct.MapFieldNames.html  |  12 +-
 arrow_array/builder/null_builder/index.html        |   4 +-
 .../builder/null_builder/struct.NullBuilder.html   |  14 +-
 arrow_array/builder/primitive_builder/index.html   |   4 +-
 .../primitive_builder/struct.PrimitiveBuilder.html |  18 +-
 .../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        |   4 +-
 .../struct.PrimitiveDictionaryBuilder.html         |  22 +-
 .../primitive_dictionary_builder/struct.Value.html |  12 +-
 .../builder/primitive_run_builder/index.html       |   4 +-
 .../struct.PrimitiveRunBuilder.html                |  14 +-
 .../builder/struct.BooleanBufferBuilder.html       |  14 +-
 arrow_array/builder/struct.BooleanBuilder.html     |  14 +-
 arrow_array/builder/struct.BufferBuilder.html      |  40 +-
 .../builder/struct.FixedSizeBinaryBuilder.html     |  12 +-
 .../builder/struct.FixedSizeListBuilder.html       |  12 +-
 arrow_array/builder/struct.GenericByteBuilder.html |  16 +-
 .../struct.GenericByteDictionaryBuilder.html       |  18 +-
 .../builder/struct.GenericByteRunBuilder.html      |  14 +-
 arrow_array/builder/struct.GenericListBuilder.html |  18 +-
 arrow_array/builder/struct.MapBuilder.html         |  12 +-
 arrow_array/builder/struct.MapFieldNames.html      |  12 +-
 arrow_array/builder/struct.NullBuilder.html        |  14 +-
 arrow_array/builder/struct.PrimitiveBuilder.html   |  18 +-
 .../builder/struct.PrimitiveDictionaryBuilder.html |  22 +-
 .../builder/struct.PrimitiveRunBuilder.html        |  14 +-
 arrow_array/builder/struct.StructBuilder.html      |  12 +-
 arrow_array/builder/struct.UnionBuilder.html       |  12 +-
 .../builder/struct_builder/fn.make_builder.html    |   2 +-
 arrow_array/builder/struct_builder/index.html      |   4 +-
 .../struct_builder/struct.StructBuilder.html       |  12 +-
 arrow_array/builder/trait.ArrayBuilder.html        |   4 +-
 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       |   4 +-
 .../builder/union_builder/struct.FieldData.html    |  12 +-
 .../builder/union_builder/struct.UnionBuilder.html |  12 +-
 .../union_builder/trait.FieldDataValues.html       |   2 +-
 arrow_array/cast/fn.as_boolean_array.html          |   4 +-
 arrow_array/cast/fn.as_decimal_array.html          |   2 +-
 arrow_array/cast/fn.as_dictionary_array.html       |   4 +-
 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        |   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           |   2 +-
 arrow_array/cast/fn.as_union_array.html            |   2 +-
 arrow_array/cast/fn.downcast_array.html            |   4 +-
 arrow_array/cast/index.html                        |   4 +-
 arrow_array/cast/macro.array_downcast_fn.html      |   2 +-
 arrow_array/cast/private/index.html                |   4 +-
 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                       |   4 +-
 arrow_array/index.html                             |  18 +-
 arrow_array/iterator/index.html                    |   4 +-
 arrow_array/iterator/struct.ArrayIter.html         |  16 +-
 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                     |   4 +-
 arrow_array/numeric/trait.ArrowNumericType.html    |   2 +-
 arrow_array/record_batch/index.html                |   6 +-
 arrow_array/record_batch/struct.RecordBatch.html   |  30 +-
 .../record_batch/struct.RecordBatchIterator.html   |  16 +-
 .../record_batch/struct.RecordBatchOptions.html    |  12 +-
 .../record_batch/trait.RecordBatchReader.html      |   2 +-
 .../record_batch/trait.RecordBatchWriter.html      |   2 +-
 arrow_array/run_iterator/index.html                |   4 +-
 arrow_array/run_iterator/struct.RunArrayIter.html  |  14 +-
 arrow_array/scalar/index.html                      |   6 +-
 arrow_array/scalar/struct.Scalar.html              |  16 +-
 arrow_array/scalar/trait.Datum.html                |   2 +-
 arrow_array/struct.RecordBatch.html                |  30 +-
 arrow_array/struct.RecordBatchIterator.html        |  16 +-
 arrow_array/struct.RecordBatchOptions.html         |  12 +-
 arrow_array/struct.Scalar.html                     |  16 +-
 .../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        |   4 +-
 arrow_array/timezone/fn.parse_fixed_offset.html    |   2 +-
 arrow_array/timezone/index.html                    |   4 +-
 arrow_array/timezone/private/enum.TzInner.html     |  12 +-
 arrow_array/timezone/private/index.html            |   4 +-
 arrow_array/timezone/private/macro.tz.html         |   2 +-
 arrow_array/timezone/private/struct.Tz.html        |  12 +-
 arrow_array/timezone/private/struct.TzOffset.html  |  12 +-
 arrow_array/timezone/struct.Tz.html                |  12 +-
 arrow_array/timezone/struct.TzOffset.html          |  12 +-
 arrow_array/trait.ArrowNativeTypeOp.html           |   2 +-
 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  |   4 +-
 arrow_array/trusted_len/index.html                 |   4 +-
 arrow_array/types/bytes/index.html                 |   4 +-
 .../types/bytes/trait.ByteArrayNativeType.html     |   4 +-
 .../types/bytes/trait.ByteArrayTypeSealed.html     |   2 +-
 arrow_array/types/decimal/index.html               |   4 +-
 .../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                       |   6 +-
 arrow_array/types/macro.make_type.html             |   2 +-
 arrow_array/types/primitive/index.html             |   4 +-
 .../types/primitive/trait.PrimitiveTypeSealed.html |   2 +-
 arrow_array/types/struct.BooleanType.html          |  12 +-
 arrow_array/types/struct.Date32Type.html           |  28 +-
 arrow_array/types/struct.Date64Type.html           |  28 +-
 arrow_array/types/struct.Decimal128Type.html       |  12 +-
 arrow_array/types/struct.Decimal256Type.html       |  12 +-
 .../types/struct.DurationMicrosecondType.html      |  12 +-
 .../types/struct.DurationMillisecondType.html      |  12 +-
 .../types/struct.DurationNanosecondType.html       |  12 +-
 arrow_array/types/struct.DurationSecondType.html   |  12 +-
 arrow_array/types/struct.Float16Type.html          |  12 +-
 arrow_array/types/struct.Float32Type.html          |  12 +-
 arrow_array/types/struct.Float64Type.html          |  12 +-
 arrow_array/types/struct.GenericBinaryType.html    |  12 +-
 arrow_array/types/struct.GenericStringType.html    |  12 +-
 arrow_array/types/struct.Int16Type.html            |  12 +-
 arrow_array/types/struct.Int32Type.html            |  12 +-
 arrow_array/types/struct.Int64Type.html            |  12 +-
 arrow_array/types/struct.Int8Type.html             |  12 +-
 arrow_array/types/struct.IntervalDayTimeType.html  |  20 +-
 .../types/struct.IntervalMonthDayNanoType.html     |  20 +-
 .../types/struct.IntervalYearMonthType.html        |  16 +-
 .../types/struct.Time32MillisecondType.html        |  12 +-
 arrow_array/types/struct.Time32SecondType.html     |  12 +-
 .../types/struct.Time64MicrosecondType.html        |  12 +-
 arrow_array/types/struct.Time64NanosecondType.html |  12 +-
 .../types/struct.TimestampMicrosecondType.html     |  24 +-
 .../types/struct.TimestampMillisecondType.html     |  24 +-
 .../types/struct.TimestampNanosecondType.html      |  24 +-
 arrow_array/types/struct.TimestampSecondType.html  |  24 +-
 arrow_array/types/struct.UInt16Type.html           |  12 +-
 arrow_array/types/struct.UInt32Type.html           |  12 +-
 arrow_array/types/struct.UInt64Type.html           |  12 +-
 arrow_array/types/struct.UInt8Type.html            |  12 +-
 .../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                   |  12 +-
 arrow_avro/codec/enum.Nulls.html                   |  12 +-
 arrow_avro/codec/fn.make_data_type.html            |   2 +-
 arrow_avro/codec/index.html                        |   6 +-
 arrow_avro/codec/struct.AvroDataType.html          |  12 +-
 arrow_avro/codec/struct.AvroField.html             |  12 +-
 arrow_avro/codec/struct.Resolver.html              |  12 +-
 .../compression/constant.CODEC_METADATA_KEY.html   |   2 +-
 arrow_avro/compression/enum.CompressionCodec.html  |  12 +-
 arrow_avro/compression/index.html                  |   4 +-
 arrow_avro/index.html                              |   4 +-
 .../reader/block/enum.BlockDecoderState.html       |  12 +-
 arrow_avro/reader/block/index.html                 |   4 +-
 arrow_avro/reader/block/struct.Block.html          |  12 +-
 arrow_avro/reader/block/struct.BlockDecoder.html   |  12 +-
 arrow_avro/reader/fn.read_blocks.html              |   2 +-
 arrow_avro/reader/fn.read_header.html              |   2 +-
 arrow_avro/reader/header/constant.MAGIC.html       |   2 +-
 .../reader/header/enum.HeaderDecoderState.html     |  12 +-
 arrow_avro/reader/header/index.html                |   4 +-
 arrow_avro/reader/header/struct.Header.html        |  12 +-
 arrow_avro/reader/header/struct.HeaderDecoder.html |  12 +-
 arrow_avro/reader/index.html                       |   4 +-
 arrow_avro/reader/vlq/index.html                   |   4 +-
 arrow_avro/reader/vlq/struct.VLQDecoder.html       |  12 +-
 .../schema/constant.SCHEMA_METADATA_KEY.html       |   2 +-
 arrow_avro/schema/enum.ComplexType.html            |  12 +-
 arrow_avro/schema/enum.PrimitiveType.html          |  12 +-
 arrow_avro/schema/enum.Schema.html                 |  12 +-
 arrow_avro/schema/enum.TypeName.html               |  12 +-
 arrow_avro/schema/index.html                       |   4 +-
 arrow_avro/schema/struct.Array.html                |  12 +-
 arrow_avro/schema/struct.Attributes.html           |  12 +-
 arrow_avro/schema/struct.Enum.html                 |  12 +-
 arrow_avro/schema/struct.Field.html                |  12 +-
 arrow_avro/schema/struct.Fixed.html                |  12 +-
 arrow_avro/schema/struct.Map.html                  |  12 +-
 arrow_avro/schema/struct.Record.html               |  12 +-
 arrow_avro/schema/struct.Type.html                 |  12 +-
 arrow_buffer/all.html                              |   2 +-
 .../alloc/alignment/constant.ALIGNMENT.html        |   2 +-
 arrow_buffer/alloc/alignment/index.html            |   4 +-
 arrow_buffer/alloc/constant.ALIGNMENT.html         |   2 +-
 arrow_buffer/alloc/enum.Deallocation.html          |  12 +-
 arrow_buffer/alloc/index.html                      |   4 +-
 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            |   4 +-
 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                 |   4 +-
 arrow_buffer/bigint/div/struct.ArrayPlusOne.html   | 865 +++++++++-----------
 arrow_buffer/bigint/enum.DivRemError.html          |  12 +-
 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                     |   4 +-
 arrow_buffer/bigint/macro.define_as_primitive.html |   2 +-
 arrow_buffer/bigint/macro.derive_op.html           |   2 +-
 arrow_buffer/bigint/struct.ParseI256Error.html     |  14 +-
 arrow_buffer/bigint/struct.i256.html               |  18 +-
 arrow_buffer/bit_chunk_iterator/index.html         |   4 +-
 .../struct.BitChunkIterator.html                   |  14 +-
 .../bit_chunk_iterator/struct.BitChunks.html       |  12 +-
 .../struct.UnalignedBitChunk.html                  |  12 +-
 .../type.UnalignedBitChunkIterator.html            |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 arrow_buffer/bit_iterator/index.html               |   4 +-
 .../bit_iterator/struct.BitIndexIterator.html      |  14 +-
 arrow_buffer/bit_iterator/struct.BitIterator.html  |  16 +-
 .../bit_iterator/struct.BitSliceIterator.html      |  14 +-
 arrow_buffer/bit_mask/fn.set_bits.html             |   2 +-
 arrow_buffer/bit_mask/index.html                   |   4 +-
 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          |   4 +-
 .../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          |   4 +-
 arrow_buffer/bit_util/fn.unset_bit.html            |   2 +-
 arrow_buffer/bit_util/fn.unset_bit_raw.html        |   4 +-
 arrow_buffer/bit_util/index.html                   |   4 +-
 arrow_buffer/buffer/boolean/index.html             |   4 +-
 .../buffer/boolean/struct.BooleanBuffer.html       |  22 +-
 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           |   4 +-
 arrow_buffer/buffer/immutable/struct.Buffer.html   | 436 +++++-----
 arrow_buffer/buffer/index.html                     |   6 +-
 arrow_buffer/buffer/mutable/fn.dangling_ptr.html   |   2 +-
 arrow_buffer/buffer/mutable/index.html             |   4 +-
 .../buffer/mutable/struct.MutableBuffer.html       | 899 ++++++++++----------
 .../buffer/mutable/struct.SetLenOnDrop.html        |  12 +-
 arrow_buffer/buffer/null/index.html                |   4 +-
 arrow_buffer/buffer/null/struct.NullBuffer.html    |  16 +-
 arrow_buffer/buffer/offset/index.html              |   4 +-
 .../buffer/offset/struct.OffsetBuffer.html         | 418 +++++-----
 .../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                 |   4 +-
 arrow_buffer/buffer/run/index.html                 |   4 +-
 arrow_buffer/buffer/run/struct.RunEndBuffer.html   |  20 +-
 arrow_buffer/buffer/scalar/index.html              |   4 +-
 .../buffer/scalar/struct.ScalarBuffer.html         | 422 +++++-----
 arrow_buffer/buffer/struct.BooleanBuffer.html      |  22 +-
 arrow_buffer/buffer/struct.Buffer.html             | 436 +++++-----
 arrow_buffer/buffer/struct.MutableBuffer.html      | 899 ++++++++++----------
 arrow_buffer/buffer/struct.NullBuffer.html         |  16 +-
 arrow_buffer/buffer/struct.OffsetBuffer.html       | 418 +++++-----
 arrow_buffer/buffer/struct.RunEndBuffer.html       |  20 +-
 arrow_buffer/buffer/struct.ScalarBuffer.html       | 422 +++++-----
 arrow_buffer/builder/boolean/index.html            |   4 +-
 .../boolean/struct.BooleanBufferBuilder.html       |  14 +-
 arrow_buffer/builder/index.html                    |   4 +-
 arrow_buffer/builder/null/index.html               |   4 +-
 .../builder/null/struct.NullBufferBuilder.html     |  12 +-
 .../builder/struct.BooleanBufferBuilder.html       |  14 +-
 arrow_buffer/builder/struct.BufferBuilder.html     |  42 +-
 arrow_buffer/builder/struct.NullBufferBuilder.html |  12 +-
 arrow_buffer/bytes/index.html                      |   4 +-
 arrow_buffer/bytes/struct.Bytes.html               | 414 +++++-----
 arrow_buffer/index.html                            |   6 +-
 arrow_buffer/native/index.html                     |   4 +-
 arrow_buffer/native/macro.native_float.html        |   2 +-
 arrow_buffer/native/macro.native_integer.html      |   2 +-
 arrow_buffer/native/private/index.html             |   4 +-
 arrow_buffer/native/private/trait.Sealed.html      |   2 +-
 arrow_buffer/native/trait.ArrowNativeType.html     |   6 +-
 arrow_buffer/native/trait.ToByteSlice.html         |   2 +-
 arrow_buffer/struct.i256.html                      |  18 +-
 arrow_buffer/trait.ArrowNativeType.html            |   6 +-
 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    |   4 +-
 .../struct.BitChunkIterator.html                   |  14 +-
 .../util/bit_chunk_iterator/struct.BitChunks.html  |  12 +-
 .../struct.UnalignedBitChunk.html                  |  12 +-
 .../type.UnalignedBitChunkIterator.html            |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 arrow_buffer/util/bit_iterator/index.html          |   4 +-
 .../util/bit_iterator/struct.BitIndexIterator.html |  14 +-
 .../util/bit_iterator/struct.BitIterator.html      |  16 +-
 .../util/bit_iterator/struct.BitSliceIterator.html |  14 +-
 arrow_buffer/util/bit_mask/fn.set_bits.html        |   2 +-
 arrow_buffer/util/bit_mask/index.html              |   4 +-
 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     |   4 +-
 .../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     |   4 +-
 arrow_buffer/util/bit_util/fn.unset_bit.html       |   2 +-
 arrow_buffer/util/bit_util/fn.unset_bit_raw.html   |   4 +-
 arrow_buffer/util/bit_util/index.html              |   4 +-
 arrow_buffer/util/index.html                       |   4 +-
 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                       |   4 +-
 arrow_cast/base64/trait.Engine.html                |  14 +-
 .../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 +-
 arrow_cast/cast/fn.cast_values_to_list.html        |   2 +-
 arrow_cast/cast/fn.cast_with_options.html          |   4 +-
 ...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                         |   6 +-
 arrow_cast/cast/struct.CastOptions.html            |  12 +-
 arrow_cast/cast/trait.DecimalCast.html             |   2 +-
 arrow_cast/display/enum.DurationFormat.html        |  12 +-
 arrow_cast/display/enum.FormatError.html           |  14 +-
 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                      |   4 +-
 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 +-
 arrow_cast/display/macro.temporal_display.html     |   2 +-
 arrow_cast/display/macro.timestamp_display.html    |   2 +-
 arrow_cast/display/struct.ArrayFormat.html         |  12 +-
 arrow_cast/display/struct.ArrayFormatter.html      |  12 +-
 arrow_cast/display/struct.FormatOptions.html       |  12 +-
 arrow_cast/display/struct.ValueFormatter.html      |  12 +-
 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                              |   4 +-
 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            |  12 +-
 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       |   4 +-
 arrow_cast/parse/fn.string_to_timestamp_nanos.html |   6 +-
 arrow_cast/parse/fn.to_timestamp_nanos.html        |   2 +-
 arrow_cast/parse/index.html                        |   8 +-
 arrow_cast/parse/macro.parser_primitive.html       |   2 +-
 arrow_cast/parse/struct.Interval.html              |  12 +-
 arrow_cast/parse/struct.IntervalAmount.html        |  12 +-
 arrow_cast/parse/struct.IntervalParseConfig.html   |  12 +-
 arrow_cast/parse/struct.TimestampParser.html       |  12 +-
 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                       |   4 +-
 arrow_csv/all.html                                 |   2 +-
 arrow_csv/fn.map_csv_error.html                    |   2 +-
 arrow_csv/index.html                               |   4 +-
 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                        |  10 +-
 .../records/constant.AVERAGE_FIELD_SIZE.html       |   2 +-
 .../reader/records/constant.MIN_CAPACITY.html      |   2 +-
 arrow_csv/reader/records/index.html                |   4 +-
 arrow_csv/reader/records/struct.RecordDecoder.html |  12 +-
 arrow_csv/reader/records/struct.StringRecord.html  |  12 +-
 arrow_csv/reader/records/struct.StringRecords.html |  12 +-
 arrow_csv/reader/struct.BufReader.html             |  14 +-
 arrow_csv/reader/struct.Decoder.html               |  12 +-
 arrow_csv/reader/struct.Format.html                |  12 +-
 arrow_csv/reader/struct.InferredDataType.html      |  12 +-
 arrow_csv/reader/struct.NullRegex.html             |  12 +-
 arrow_csv/reader/struct.REGEX_SET.html             |  30 +-
 arrow_csv/reader/struct.ReaderBuilder.html         |  14 +-
 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                        |   4 +-
 arrow_csv/writer/struct.Writer.html                |  12 +-
 arrow_csv/writer/struct.WriterBuilder.html         |  14 +-
 arrow_data/all.html                                |   2 +-
 .../bit_iterator/fn.try_for_each_valid_idx.html    |   2 +-
 arrow_data/bit_iterator/index.html                 |   4 +-
 .../bit_iterator/struct.BitIndexIterator.html      |  14 +-
 arrow_data/bit_iterator/struct.BitIterator.html    |  16 +-
 .../bit_iterator/struct.BitSliceIterator.html      |  14 +-
 arrow_data/bit_mask/fn.set_bits.html               |   2 +-
 arrow_data/bit_mask/index.html                     |   4 +-
 arrow_data/data/enum.BufferSpec.html               |  12 +-
 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                         |   8 +-
 arrow_data/data/struct.ArrayData.html              |  20 +-
 arrow_data/data/struct.ArrayDataBuilder.html       |  14 +-
 arrow_data/data/struct.DataTypeLayout.html         |  12 +-
 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                      |   6 +-
 arrow_data/enum.BufferSpec.html                    |  12 +-
 arrow_data/equal/boolean/fn.boolean_equal.html     |   2 +-
 arrow_data/equal/boolean/index.html                |   4 +-
 .../equal/dictionary/fn.dictionary_equal.html      |   2 +-
 arrow_data/equal/dictionary/index.html             |   4 +-
 .../equal/fixed_binary/fn.fixed_binary_equal.html  |   2 +-
 arrow_data/equal/fixed_binary/index.html           |   4 +-
 .../equal/fixed_list/fn.fixed_list_equal.html      |   2 +-
 arrow_data/equal/fixed_list/index.html             |   4 +-
 arrow_data/equal/fn.equal.html                     |   4 +-
 arrow_data/equal/fn.equal_range.html               |   2 +-
 arrow_data/equal/fn.equal_values.html              |   2 +-
 arrow_data/equal/index.html                        |   4 +-
 arrow_data/equal/list/fn.lengths_equal.html        |   2 +-
 arrow_data/equal/list/fn.list_equal.html           |   2 +-
 arrow_data/equal/list/index.html                   |   4 +-
 arrow_data/equal/null/fn.null_equal.html           |   2 +-
 arrow_data/equal/null/index.html                   |   4 +-
 ...constant.NULL_SLICES_SELECTIVITY_THRESHOLD.html |   2 +-
 arrow_data/equal/primitive/fn.primitive_equal.html |   2 +-
 arrow_data/equal/primitive/index.html              |   4 +-
 arrow_data/equal/run/fn.run_equal.html             |   2 +-
 arrow_data/equal/run/index.html                    |   4 +-
 .../equal/structure/fn.equal_child_values.html     |   2 +-
 arrow_data/equal/structure/fn.struct_equal.html    |   2 +-
 arrow_data/equal/structure/index.html              |   4 +-
 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                  |   4 +-
 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                  |   4 +-
 .../equal/variable_size/fn.offset_value_equal.html |   2 +-
 .../variable_size/fn.variable_sized_equal.html     |   2 +-
 arrow_data/equal/variable_size/index.html          |   4 +-
 arrow_data/ffi/fn.align_nulls.html                 |   2 +-
 arrow_data/ffi/fn.release_array.html               |   2 +-
 arrow_data/ffi/index.html                          |   6 +-
 arrow_data/ffi/struct.ArrayPrivateData.html        |  12 +-
 arrow_data/ffi/struct.FFI_ArrowArray.html          |  16 +-
 arrow_data/fn.layout.html                          |   2 +-
 arrow_data/index.html                              |  10 +-
 arrow_data/struct.ArrayData.html                   |  20 +-
 arrow_data/struct.ArrayDataBuilder.html            |  14 +-
 arrow_data/struct.DataTypeLayout.html              |  12 +-
 arrow_data/transform/boolean/fn.build_extend.html  |   2 +-
 arrow_data/transform/boolean/fn.extend_nulls.html  |   2 +-
 arrow_data/transform/boolean/index.html            |   4 +-
 arrow_data/transform/enum.Capacities.html          |  12 +-
 .../transform/fixed_binary/fn.build_extend.html    |   2 +-
 .../transform/fixed_binary/fn.extend_nulls.html    |   2 +-
 arrow_data/transform/fixed_binary/index.html       |   4 +-
 .../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    |   4 +-
 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                    |   8 +-
 arrow_data/transform/list/fn.build_extend.html     |   2 +-
 arrow_data/transform/list/fn.extend_nulls.html     |   2 +-
 arrow_data/transform/list/index.html               |   4 +-
 arrow_data/transform/null/fn.build_extend.html     |   2 +-
 arrow_data/transform/null/fn.extend_nulls.html     |   2 +-
 arrow_data/transform/null/index.html               |   4 +-
 .../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          |   4 +-
 arrow_data/transform/struct.MutableArrayData.html  |  20 +-
 arrow_data/transform/struct._MutableArrayData.html |  12 +-
 .../transform/structure/fn.build_extend.html       |   2 +-
 .../transform/structure/fn.extend_nulls.html       |   2 +-
 arrow_data/transform/structure/index.html          |   4 +-
 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              |   4 +-
 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              |   4 +-
 .../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      |   4 +-
 arrow_data/type.ArrayDataRef.html                  |   2 +-
 arrow_file_to_stream/all.html                      |   2 +-
 arrow_file_to_stream/fn.main.html                  |   2 +-
 arrow_file_to_stream/index.html                    |   4 +-
 arrow_file_to_stream/struct.Args.html              |  12 +-
 arrow_flight/all.html                              |   2 +-
 arrow_flight/client/index.html                     |   4 +-
 arrow_flight/client/struct.FlightClient.html       |  34 +-
 arrow_flight/decode/enum.DecodedPayload.html       |  12 +-
 arrow_flight/decode/index.html                     |   6 +-
 arrow_flight/decode/struct.DecodedFlightData.html  |  12 +-
 arrow_flight/decode/struct.FlightDataDecoder.html  |  14 +-
 .../decode/struct.FlightRecordBatchStream.html     |  16 +-
 arrow_flight/decode/struct.FlightStreamState.html  |  12 +-
 ...constant.GRPC_TARGET_MAX_FLIGHT_SIZE_BYTES.html |   2 +-
 arrow_flight/encode/enum.DictionaryHandling.html   |  12 +-
 arrow_flight/encode/fn.hydrate_dictionary.html     |   2 +-
 .../encode/fn.prepare_batch_for_flight.html        |   2 +-
 .../encode/fn.prepare_schema_for_flight.html       |   2 +-
 .../encode/fn.split_batch_for_grpc_response.html   |   2 +-
 arrow_flight/encode/index.html                     |   6 +-
 arrow_flight/encode/struct.FlightDataEncoder.html  |  12 +-
 .../encode/struct.FlightDataEncoderBuilder.html    |  18 +-
 arrow_flight/encode/struct.FlightIpcEncoder.html   |  12 +-
 arrow_flight/error/enum.FlightError.html           |  14 +-
 arrow_flight/error/index.html                      |   4 +-
 arrow_flight/error/type.Result.html                |   2 +-
 .../flight_descriptor/enum.DescriptorType.html     |  12 +-
 arrow_flight/flight_descriptor/index.html          |   4 +-
 arrow_flight/flight_service_client/index.html      |   4 +-
 .../struct.FlightServiceClient.html                |  12 +-
 arrow_flight/flight_service_server/index.html      |   6 +-
 .../struct.FlightServiceServer.html                |  12 +-
 .../flight_service_server/trait.FlightService.html |   2 +-
 arrow_flight/fn.flight_schema_as_encoded_data.html |   2 +-
 arrow_flight/fn.flight_schema_as_flatbuffer.html   |   2 +-
 arrow_flight/fn.limited_fmt.html                   |   2 +-
 arrow_flight/fn.schema_to_ipc_format.html          |   2 +-
 .../gen/flight_descriptor/enum.DescriptorType.html |  12 +-
 arrow_flight/gen/flight_descriptor/index.html      |   4 +-
 arrow_flight/gen/flight_service_client/index.html  |   4 +-
 .../struct.FlightServiceClient.html                |  12 +-
 arrow_flight/gen/flight_service_server/index.html  |   6 +-
 .../struct.FlightServiceServer.html                |  12 +-
 .../gen/flight_service_server/struct._Inner.html   |  12 +-
 .../flight_service_server/trait.FlightService.html |   2 +-
 arrow_flight/gen/index.html                        |   4 +-
 arrow_flight/gen/struct.Action.html                |  12 +-
 arrow_flight/gen/struct.ActionType.html            |  12 +-
 arrow_flight/gen/struct.BasicAuth.html             |  12 +-
 arrow_flight/gen/struct.Criteria.html              |  12 +-
 arrow_flight/gen/struct.Empty.html                 |  12 +-
 arrow_flight/gen/struct.FlightData.html            |  16 +-
 arrow_flight/gen/struct.FlightDescriptor.html      |  14 +-
 arrow_flight/gen/struct.FlightEndpoint.html        |  14 +-
 arrow_flight/gen/struct.FlightInfo.html            |  14 +-
 arrow_flight/gen/struct.HandshakeRequest.html      |  12 +-
 arrow_flight/gen/struct.HandshakeResponse.html     |  12 +-
 arrow_flight/gen/struct.Location.html              |  12 +-
 arrow_flight/gen/struct.PutResult.html             |  12 +-
 arrow_flight/gen/struct.Result.html                |  12 +-
 arrow_flight/gen/struct.SchemaResult.html          |  14 +-
 arrow_flight/gen/struct.Ticket.html                |  14 +-
 arrow_flight/index.html                            |  10 +-
 arrow_flight/sql/client/enum.ArrowFlightData.html  |  12 +-
 .../sql/client/fn.arrow_data_from_flight_data.html |   2 +-
 .../sql/client/fn.decode_error_to_arrow_error.html |   2 +-
 .../sql/client/fn.flight_error_to_arrow_error.html |   2 +-
 .../sql/client/fn.status_to_arrow_error.html       |   2 +-
 arrow_flight/sql/client/index.html                 |   6 +-
 .../sql/client/struct.FlightSqlServiceClient.html  |  12 +-
 .../sql/client/struct.PreparedStatement.html       |  12 +-
 ...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                 |  14 +-
 arrow_flight/sql/enum.Nullable.html                |  12 +-
 arrow_flight/sql/enum.Searchable.html              |  12 +-
 arrow_flight/sql/enum.SqlInfo.html                 |  12 +-
 arrow_flight/sql/enum.SqlNullOrdering.html         |  12 +-
 .../sql/enum.SqlOuterJoinsSupportLevel.html        |  12 +-
 .../sql/enum.SqlSupportedCaseSensitivity.html      |  12 +-
 .../sql/enum.SqlSupportedElementActions.html       |  12 +-
 arrow_flight/sql/enum.SqlSupportedGroupBy.html     |  12 +-
 .../sql/enum.SqlSupportedPositionedCommands.html   |  12 +-
 .../sql/enum.SqlSupportedResultSetConcurrency.html |  12 +-
 .../sql/enum.SqlSupportedResultSetType.html        |  12 +-
 arrow_flight/sql/enum.SqlSupportedSubqueries.html  |  12 +-
 arrow_flight/sql/enum.SqlSupportedTransaction.html |  12 +-
 .../sql/enum.SqlSupportedTransactions.html         |  12 +-
 arrow_flight/sql/enum.SqlSupportedUnions.html      |  12 +-
 arrow_flight/sql/enum.SqlSupportsConvert.html      |  12 +-
 .../sql/enum.SqlTransactionIsolationLevel.html     |  12 +-
 arrow_flight/sql/enum.SupportedSqlGrammar.html     |  12 +-
 arrow_flight/sql/enum.UpdateDeleteRules.html       |  12 +-
 arrow_flight/sql/enum.XdbcDataType.html            |  12 +-
 arrow_flight/sql/enum.XdbcDatetimeSubcode.html     |  12 +-
 .../enum.CancelResult.html                         |  12 +-
 .../sql/gen/action_cancel_query_result/index.html  |   4 +-
 .../enum.EndSavepoint.html                         |  12 +-
 .../gen/action_end_savepoint_request/index.html    |   4 +-
 .../enum.EndTransaction.html                       |  12 +-
 .../gen/action_end_transaction_request/index.html  |   4 +-
 arrow_flight/sql/gen/enum.Nullable.html            |  12 +-
 arrow_flight/sql/gen/enum.Searchable.html          |  12 +-
 arrow_flight/sql/gen/enum.SqlInfo.html             |  12 +-
 arrow_flight/sql/gen/enum.SqlNullOrdering.html     |  12 +-
 .../sql/gen/enum.SqlOuterJoinsSupportLevel.html    |  12 +-
 .../sql/gen/enum.SqlSupportedCaseSensitivity.html  |  12 +-
 .../sql/gen/enum.SqlSupportedElementActions.html   |  12 +-
 arrow_flight/sql/gen/enum.SqlSupportedGroupBy.html |  12 +-
 .../gen/enum.SqlSupportedPositionedCommands.html   |  12 +-
 .../gen/enum.SqlSupportedResultSetConcurrency.html |  12 +-
 .../sql/gen/enum.SqlSupportedResultSetType.html    |  12 +-
 .../sql/gen/enum.SqlSupportedSubqueries.html       |  12 +-
 .../sql/gen/enum.SqlSupportedTransaction.html      |  12 +-
 .../sql/gen/enum.SqlSupportedTransactions.html     |  12 +-
 arrow_flight/sql/gen/enum.SqlSupportedUnions.html  |  12 +-
 arrow_flight/sql/gen/enum.SqlSupportsConvert.html  |  12 +-
 .../sql/gen/enum.SqlTransactionIsolationLevel.html |  12 +-
 .../gen/enum.SupportedAnsi92SqlGrammarLevel.html   |  12 +-
 arrow_flight/sql/gen/enum.SupportedSqlGrammar.html |  12 +-
 arrow_flight/sql/gen/enum.UpdateDeleteRules.html   |  12 +-
 arrow_flight/sql/gen/enum.XdbcDataType.html        |  12 +-
 arrow_flight/sql/gen/enum.XdbcDatetimeSubcode.html |  12 +-
 arrow_flight/sql/gen/index.html                    |   6 +-
 .../gen/struct.ActionBeginSavepointRequest.html    |  12 +-
 .../sql/gen/struct.ActionBeginSavepointResult.html |  12 +-
 .../gen/struct.ActionBeginTransactionRequest.html  |  12 +-
 .../gen/struct.ActionBeginTransactionResult.html   |  12 +-
 .../sql/gen/struct.ActionCancelQueryRequest.html   |  12 +-
 .../sql/gen/struct.ActionCancelQueryResult.html    |  12 +-
 ...struct.ActionClosePreparedStatementRequest.html |  12 +-
 ...truct.ActionCreatePreparedStatementRequest.html |  12 +-
 ...struct.ActionCreatePreparedStatementResult.html |  12 +-
 ...t.ActionCreatePreparedSubstraitPlanRequest.html |  12 +-
 .../sql/gen/struct.ActionEndSavepointRequest.html  |  12 +-
 .../gen/struct.ActionEndTransactionRequest.html    |  12 +-
 .../sql/gen/struct.CommandGetCatalogs.html         |  12 +-
 .../sql/gen/struct.CommandGetCrossReference.html   |  12 +-
 .../sql/gen/struct.CommandGetDbSchemas.html        |  12 +-
 .../sql/gen/struct.CommandGetExportedKeys.html     |  12 +-
 .../sql/gen/struct.CommandGetImportedKeys.html     |  12 +-
 .../sql/gen/struct.CommandGetPrimaryKeys.html      |  12 +-
 arrow_flight/sql/gen/struct.CommandGetSqlInfo.html |  12 +-
 .../sql/gen/struct.CommandGetTableTypes.html       |  12 +-
 arrow_flight/sql/gen/struct.CommandGetTables.html  |  12 +-
 .../sql/gen/struct.CommandGetXdbcTypeInfo.html     |  12 +-
 .../gen/struct.CommandPreparedStatementQuery.html  |  12 +-
 .../gen/struct.CommandPreparedStatementUpdate.html |  12 +-
 .../sql/gen/struct.CommandStatementQuery.html      |  12 +-
 .../gen/struct.CommandStatementSubstraitPlan.html  |  12 +-
 .../sql/gen/struct.CommandStatementUpdate.html     |  12 +-
 arrow_flight/sql/gen/struct.DoPutUpdateResult.html |  12 +-
 arrow_flight/sql/gen/struct.SubstraitPlan.html     |  12 +-
 .../sql/gen/struct.TicketStatementQuery.html       |  12 +-
 arrow_flight/sql/index.html                        |  12 +-
 arrow_flight/sql/macro.as_item.html                |   2 +-
 arrow_flight/sql/macro.prost_message_ext.html      |   2 +-
 .../metadata/catalogs/fn.get_catalogs_schema.html  |   2 +-
 arrow_flight/sql/metadata/catalogs/index.html      |   4 +-
 .../catalogs/static.GET_CATALOG_SCHEMA.html        |   2 +-
 .../catalogs/struct.GetCatalogsBuilder.html        |  12 +-
 .../db_schemas/fn.get_db_schemas_schema.html       |   2 +-
 arrow_flight/sql/metadata/db_schemas/index.html    |   4 +-
 .../db_schemas/static.GET_DB_SCHEMAS_SCHEMA.html   |   2 +-
 .../db_schemas/struct.GetDbSchemasBuilder.html     |  14 +-
 .../sql/metadata/fn.lexsort_to_indices.html        |   2 +-
 arrow_flight/sql/metadata/index.html               |   4 +-
 .../sql/metadata/sql_info/enum.SqlInfoValue.html   |  14 +-
 arrow_flight/sql/metadata/sql_info/index.html      |   4 +-
 .../metadata/sql_info/static.SQL_INFO_SCHEMA.html  |   2 +-
 .../sql/metadata/sql_info/static.UNION_TYPE.html   |   2 +-
 .../sql_info/struct.GetSqlInfoBuilder.html         |  12 +-
 .../sql/metadata/sql_info/struct.SqlInfoData.html  |  14 +-
 .../sql_info/struct.SqlInfoDataBuilder.html        |  12 +-
 .../sql_info/struct.SqlInfoUnionBuilder.html       |  12 +-
 .../sql/metadata/sql_info/trait.SqlInfoName.html   |   2 +-
 .../sql/metadata/struct.GetCatalogsBuilder.html    |  12 +-
 .../sql/metadata/struct.GetDbSchemasBuilder.html   |  14 +-
 .../sql/metadata/struct.GetTablesBuilder.html      |  14 +-
 arrow_flight/sql/metadata/struct.SqlInfoData.html  |  14 +-
 .../sql/metadata/struct.SqlInfoDataBuilder.html    |  12 +-
 arrow_flight/sql/metadata/struct.XdbcTypeInfo.html |  12 +-
 .../sql/metadata/struct.XdbcTypeInfoData.html      |  12 +-
 .../metadata/struct.XdbcTypeInfoDataBuilder.html   |  14 +-
 .../sql/metadata/tables/fn.get_tables_schema.html  |   2 +-
 arrow_flight/sql/metadata/tables/index.html        |   4 +-
 ...tic.GET_TABLES_SCHEMA_WITHOUT_TABLE_SCHEMA.html |   2 +-
 ...static.GET_TABLES_SCHEMA_WITH_TABLE_SCHEMA.html |   2 +-
 .../metadata/tables/struct.GetTablesBuilder.html   |  14 +-
 arrow_flight/sql/metadata/xdbc_info/index.html     |   4 +-
 .../xdbc_info/static.GET_XDBC_INFO_SCHEMA.html     |   2 +-
 .../xdbc_info/struct.GetXdbcTypeInfoBuilder.html   |  12 +-
 .../metadata/xdbc_info/struct.XdbcTypeInfo.html    |  12 +-
 .../xdbc_info/struct.XdbcTypeInfoData.html         |  12 +-
 .../xdbc_info/struct.XdbcTypeInfoDataBuilder.html  |  14 +-
 .../sql/server/fn.arrow_error_to_status.html       |   2 +-
 .../sql/server/fn.decode_error_to_status.html      |   2 +-
 arrow_flight/sql/server/index.html                 |   6 +-
 .../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    |  14 +-
 .../sql/server/trait.FlightSqlService.html         |   2 +-
 .../sql/struct.ActionBeginSavepointRequest.html    |  12 +-
 .../sql/struct.ActionBeginSavepointResult.html     |  12 +-
 .../sql/struct.ActionBeginTransactionRequest.html  |  12 +-
 .../sql/struct.ActionBeginTransactionResult.html   |  12 +-
 .../sql/struct.ActionCancelQueryRequest.html       |  12 +-
 .../sql/struct.ActionCancelQueryResult.html        |  12 +-
 ...struct.ActionClosePreparedStatementRequest.html |  12 +-
 ...truct.ActionCreatePreparedStatementRequest.html |  12 +-
 ...struct.ActionCreatePreparedStatementResult.html |  12 +-
 ...t.ActionCreatePreparedSubstraitPlanRequest.html |  12 +-
 .../sql/struct.ActionEndSavepointRequest.html      |  12 +-
 .../sql/struct.ActionEndTransactionRequest.html    |  12 +-
 arrow_flight/sql/struct.Any.html                   |  12 +-
 arrow_flight/sql/struct.CommandGetCatalogs.html    |  12 +-
 .../sql/struct.CommandGetCrossReference.html       |  12 +-
 arrow_flight/sql/struct.CommandGetDbSchemas.html   |  12 +-
 .../sql/struct.CommandGetExportedKeys.html         |  12 +-
 .../sql/struct.CommandGetImportedKeys.html         |  12 +-
 arrow_flight/sql/struct.CommandGetPrimaryKeys.html |  12 +-
 arrow_flight/sql/struct.CommandGetSqlInfo.html     |  12 +-
 arrow_flight/sql/struct.CommandGetTableTypes.html  |  12 +-
 arrow_flight/sql/struct.CommandGetTables.html      |  12 +-
 .../sql/struct.CommandGetXdbcTypeInfo.html         |  12 +-
 .../sql/struct.CommandPreparedStatementQuery.html  |  12 +-
 .../sql/struct.CommandPreparedStatementUpdate.html |  12 +-
 arrow_flight/sql/struct.CommandStatementQuery.html |  12 +-
 .../sql/struct.CommandStatementSubstraitPlan.html  |  12 +-
 .../sql/struct.CommandStatementUpdate.html         |  12 +-
 arrow_flight/sql/struct.DoPutUpdateResult.html     |  12 +-
 arrow_flight/sql/struct.SubstraitPlan.html         |  12 +-
 arrow_flight/sql/struct.TicketStatementQuery.html  |  12 +-
 arrow_flight/sql/trait.ProstMessageExt.html        |   2 +-
 arrow_flight/struct.Action.html                    |  12 +-
 arrow_flight/struct.ActionType.html                |  12 +-
 arrow_flight/struct.BasicAuth.html                 |  12 +-
 arrow_flight/struct.Criteria.html                  |  12 +-
 arrow_flight/struct.Empty.html                     |  12 +-
 arrow_flight/struct.FlightData.html                |  16 +-
 arrow_flight/struct.FlightDescriptor.html          |  14 +-
 arrow_flight/struct.FlightEndpoint.html            |  14 +-
 arrow_flight/struct.FlightInfo.html                |  14 +-
 arrow_flight/struct.HandshakeRequest.html          |  12 +-
 arrow_flight/struct.HandshakeResponse.html         |  12 +-
 arrow_flight/struct.IpcMessage.html                | 412 +++++-----
 arrow_flight/struct.Location.html                  |  12 +-
 arrow_flight/struct.PutResult.html                 |  12 +-
 arrow_flight/struct.Result.html                    |  12 +-
 arrow_flight/struct.SchemaAsIpc.html               |  12 +-
 arrow_flight/struct.SchemaResult.html              |  14 +-
 arrow_flight/struct.Ticket.html                    |  14 +-
 .../trailers/fn.extract_lazy_trailers.html         |   2 +-
 arrow_flight/trailers/index.html                   |   4 +-
 .../trailers/struct.ExtractTrailersStream.html     |  12 +-
 arrow_flight/trailers/struct.LazyTrailers.html     |  12 +-
 arrow_flight/trailers/type.SharedTrailers.html     |   2 +-
 arrow_flight/type.ArrowResult.html                 |   2 +-
 arrow_flight/utils/fn.batches_to_flight_data.html  |   2 +-
 .../utils/fn.flight_data_from_arrow_batch.html     |   2 +-
 .../utils/fn.flight_data_from_arrow_schema.html    |   2 +-
 .../utils/fn.flight_data_to_arrow_batch.html       |   2 +-
 arrow_flight/utils/fn.flight_data_to_batches.html  |   2 +-
 .../utils/fn.flight_schema_from_arrow_schema.html  |   2 +-
 .../utils/fn.ipc_message_from_arrow_schema.html    |   2 +-
 arrow_flight/utils/index.html                      |   4 +-
 arrow_integration_test/all.html                    |   2 +-
 .../datatype/fn.data_type_from_json.html           |   2 +-
 .../datatype/fn.data_type_to_json.html             |   2 +-
 arrow_integration_test/datatype/index.html         |   4 +-
 .../field/fn.field_from_json.html                  |   2 +-
 arrow_integration_test/field/fn.field_to_json.html |   2 +-
 arrow_integration_test/field/index.html            |   4 +-
 arrow_integration_test/fn.array_from_json.html     |   2 +-
 arrow_integration_test/fn.create_null_buf.html     |   2 +-
 arrow_integration_test/fn.data_type_from_json.html |   2 +-
 arrow_integration_test/fn.data_type_to_json.html   |   2 +-
 .../fn.dictionary_array_from_json.html             |   2 +-
 arrow_integration_test/fn.field_from_json.html     |   2 +-
 arrow_integration_test/fn.field_to_json.html       |   2 +-
 .../fn.record_batch_from_json.html                 |   2 +-
 arrow_integration_test/fn.schema_from_json.html    |   2 +-
 arrow_integration_test/fn.schema_to_json.html      |   2 +-
 arrow_integration_test/index.html                  |   4 +-
 .../schema/fn.from_metadata.html                   |   2 +-
 .../schema/fn.schema_from_json.html                |   2 +-
 .../schema/fn.schema_to_json.html                  |   2 +-
 arrow_integration_test/schema/index.html           |   4 +-
 .../schema/struct.MetadataKeyValue.html            |  12 +-
 arrow_integration_test/struct.ArrowJson.html       |  12 +-
 arrow_integration_test/struct.ArrowJsonBatch.html  |  12 +-
 arrow_integration_test/struct.ArrowJsonColumn.html |  12 +-
 .../struct.ArrowJsonDictionaryBatch.html           |  12 +-
 arrow_integration_test/struct.ArrowJsonField.html  |  12 +-
 .../struct.ArrowJsonFieldDictionary.html           |  12 +-
 arrow_integration_test/struct.ArrowJsonSchema.html |  12 +-
 .../struct.DictionaryIndexType.html                |  12 +-
 arrow_integration_testing/all.html                 |   2 +-
 .../constant.AUTH_PASSWORD.html                    |   2 +-
 .../constant.AUTH_USERNAME.html                    |   2 +-
 .../auth_basic_proto/fn.authenticate.html          |   2 +-
 .../auth_basic_proto/fn.run_scenario.html          |   2 +-
 .../auth_basic_proto/index.html                    |   4 +-
 .../auth_basic_proto/type.Client.html              |   2 +-
 .../auth_basic_proto/type.Error.html               |   2 +-
 .../auth_basic_proto/type.Result.html              |   2 +-
 .../flight_client_scenarios/index.html             |   4 +-
 .../fn.consume_flight_location.html                |   2 +-
 .../fn.receive_batch_flight_data.html              |   2 +-
 .../fn.receive_schema_flight_data.html             |   2 +-
 .../integration_test/fn.run_scenario.html          |   2 +-
 .../integration_test/fn.send_batch.html            |   2 +-
 .../integration_test/fn.upload_data.html           |   2 +-
 .../integration_test/fn.verify_data.html           |   2 +-
 .../integration_test/index.html                    |   4 +-
 .../integration_test/type.Client.html              |   2 +-
 .../integration_test/type.Error.html               |   2 +-
 .../integration_test/type.Result.html              |   2 +-
 .../middleware/fn.middleware_interceptor.html      |   2 +-
 .../middleware/fn.run_scenario.html                |   2 +-
 .../flight_client_scenarios/middleware/index.html  |   4 +-
 .../middleware/type.Error.html                     |   2 +-
 .../middleware/type.Result.html                    |   2 +-
 .../auth_basic_proto/fn.scenario_setup.html        |   2 +-
 .../auth_basic_proto/index.html                    |   4 +-
 .../struct.AuthBasicProtoScenarioImpl.html         |  12 +-
 .../struct.GrpcServerCallContext.html              |  12 +-
 .../auth_basic_proto/type.Error.html               |   2 +-
 .../auth_basic_proto/type.Result.html              |   2 +-
 .../auth_basic_proto/type.TonicStream.html         |   2 +-
 .../flight_server_scenarios/fn.endpoint.html       |   2 +-
 .../flight_server_scenarios/fn.listen_on.html      |   2 +-
 .../flight_server_scenarios/index.html             |   4 +-
 .../fn.dictionary_from_message.html                |   2 +-
 .../fn.record_batch_from_message.html              |   2 +-
 .../integration_test/fn.save_uploaded_chunks.html  |   2 +-
 .../integration_test/fn.scenario_setup.html        |   2 +-
 .../integration_test/fn.send_app_metadata.html     |   2 +-
 .../integration_test/index.html                    |   4 +-
 .../integration_test/struct.FlightServiceImpl.html |  12 +-
 .../struct.IntegrationDataset.html                 |  12 +-
 .../integration_test/type.Error.html               |   2 +-
 .../integration_test/type.Result.html              |   2 +-
 .../integration_test/type.TonicStream.html         |   2 +-
 .../middleware/fn.scenario_setup.html              |   2 +-
 .../flight_server_scenarios/middleware/index.html  |   4 +-
 .../middleware/struct.MiddlewareScenarioImpl.html  |  12 +-
 .../middleware/type.Error.html                     |   2 +-
 .../middleware/type.Result.html                    |   2 +-
 .../middleware/type.TonicStream.html               |   2 +-
 .../flight_server_scenarios/type.Error.html        |   2 +-
 .../flight_server_scenarios/type.Result.html       |   2 +-
 ...s_cdata_integration_export_batch_from_json.html |   2 +-
 ..._cdata_integration_export_schema_from_json.html |   2 +-
 ...tegration_import_batch_and_compare_to_json.html |   2 +-
 ...egration_import_schema_and_compare_to_json.html |   2 +-
 .../fn.arrow_rs_free_error.html                    |   4 +-
 .../fn.canonicalize_schema.html                    |   2 +-
 ...n.cdata_integration_export_batch_from_json.html |   2 +-
 ....cdata_integration_export_schema_from_json.html |   2 +-
 ...tegration_import_batch_and_compare_to_json.html |   2 +-
 ...egration_import_schema_and_compare_to_json.html |   2 +-
 arrow_integration_testing/fn.compare_batches.html  |   2 +-
 arrow_integration_testing/fn.open_json_file.html   |   2 +-
 arrow_integration_testing/fn.read_gzip_json.html   |   2 +-
 .../fn.result_to_c_error.html                      |   2 +-
 arrow_integration_testing/index.html               |   4 +-
 arrow_integration_testing/struct.ArrowFile.html    |  12 +-
 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   |  12 +-
 arrow_ipc/compression/fn.compress_lz4.html         |   2 +-
 arrow_ipc/compression/fn.compress_zstd.html        |   2 +-
 arrow_ipc/compression/fn.decompress_lz4.html       |   2 +-
 arrow_ipc/compression/fn.decompress_zstd.html      |   2 +-
 .../compression/fn.read_uncompressed_size.html     |   2 +-
 arrow_ipc/compression/index.html                   |   4 +-
 arrow_ipc/constant.ARROW_MAGIC.html                |   2 +-
 arrow_ipc/constant.CONTINUATION_MARKER.html        |   2 +-
 arrow_ipc/convert/fn.build_field.html              |   2 +-
 arrow_ipc/convert/fn.fb_to_schema.html             |   2 +-
 arrow_ipc/convert/fn.get_data_type.html            |   2 +-
 arrow_ipc/convert/fn.get_fb_dictionary.html        |   2 +-
 arrow_ipc/convert/fn.get_fb_field_type.html        |   2 +-
 arrow_ipc/convert/fn.metadata_to_fb.html           |   2 +-
 arrow_ipc/convert/fn.schema_to_fb.html             |   2 +-
 arrow_ipc/convert/fn.schema_to_fb_offset.html      |   2 +-
 .../fn.try_schema_from_flatbuffer_bytes.html       |   2 +-
 .../convert/fn.try_schema_from_ipc_buffer.html     |   2 +-
 arrow_ipc/convert/index.html                       |   4 +-
 arrow_ipc/convert/struct.FBFieldType.html          |  12 +-
 arrow_ipc/gen/File/enum.FooterOffset.html          |  12 +-
 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      |   4 +-
 .../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 |   4 +-
 .../fn.size_prefixed_root_as_footer_with_opts.html |   2 +-
 arrow_ipc/gen/File/index.html                      |   6 +-
 arrow_ipc/gen/File/struct.Block.html               |  14 +-
 arrow_ipc/gen/File/struct.Footer.html              |  12 +-
 arrow_ipc/gen/File/struct.FooterArgs.html          |  12 +-
 arrow_ipc/gen/File/struct.FooterBuilder.html       |  12 +-
 .../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    |  12 +-
 .../gen/Message/enum.DictionaryBatchOffset.html    |  12 +-
 arrow_ipc/gen/Message/enum.MessageOffset.html      |  12 +-
 arrow_ipc/gen/Message/enum.RecordBatchOffset.html  |  12 +-
 .../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  |   4 +-
 .../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 |   4 +-
 ...fn.size_prefixed_root_as_message_with_opts.html |   2 +-
 arrow_ipc/gen/Message/index.html                   |   6 +-
 arrow_ipc/gen/Message/struct.BodyCompression.html  |  12 +-
 .../gen/Message/struct.BodyCompressionArgs.html    |  12 +-
 .../gen/Message/struct.BodyCompressionBuilder.html |  12 +-
 .../gen/Message/struct.BodyCompressionMethod.html  |  12 +-
 arrow_ipc/gen/Message/struct.CompressionType.html  |  12 +-
 arrow_ipc/gen/Message/struct.DictionaryBatch.html  |  12 +-
 .../gen/Message/struct.DictionaryBatchArgs.html    |  12 +-
 .../gen/Message/struct.DictionaryBatchBuilder.html |  12 +-
 arrow_ipc/gen/Message/struct.FieldNode.html        |  14 +-
 arrow_ipc/gen/Message/struct.Message.html          |  12 +-
 arrow_ipc/gen/Message/struct.MessageArgs.html      |  12 +-
 arrow_ipc/gen/Message/struct.MessageBuilder.html   |  12 +-
 arrow_ipc/gen/Message/struct.MessageHeader.html    |  12 +-
 .../struct.MessageHeaderUnionTableOffset.html      |  12 +-
 arrow_ipc/gen/Message/struct.RecordBatch.html      |  12 +-
 arrow_ipc/gen/Message/struct.RecordBatchArgs.html  |  12 +-
 .../gen/Message/struct.RecordBatchBuilder.html     |  12 +-
 .../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        |  12 +-
 arrow_ipc/gen/Schema/enum.BoolOffset.html          |  12 +-
 arrow_ipc/gen/Schema/enum.DateOffset.html          |  12 +-
 arrow_ipc/gen/Schema/enum.DecimalOffset.html       |  12 +-
 .../gen/Schema/enum.DictionaryEncodingOffset.html  |  12 +-
 arrow_ipc/gen/Schema/enum.DurationOffset.html      |  12 +-
 arrow_ipc/gen/Schema/enum.FieldOffset.html         |  12 +-
 .../gen/Schema/enum.FixedSizeBinaryOffset.html     |  12 +-
 arrow_ipc/gen/Schema/enum.FixedSizeListOffset.html |  12 +-
 arrow_ipc/gen/Schema/enum.FloatingPointOffset.html |  12 +-
 arrow_ipc/gen/Schema/enum.IntOffset.html           |  12 +-
 arrow_ipc/gen/Schema/enum.IntervalOffset.html      |  12 +-
 arrow_ipc/gen/Schema/enum.KeyValueOffset.html      |  12 +-
 arrow_ipc/gen/Schema/enum.LargeBinaryOffset.html   |  12 +-
 arrow_ipc/gen/Schema/enum.LargeListOffset.html     |  12 +-
 arrow_ipc/gen/Schema/enum.LargeUtf8Offset.html     |  12 +-
 arrow_ipc/gen/Schema/enum.ListOffset.html          |  12 +-
 arrow_ipc/gen/Schema/enum.MapOffset.html           |  12 +-
 arrow_ipc/gen/Schema/enum.NullOffset.html          |  12 +-
 arrow_ipc/gen/Schema/enum.RunEndEncodedOffset.html |  12 +-
 arrow_ipc/gen/Schema/enum.SchemaOffset.html        |  12 +-
 arrow_ipc/gen/Schema/enum.Struct_Offset.html       |  12 +-
 arrow_ipc/gen/Schema/enum.TimeOffset.html          |  12 +-
 arrow_ipc/gen/Schema/enum.TimestampOffset.html     |  12 +-
 arrow_ipc/gen/Schema/enum.UnionOffset.html         |  12 +-
 arrow_ipc/gen/Schema/enum.Utf8Offset.html          |  12 +-
 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    |   4 +-
 .../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 |   4 +-
 .../fn.size_prefixed_root_as_schema_with_opts.html |   2 +-
 arrow_ipc/gen/Schema/index.html                    |   6 +-
 arrow_ipc/gen/Schema/struct.Binary.html            |  12 +-
 arrow_ipc/gen/Schema/struct.BinaryArgs.html        |  12 +-
 arrow_ipc/gen/Schema/struct.BinaryBuilder.html     |  12 +-
 arrow_ipc/gen/Schema/struct.Bool.html              |  12 +-
 arrow_ipc/gen/Schema/struct.BoolArgs.html          |  12 +-
 arrow_ipc/gen/Schema/struct.BoolBuilder.html       |  12 +-
 arrow_ipc/gen/Schema/struct.Buffer.html            |  14 +-
 arrow_ipc/gen/Schema/struct.Date.html              |  12 +-
 arrow_ipc/gen/Schema/struct.DateArgs.html          |  12 +-
 arrow_ipc/gen/Schema/struct.DateBuilder.html       |  12 +-
 arrow_ipc/gen/Schema/struct.DateUnit.html          |  12 +-
 arrow_ipc/gen/Schema/struct.Decimal.html           |  12 +-
 arrow_ipc/gen/Schema/struct.DecimalArgs.html       |  12 +-
 arrow_ipc/gen/Schema/struct.DecimalBuilder.html    |  12 +-
 .../gen/Schema/struct.DictionaryEncoding.html      |  12 +-
 .../gen/Schema/struct.DictionaryEncodingArgs.html  |  12 +-
 .../Schema/struct.DictionaryEncodingBuilder.html   |  12 +-
 arrow_ipc/gen/Schema/struct.DictionaryKind.html    |  12 +-
 arrow_ipc/gen/Schema/struct.Duration.html          |  12 +-
 arrow_ipc/gen/Schema/struct.DurationArgs.html      |  12 +-
 arrow_ipc/gen/Schema/struct.DurationBuilder.html   |  12 +-
 arrow_ipc/gen/Schema/struct.Endianness.html        |  12 +-
 arrow_ipc/gen/Schema/struct.Feature.html           |  12 +-
 arrow_ipc/gen/Schema/struct.Field.html             |  12 +-
 arrow_ipc/gen/Schema/struct.FieldArgs.html         |  12 +-
 arrow_ipc/gen/Schema/struct.FieldBuilder.html      |  12 +-
 arrow_ipc/gen/Schema/struct.FixedSizeBinary.html   |  12 +-
 .../gen/Schema/struct.FixedSizeBinaryArgs.html     |  12 +-
 .../gen/Schema/struct.FixedSizeBinaryBuilder.html  |  12 +-
 arrow_ipc/gen/Schema/struct.FixedSizeList.html     |  12 +-
 arrow_ipc/gen/Schema/struct.FixedSizeListArgs.html |  12 +-
 .../gen/Schema/struct.FixedSizeListBuilder.html    |  12 +-
 arrow_ipc/gen/Schema/struct.FloatingPoint.html     |  12 +-
 arrow_ipc/gen/Schema/struct.FloatingPointArgs.html |  12 +-
 .../gen/Schema/struct.FloatingPointBuilder.html    |  12 +-
 arrow_ipc/gen/Schema/struct.Int.html               |  12 +-
 arrow_ipc/gen/Schema/struct.IntArgs.html           |  12 +-
 arrow_ipc/gen/Schema/struct.IntBuilder.html        |  12 +-
 arrow_ipc/gen/Schema/struct.Interval.html          |  12 +-
 arrow_ipc/gen/Schema/struct.IntervalArgs.html      |  12 +-
 arrow_ipc/gen/Schema/struct.IntervalBuilder.html   |  12 +-
 arrow_ipc/gen/Schema/struct.IntervalUnit.html      |  12 +-
 arrow_ipc/gen/Schema/struct.KeyValue.html          |  12 +-
 arrow_ipc/gen/Schema/struct.KeyValueArgs.html      |  12 +-
 arrow_ipc/gen/Schema/struct.KeyValueBuilder.html   |  12 +-
 arrow_ipc/gen/Schema/struct.LargeBinary.html       |  12 +-
 arrow_ipc/gen/Schema/struct.LargeBinaryArgs.html   |  12 +-
 .../gen/Schema/struct.LargeBinaryBuilder.html      |  12 +-
 arrow_ipc/gen/Schema/struct.LargeList.html         |  12 +-
 arrow_ipc/gen/Schema/struct.LargeListArgs.html     |  12 +-
 arrow_ipc/gen/Schema/struct.LargeListBuilder.html  |  12 +-
 arrow_ipc/gen/Schema/struct.LargeUtf8.html         |  12 +-
 arrow_ipc/gen/Schema/struct.LargeUtf8Args.html     |  12 +-
 arrow_ipc/gen/Schema/struct.LargeUtf8Builder.html  |  12 +-
 arrow_ipc/gen/Schema/struct.List.html              |  12 +-
 arrow_ipc/gen/Schema/struct.ListArgs.html          |  12 +-
 arrow_ipc/gen/Schema/struct.ListBuilder.html       |  12 +-
 arrow_ipc/gen/Schema/struct.Map.html               |  12 +-
 arrow_ipc/gen/Schema/struct.MapArgs.html           |  12 +-
 arrow_ipc/gen/Schema/struct.MapBuilder.html        |  12 +-
 arrow_ipc/gen/Schema/struct.MetadataVersion.html   |  12 +-
 arrow_ipc/gen/Schema/struct.Null.html              |  12 +-
 arrow_ipc/gen/Schema/struct.NullArgs.html          |  12 +-
 arrow_ipc/gen/Schema/struct.NullBuilder.html       |  12 +-
 arrow_ipc/gen/Schema/struct.Precision.html         |  12 +-
 arrow_ipc/gen/Schema/struct.RunEndEncoded.html     |  12 +-
 arrow_ipc/gen/Schema/struct.RunEndEncodedArgs.html |  12 +-
 .../gen/Schema/struct.RunEndEncodedBuilder.html    |  12 +-
 arrow_ipc/gen/Schema/struct.Schema.html            |  12 +-
 arrow_ipc/gen/Schema/struct.SchemaArgs.html        |  12 +-
 arrow_ipc/gen/Schema/struct.SchemaBuilder.html     |  12 +-
 arrow_ipc/gen/Schema/struct.Struct_.html           |  12 +-
 arrow_ipc/gen/Schema/struct.Struct_Args.html       |  12 +-
 arrow_ipc/gen/Schema/struct.Struct_Builder.html    |  12 +-
 arrow_ipc/gen/Schema/struct.Time.html              |  12 +-
 arrow_ipc/gen/Schema/struct.TimeArgs.html          |  12 +-
 arrow_ipc/gen/Schema/struct.TimeBuilder.html       |  12 +-
 arrow_ipc/gen/Schema/struct.TimeUnit.html          |  12 +-
 arrow_ipc/gen/Schema/struct.Timestamp.html         |  20 +-
 arrow_ipc/gen/Schema/struct.TimestampArgs.html     |  12 +-
 arrow_ipc/gen/Schema/struct.TimestampBuilder.html  |  12 +-
 arrow_ipc/gen/Schema/struct.Type.html              |  12 +-
 .../gen/Schema/struct.TypeUnionTableOffset.html    |  12 +-
 arrow_ipc/gen/Schema/struct.Union.html             |  12 +-
 arrow_ipc/gen/Schema/struct.UnionArgs.html         |  12 +-
 arrow_ipc/gen/Schema/struct.UnionBuilder.html      |  12 +-
 arrow_ipc/gen/Schema/struct.UnionMode.html         |  12 +-
 arrow_ipc/gen/Schema/struct.Utf8.html              |  12 +-
 arrow_ipc/gen/Schema/struct.Utf8Args.html          |  12 +-
 arrow_ipc/gen/Schema/struct.Utf8Builder.html       |  12 +-
 ...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           |  12 +-
 .../enum.SparseTensorIndexCOOOffset.html           |  12 +-
 .../enum.SparseTensorIndexCSFOffset.html           |  12 +-
 .../gen/SparseTensor/enum.SparseTensorOffset.html  |  12 +-
 ....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        |   4 +-
 .../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 |   4 +-
 ...e_prefixed_root_as_sparse_tensor_with_opts.html |   2 +-
 arrow_ipc/gen/SparseTensor/index.html              |   6 +-
 .../struct.SparseMatrixCompressedAxis.html         |  12 +-
 .../SparseTensor/struct.SparseMatrixIndexCSX.html  |  12 +-
 .../struct.SparseMatrixIndexCSXArgs.html           |  12 +-
 .../struct.SparseMatrixIndexCSXBuilder.html        |  12 +-
 .../gen/SparseTensor/struct.SparseTensor.html      |  12 +-
 .../gen/SparseTensor/struct.SparseTensorArgs.html  |  12 +-
 .../SparseTensor/struct.SparseTensorBuilder.html   |  12 +-
 .../gen/SparseTensor/struct.SparseTensorIndex.html |  12 +-
 .../SparseTensor/struct.SparseTensorIndexCOO.html  |  12 +-
 .../struct.SparseTensorIndexCOOArgs.html           |  12 +-
 .../struct.SparseTensorIndexCOOBuilder.html        |  12 +-
 .../SparseTensor/struct.SparseTensorIndexCSF.html  |  12 +-
 .../struct.SparseTensorIndexCSFArgs.html           |  12 +-
 .../struct.SparseTensorIndexCSFBuilder.html        |  12 +-
 .../struct.SparseTensorIndexUnionTableOffset.html  |  12 +-
 arrow_ipc/gen/Tensor/enum.TensorDimOffset.html     |  12 +-
 arrow_ipc/gen/Tensor/enum.TensorOffset.html        |  12 +-
 .../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    |   4 +-
 .../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 |   4 +-
 .../fn.size_prefixed_root_as_tensor_with_opts.html |   2 +-
 arrow_ipc/gen/Tensor/index.html                    |   6 +-
 arrow_ipc/gen/Tensor/struct.Tensor.html            |  12 +-
 arrow_ipc/gen/Tensor/struct.TensorArgs.html        |  12 +-
 arrow_ipc/gen/Tensor/struct.TensorBuilder.html     |  12 +-
 arrow_ipc/gen/Tensor/struct.TensorDim.html         |  12 +-
 arrow_ipc/gen/Tensor/struct.TensorDimArgs.html     |  12 +-
 arrow_ipc/gen/Tensor/struct.TensorDimBuilder.html  |  12 +-
 arrow_ipc/gen/index.html                           |   4 +-
 arrow_ipc/index.html                               |   4 +-
 arrow_ipc/reader/fn.create_array.html              |   2 +-
 arrow_ipc/reader/fn.create_dictionary_array.html   |   2 +-
 arrow_ipc/reader/fn.create_list_array.html         |   2 +-
 arrow_ipc/reader/fn.create_primitive_array.html    |   2 +-
 arrow_ipc/reader/fn.parse_message.html             |   2 +-
 arrow_ipc/reader/fn.read_block.html                |   2 +-
 arrow_ipc/reader/fn.read_buffer.html               |   2 +-
 arrow_ipc/reader/fn.read_dictionary.html           |   2 +-
 arrow_ipc/reader/fn.read_footer_length.html        |   2 +-
 arrow_ipc/reader/fn.read_record_batch.html         |   2 +-
 arrow_ipc/reader/index.html                        |   4 +-
 arrow_ipc/reader/struct.ArrayReader.html           |  12 +-
 arrow_ipc/reader/struct.FileDecoder.html           |  12 +-
 arrow_ipc/reader/struct.FileReader.html            |  14 +-
 arrow_ipc/reader/struct.FileReaderBuilder.html     |  12 +-
 arrow_ipc/reader/struct.StreamReader.html          |  14 +-
 arrow_ipc/writer/fn.buffer_need_truncate.html      |   2 +-
 arrow_ipc/writer/fn.get_buffer_element_width.html  |   2 +-
 arrow_ipc/writer/fn.get_byte_array_buffers.html    |   2 +-
 arrow_ipc/writer/fn.get_list_array_buffers.html    |   2 +-
 arrow_ipc/writer/fn.has_validity_bitmap.html       |   2 +-
 .../writer/fn.into_zero_offset_run_array.html      |   2 +-
 arrow_ipc/writer/fn.pad_to_8.html                  |   2 +-
 arrow_ipc/writer/fn.reencode_offsets.html          |   2 +-
 arrow_ipc/writer/fn.unslice_run_array.html         |   2 +-
 arrow_ipc/writer/fn.write_array_data.html          |   2 +-
 arrow_ipc/writer/fn.write_body_buffers.html        |   2 +-
 arrow_ipc/writer/fn.write_buffer.html              |   2 +-
 arrow_ipc/writer/fn.write_continuation.html        |   2 +-
 arrow_ipc/writer/fn.write_message.html             |   2 +-
 arrow_ipc/writer/index.html                        |   6 +-
 arrow_ipc/writer/struct.DictionaryTracker.html     |  12 +-
 arrow_ipc/writer/struct.EncodedData.html           |  12 +-
 arrow_ipc/writer/struct.FileWriter.html            |  12 +-
 arrow_ipc/writer/struct.IpcDataGenerator.html      |  14 +-
 arrow_ipc/writer/struct.IpcWriteOptions.html       |  12 +-
 arrow_ipc/writer/struct.StreamWriter.html          |  16 +-
 arrow_json/all.html                                |   2 +-
 arrow_json/index.html                              |   6 +-
 arrow_json/macro.json_serializable.html            |   2 +-
 arrow_json/reader/boolean_array/index.html         |   4 +-
 .../boolean_array/struct.BooleanArrayDecoder.html  |  12 +-
 arrow_json/reader/decimal_array/index.html         |   4 +-
 .../decimal_array/struct.DecimalArrayDecoder.html  |  12 +-
 arrow_json/reader/fn.infer_json_schema.html        |   4 +-
 .../reader/fn.infer_json_schema_from_iterator.html |   2 +-
 .../reader/fn.infer_json_schema_from_seekable.html |   4 +-
 arrow_json/reader/fn.make_decoder.html             |   2 +-
 arrow_json/reader/index.html                       |   8 +-
 arrow_json/reader/list_array/index.html            |   4 +-
 .../reader/list_array/struct.ListArrayDecoder.html |  12 +-
 arrow_json/reader/macro.primitive_decoder.html     |   2 +-
 arrow_json/reader/map_array/index.html             |   4 +-
 .../reader/map_array/struct.MapArrayDecoder.html   |  12 +-
 arrow_json/reader/null_array/index.html            |   4 +-
 .../reader/null_array/struct.NullArrayDecoder.html |  12 +-
 arrow_json/reader/primitive_array/index.html       |   4 +-
 .../primitive_array/macro.primitive_parse.html     |   2 +-
 .../struct.PrimitiveArrayDecoder.html              |  12 +-
 .../primitive_array/trait.ParseJsonNumber.html     |   2 +-
 arrow_json/reader/schema/enum.InferredType.html    |  12 +-
 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 |   4 +-
 .../schema/fn.infer_json_schema_from_iterator.html |   2 +-
 .../schema/fn.infer_json_schema_from_seekable.html |   4 +-
 .../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                |   4 +-
 arrow_json/reader/schema/struct.ValueIter.html     |  16 +-
 arrow_json/reader/serializer/index.html            |   4 +-
 .../reader/serializer/struct.ListSerializer.html   |  20 +-
 .../reader/serializer/struct.ObjectSerializer.html |  20 +-
 .../reader/serializer/struct.SerializerError.html  |  14 +-
 .../reader/serializer/struct.TapeSerializer.html   |  12 +-
 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          |   4 +-
 .../string_array/struct.StringArrayDecoder.html    |  12 +-
 arrow_json/reader/struct.Decoder.html              |  12 +-
 arrow_json/reader/struct.Reader.html               |  14 +-
 arrow_json/reader/struct.ReaderBuilder.html        |  12 +-
 arrow_json/reader/struct.ValueIter.html            |  16 +-
 .../reader/struct_array/fn.struct_fields.html      |   2 +-
 arrow_json/reader/struct_array/index.html          |   4 +-
 .../struct_array/struct.StructArrayDecoder.html    |  12 +-
 arrow_json/reader/tape/enum.DecoderState.html      |  12 +-
 arrow_json/reader/tape/enum.Literal.html           |  12 +-
 arrow_json/reader/tape/enum.TapeElement.html       |  12 +-
 .../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                  |   6 +-
 arrow_json/reader/tape/macro.next.html             |   2 +-
 arrow_json/reader/tape/struct.BufIter.html         |  14 +-
 arrow_json/reader/tape/struct.Tape.html            |  12 +-
 arrow_json/reader/tape/struct.TapeDecoder.html     |  12 +-
 arrow_json/reader/timestamp_array/index.html       |   4 +-
 .../struct.TimestampArrayDecoder.html              |  12 +-
 arrow_json/reader/trait.ArrayDecoder.html          |   2 +-
 arrow_json/trait.JsonSerializable.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                       |  16 +-
 .../writer/macro.set_column_by_array_type.html     |   2 +-
 arrow_json/writer/struct.JsonArray.html            |  12 +-
 arrow_json/writer/struct.LineDelimited.html        |  12 +-
 arrow_json/writer/struct.Writer.html               |  12 +-
 arrow_json/writer/struct.WriterBuilder.html        |  14 +-
 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         |  12 +-
 arrow_json_integration_test/fn.arrow_to_json.html  |   2 +-
 arrow_json_integration_test/fn.json_to_arrow.html  |   2 +-
 arrow_json_integration_test/fn.main.html           |   2 +-
 arrow_json_integration_test/fn.validate.html       |   2 +-
 arrow_json_integration_test/index.html             |   4 +-
 arrow_json_integration_test/struct.Args.html       |  12 +-
 arrow_ord/all.html                                 |   2 +-
 arrow_ord/cmp/enum.Op.html                         |  14 +-
 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                           |   4 +-
 arrow_ord/cmp/trait.ArrayOrd.html                  |   4 +-
 arrow_ord/index.html                               |   6 +-
 arrow_ord/ord/fn.build_compare.html                |   4 +-
 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                           |   6 +-
 arrow_ord/ord/type.DynComparator.html              |   2 +-
 arrow_ord/partition/fn.find_boundaries.html        |   2 +-
 .../fn.lexicographical_partition_ranges.html       |   2 +-
 arrow_ord/partition/fn.partition.html              |   6 +-
 arrow_ord/partition/index.html                     |   4 +-
 arrow_ord/partition/struct.Partitions.html         |  12 +-
 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                          |   4 +-
 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                        |   4 +-
 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                  |   4 +-
 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                          |   8 +-
 .../sort/struct.LexicographicalComparator.html     |  12 +-
 arrow_ord/sort/struct.SortColumn.html              |  12 +-
 arrow_ord/sort/struct.SortOptions.html             |  12 +-
 .../sort/type.LexicographicalCompareItem.html      |   2 +-
 arrow_row/all.html                                 |   2 +-
 arrow_row/enum.Codec.html                          |  12 +-
 arrow_row/enum.Encoder.html                        |  12 +-
 arrow_row/fixed/fn.decode_bool.html                |   2 +-
 arrow_row/fixed/fn.decode_fixed.html               |   4 +-
 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                         |   6 +-
 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                    |   4 +-
 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                               |   8 +-
 arrow_row/list/fn.compute_lengths.html             |   2 +-
 arrow_row/list/fn.decode.html                      |   4 +-
 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                          |   4 +-
 arrow_row/macro.decode_primitive_helper.html       |   2 +-
 arrow_row/struct.OwnedRow.html                     |  12 +-
 arrow_row/struct.Row.html                          |  12 +-
 arrow_row/struct.RowConfig.html                    |  12 +-
 arrow_row/struct.RowConverter.html                 |  44 +-
 arrow_row/struct.RowParser.html                    |  12 +-
 arrow_row/struct.Rows.html                         |  12 +-
 arrow_row/struct.RowsIter.html                     |  14 +-
 arrow_row/struct.SortField.html                    |  12 +-
 .../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           |   4 +-
 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                      |   4 +-
 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           |  24 +-
 arrow_schema/datatype/enum.IntervalUnit.html       |  12 +-
 arrow_schema/datatype/enum.TimeUnit.html           |  12 +-
 arrow_schema/datatype/enum.UnionMode.html          |  12 +-
 arrow_schema/datatype/index.html                   |   4 +-
 arrow_schema/enum.ArrowError.html                  |  14 +-
 arrow_schema/enum.DataType.html                    |  24 +-
 arrow_schema/enum.IntervalUnit.html                |  12 +-
 arrow_schema/enum.TimeUnit.html                    |  12 +-
 arrow_schema/enum.UnionMode.html                   |  12 +-
 arrow_schema/error/enum.ArrowError.html            |  14 +-
 arrow_schema/error/index.html                      |   4 +-
 arrow_schema/ffi/flags/index.html                  |   4 +-
 arrow_schema/ffi/flags/struct.Flags.html           |  26 +-
 arrow_schema/ffi/fn.get_format_string.html         |   2 +-
 arrow_schema/ffi/fn.release_schema.html            |   2 +-
 arrow_schema/ffi/index.html                        |   6 +-
 arrow_schema/ffi/struct.FFI_ArrowSchema.html       |  20 +-
 arrow_schema/ffi/struct.Flags.html                 |  26 +-
 arrow_schema/ffi/struct.SchemaPrivateData.html     |  12 +-
 arrow_schema/field/index.html                      |   4 +-
 arrow_schema/field/struct.Field.html               |  16 +-
 arrow_schema/field/type.FieldRef.html              |   2 +-
 arrow_schema/fields/index.html                     |   4 +-
 arrow_schema/fields/struct.Fields.html             | 412 +++++-----
 arrow_schema/fields/struct.UnionFields.html        |  12 +-
 arrow_schema/index.html                            |   6 +-
 arrow_schema/schema/index.html                     |   4 +-
 arrow_schema/schema/struct.Schema.html             |  16 +-
 arrow_schema/schema/struct.SchemaBuilder.html      |  20 +-
 arrow_schema/schema/type.SchemaRef.html            |   2 +-
 arrow_schema/struct.Field.html                     |  16 +-
 arrow_schema/struct.Fields.html                    | 412 +++++-----
 arrow_schema/struct.Schema.html                    |  16 +-
 arrow_schema/struct.SchemaBuilder.html             |  20 +-
 arrow_schema/struct.SortOptions.html               |  12 +-
 arrow_schema/struct.UnionFields.html               |  12 +-
 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                     |   4 +-
 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                 |   8 +-
 arrow_select/dictionary/struct.Interner.html       |  12 +-
 .../dictionary/struct.MergedDictionaries.html      |  12 +-
 arrow_select/dictionary/type.PtrEq.html            |   2 +-
 ...nstant.FILTER_SLICES_SELECTIVITY_THRESHOLD.html |   2 +-
 arrow_select/filter/enum.IterationStrategy.html    |  12 +-
 arrow_select/filter/fn.build_filter.html           |   2 +-
 arrow_select/filter/fn.filter.html                 |   4 +-
 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                     |  10 +-
 arrow_select/filter/struct.FilterBuilder.html      |  12 +-
 arrow_select/filter/struct.FilterBytes.html        |  12 +-
 arrow_select/filter/struct.FilterPredicate.html    |  12 +-
 arrow_select/filter/struct.IndexIterator.html      |  14 +-
 arrow_select/filter/struct.SlicesIterator.html     |  16 +-
 arrow_select/filter/type.Filter.html               |   2 +-
 arrow_select/index.html                            |   4 +-
 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                 |   4 +-
 arrow_select/interleave/macro.dict_helper.html     |   2 +-
 .../interleave/macro.primitive_helper.html         |   2 +-
 arrow_select/interleave/struct.Interleave.html     |  12 +-
 arrow_select/nullif/fn.nullif.html                 |   2 +-
 arrow_select/nullif/index.html                     |   4 +-
 arrow_select/take/fn.check_bounds.html             |   2 +-
 arrow_select/take/fn.maybe_usize.html              |   2 +-
 arrow_select/take/fn.take.html                     |   8 +-
 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_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                       |   6 +-
 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          |  12 +-
 arrow_select/take/trait.ToIndices.html             |   2 +-
 arrow_select/window/fn.shift.html                  |   4 +-
 arrow_select/window/index.html                     |   4 +-
 arrow_select/zip/fn.zip.html                       |   4 +-
 arrow_select/zip/index.html                        |   4 +-
 arrow_stream_to_file/all.html                      |   2 +-
 arrow_stream_to_file/fn.main.html                  |   2 +-
 arrow_stream_to_file/index.html                    |   4 +-
 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            |   4 +-
 arrow_string/index.html                            |   4 +-
 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                     |   4 +-
 arrow_string/like/enum.Op.html                     |  14 +-
 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                       |   4 +-
 arrow_string/like/macro.legacy_kernels.html        |   2 +-
 arrow_string/predicate/enum.Predicate.html         |  12 +-
 .../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                  |   4 +-
 .../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                     |   4 +-
 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           |  10 +-
 arrow_string/substring/fn.substring_by_char.html   |   8 +-
 arrow_string/substring/index.html                  |   4 +-
 flight_sql_client/all.html                         |   2 +-
 flight_sql_client/enum.Command.html                |  12 +-
 .../fn.construct_record_batch_from_params.html     |   2 +-
 flight_sql_client/fn.execute_flight.html           |   2 +-
 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                       |   4 +-
 flight_sql_client/struct.Args.html                 |  12 +-
 flight_sql_client/struct.ClientArgs.html           |  12 +-
 flight_sql_client/struct.LoggingArgs.html          |  12 +-
 flight_test_integration_client/all.html            |   2 +-
 flight_test_integration_client/enum.Scenario.html  |  12 +-
 flight_test_integration_client/fn.main.html        |   2 +-
 flight_test_integration_client/index.html          |   4 +-
 flight_test_integration_client/struct.Args.html    |  12 +-
 flight_test_integration_client/type.Error.html     |   2 +-
 flight_test_integration_client/type.Result.html    |   2 +-
 flight_test_integration_server/all.html            |   2 +-
 flight_test_integration_server/enum.Scenario.html  |  12 +-
 flight_test_integration_server/fn.main.html        |   2 +-
 flight_test_integration_server/index.html          |   4 +-
 flight_test_integration_server/struct.Args.html    |  12 +-
 flight_test_integration_server/type.Error.html     |   2 +-
 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                                     |   4 +-
 help.html                                          |   4 +-
 index.html                                         |   4 +-
 parquet/all.html                                   |   4 +-
 parquet/arrow/arrow_reader/filter/index.html       |   4 +-
 .../filter/struct.ArrowPredicateFn.html            |  12 +-
 .../arrow_reader/filter/struct.RowFilter.html      |  12 +-
 .../arrow_reader/filter/trait.ArrowPredicate.html  |   2 +-
 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    |   6 +-
 .../selection/struct.RowSelection.html             |  22 +-
 .../arrow_reader/selection/struct.RowSelector.html |  12 +-
 .../arrow_reader/struct.ArrowPredicateFn.html      |  12 +-
 .../arrow_reader/struct.ArrowReaderBuilder.html    |  12 +-
 .../arrow_reader/struct.ArrowReaderMetadata.html   |  12 +-
 .../arrow_reader/struct.ArrowReaderOptions.html    |  12 +-
 .../struct.ParquetRecordBatchReader.html           |  14 +-
 .../arrow_reader/struct.ReaderPageIterator.html    |  14 +-
 .../arrow/arrow_reader/struct.ReaderRowGroups.html |  12 +-
 parquet/arrow/arrow_reader/struct.RowFilter.html   |  12 +-
 .../arrow/arrow_reader/struct.RowSelection.html    |  22 +-
 parquet/arrow/arrow_reader/struct.RowSelector.html |  12 +-
 .../arrow/arrow_reader/trait.ArrowPredicate.html   |   2 +-
 parquet/arrow/arrow_reader/trait.RowGroups.html    |   2 +-
 .../type.ParquetRecordBatchReaderBuilder.html      |   2 +-
 .../byte_array/enum.FallbackEncoderImpl.html       |  12 +-
 .../byte_array/fn.compute_min_max.html             |   2 +-
 .../arrow/arrow_writer/byte_array/fn.encode.html   |   2 +-
 parquet/arrow/arrow_writer/byte_array/index.html   |   4 +-
 .../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        |  12 +-
 .../byte_array/struct.ByteArrayStorage.html        |  12 +-
 .../byte_array/struct.DictEncoder.html             |  12 +-
 .../byte_array/struct.FallbackEncoder.html         |  12 +-
 .../arrow_writer/enum.ArrowColumnWriterImpl.html   |  14 +-
 parquet/arrow/arrow_writer/fn.compute_leaves.html  |   4 +-
 .../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      |   4 +-
 parquet/arrow/arrow_writer/fn.write_primitive.html |   4 +-
 parquet/arrow/arrow_writer/index.html              |   8 +-
 .../arrow_writer/levels/enum.LevelInfoBuilder.html |  12 +-
 .../levels/fn.calculate_array_levels.html          |   2 +-
 parquet/arrow/arrow_writer/levels/fn.is_leaf.html  |   2 +-
 parquet/arrow/arrow_writer/levels/index.html       |   6 +-
 .../arrow_writer/levels/struct.ArrayLevels.html    |  12 +-
 .../arrow_writer/levels/struct.LevelContext.html   |  12 +-
 parquet/arrow/arrow_writer/sidebar-items.js        |   2 +-
 .../arrow_writer/struct.ArrowColumnChunk.html      |  18 +-
 .../arrow_writer/struct.ArrowColumnChunkData.html  |  16 +-
 .../struct.ArrowColumnChunkReader.html             |  16 +-
 .../arrow_writer/struct.ArrowColumnWriter.html     |  22 +-
 .../arrow/arrow_writer/struct.ArrowLeafColumn.html |  16 +-
 .../arrow/arrow_writer/struct.ArrowPageWriter.html |  18 +-
 .../arrow_writer/struct.ArrowRowGroupWriter.html   |  18 +-
 parquet/arrow/arrow_writer/struct.ArrowWriter.html |  42 +-
 .../struct.ArrowWriterOptions.html}                |  35 +-
 .../arrow/arrow_writer/type.SharedColumnChunk.html |   4 +-
 .../arrow/async_reader/enum.ColumnChunkData.html   |  12 +-
 parquet/arrow/async_reader/enum.StreamState.html   |  12 +-
 .../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     |   4 +-
 .../metadata/struct.MetadataFetchFn.html           |  12 +-
 .../metadata/struct.MetadataLoader.html            |  12 +-
 .../async_reader/metadata/trait.MetadataFetch.html |   2 +-
 parquet/arrow/async_reader/store/index.html        |   4 +-
 .../store/struct.ParquetObjectReader.html          |  12 +-
 .../async_reader/struct.ColumnChunkIterator.html   |  14 +-
 .../async_reader/struct.InMemoryRowGroup.html      |  12 +-
 .../arrow/async_reader/struct.MetadataLoader.html  |  12 +-
 .../async_reader/struct.ParquetObjectReader.html   |  12 +-
 .../struct.ParquetRecordBatchStream.html           |  12 +-
 .../arrow/async_reader/struct.ReaderFactory.html   |  12 +-
 .../arrow/async_reader/trait.AsyncFileReader.html  |   2 +-
 .../arrow/async_reader/trait.MetadataFetch.html    |   2 +-
 .../type.ParquetRecordBatchStreamBuilder.html      |   2 +-
 parquet/arrow/async_reader/type.ReadResult.html    |   2 +-
 parquet/arrow/async_writer/index.html              |   6 +-
 .../async_writer/struct.AsyncArrowWriter.html      |  35 +-
 .../arrow/async_writer/struct.SharedBuffer.html    |  16 +-
 .../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           |   4 +-
 .../dictionary_buffer/enum.DictionaryBuffer.html   |  14 +-
 parquet/arrow/buffer/dictionary_buffer/index.html  |   4 +-
 parquet/arrow/buffer/index.html                    |   4 +-
 parquet/arrow/buffer/offset_buffer/index.html      |   4 +-
 .../buffer/offset_buffer/struct.OffsetBuffer.html  |  12 +-
 parquet/arrow/constant.ARROW_SCHEMA_META_KEY.html  |   2 +-
 .../arrow/constant.PARQUET_FIELD_ID_META_KEY.html  |   2 +-
 parquet/arrow/decoder/delta_byte_array/index.html  |   4 +-
 .../struct.DeltaByteArrayDecoder.html              |  12 +-
 parquet/arrow/decoder/dictionary_index/index.html  |   4 +-
 .../dictionary_index/struct.DictIndexDecoder.html  |  12 +-
 parquet/arrow/decoder/index.html                   |   4 +-
 parquet/arrow/fn.arrow_to_parquet_schema.html      |   2 +-
 .../arrow/fn.parquet_to_arrow_field_levels.html    |   2 +-
 parquet/arrow/fn.parquet_to_arrow_schema.html      |   2 +-
 .../fn.parquet_to_arrow_schema_by_columns.html     |   2 +-
 parquet/arrow/index.html                           |  12 +-
 parquet/arrow/record_reader/buffer/index.html      |   4 +-
 .../record_reader/buffer/trait.ValuesBuffer.html   |   2 +-
 .../definition_levels/enum.BufferInner.html        |  12 +-
 .../definition_levels/enum.MaybePacked.html        |  12 +-
 .../record_reader/definition_levels/index.html     |   6 +-
 .../struct.DefinitionLevelBuffer.html              |  12 +-
 .../struct.DefinitionLevelBufferDecoder.html       |  12 +-
 .../definition_levels/struct.PackedDecoder.html    |  12 +-
 .../arrow/record_reader/fn.packed_null_mask.html   |   2 +-
 parquet/arrow/record_reader/index.html             |   6 +-
 .../record_reader/struct.GenericRecordReader.html  |  16 +-
 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           |  12 +-
 parquet/basic/enum.ColumnOrder.html                |  12 +-
 parquet/basic/enum.Compression.html                |  12 +-
 parquet/basic/enum.ConvertedType.html              |  14 +-
 parquet/basic/enum.Encoding.html                   |  12 +-
 parquet/basic/enum.LogicalType.html                |  12 +-
 parquet/basic/enum.PageType.html                   |  12 +-
 parquet/basic/enum.Repetition.html                 |  14 +-
 parquet/basic/enum.SortOrder.html                  |  14 +-
 parquet/basic/enum.Type.html                       |  12 +-
 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                           |   6 +-
 parquet/basic/struct.BrotliLevel.html              |  12 +-
 parquet/basic/struct.GzipLevel.html                |  12 +-
 parquet/basic/struct.ZstdLevel.html                |  12 +-
 .../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                    |   6 +-
 parquet/bloom_filter/struct.Block.html             |  12 +-
 parquet/bloom_filter/struct.Sbbf.html              |  12 +-
 parquet/column/index.html                          |   6 +-
 parquet/column/page/enum.Page.html                 |  12 +-
 parquet/column/page/index.html                     |   6 +-
 parquet/column/page/struct.CompressedPage.html     |  12 +-
 parquet/column/page/struct.PageMetadata.html       |  12 +-
 parquet/column/page/struct.PageWriteSpec.html      |  12 +-
 parquet/column/page/trait.PageIterator.html        |   2 +-
 parquet/column/page/trait.PageReader.html          |   2 +-
 parquet/column/page/trait.PageWriter.html          |   4 +-
 .../constant.REPETITION_LEVELS_BATCH_SIZE.html     |   2 +-
 .../reader/decoder/constant.SKIP_BUFFER_SIZE.html  |   2 +-
 .../column/reader/decoder/enum.LevelDecoder.html   |  12 +-
 parquet/column/reader/decoder/index.html           |   4 +-
 .../decoder/struct.ColumnValueDecoderImpl.html     |  12 +-
 .../decoder/struct.DefinitionLevelDecoderImpl.html |  12 +-
 .../decoder/struct.RepetitionLevelDecoderImpl.html |  12 +-
 .../reader/decoder/trait.ColumnLevelDecoder.html   |   2 +-
 .../reader/decoder/trait.ColumnValueDecoder.html   |   4 +-
 .../decoder/trait.DefinitionLevelDecoder.html      |   4 +-
 .../decoder/trait.RepetitionLevelDecoder.html      |   4 +-
 parquet/column/reader/enum.ColumnReader.html       |  12 +-
 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                   |   6 +-
 .../column/reader/struct.GenericColumnReader.html  |  14 +-
 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           |   6 +-
 .../encoder/struct.ColumnValueEncoderImpl.html     |  12 +-
 .../writer/encoder/struct.DataPageValues.html      |  12 +-
 .../writer/encoder/struct.DictionaryPage.html      |  12 +-
 .../writer/encoder/trait.ColumnValueEncoder.html   |   2 +-
 .../column/writer/encoder/trait.ColumnValues.html  |   2 +-
 parquet/column/writer/enum.ColumnWriter.html       |  12 +-
 parquet/column/writer/enum.Level.html              |  12 +-
 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                   |   8 +-
 parquet/column/writer/macro.downcast_writer.html   |   2 +-
 .../column/writer/struct.ColumnCloseResult.html    |  12 +-
 parquet/column/writer/struct.ColumnMetrics.html    |  12 +-
 .../column/writer/struct.GenericColumnWriter.html  |  12 +-
 parquet/column/writer/struct.PageMetrics.html      |  12 +-
 .../column/writer/trait.EncodingWriteSupport.html  |   2 +-
 parquet/column/writer/type.ColumnWriterImpl.html   |   2 +-
 parquet/data_type/enum.Decimal.html                |  12 +-
 parquet/data_type/index.html                       |   6 +-
 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               |   4 +-
 parquet/data_type/private/macro.impl_from_raw.html |   2 +-
 .../data_type/private/trait.ParquetValueType.html  |   2 +-
 parquet/data_type/struct.BoolType.html             |  12 +-
 parquet/data_type/struct.ByteArray.html            |  28 +-
 parquet/data_type/struct.ByteArrayType.html        |  12 +-
 parquet/data_type/struct.DoubleType.html           |  12 +-
 parquet/data_type/struct.FixedLenByteArray.html    |  24 +-
 .../data_type/struct.FixedLenByteArrayType.html    |  12 +-
 parquet/data_type/struct.FloatType.html            |  12 +-
 parquet/data_type/struct.Int32Type.html            |  12 +-
 parquet/data_type/struct.Int64Type.html            |  12 +-
 parquet/data_type/struct.Int96.html                |  12 +-
 parquet/data_type/struct.Int96Type.html            |  12 +-
 parquet/data_type/trait.AsBytes.html               |   4 +-
 parquet/data_type/trait.DataType.html              |   2 +-
 parquet/data_type/trait.SliceAsBytes.html          |   4 +-
 parquet/data_type/trait.SliceAsBytesDataType.html  |   2 +-
 parquet/errors/enum.ParquetError.html              |  14 +-
 parquet/errors/index.html                          |   4 +-
 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                     |   4 +-
 parquet/file/index.html                            |  12 +-
 parquet/file/metadata/index.html                   |   4 +-
 .../file/metadata/struct.ColumnChunkMetaData.html  |  12 +-
 .../struct.ColumnChunkMetaDataBuilder.html         |  12 +-
 .../file/metadata/struct.ColumnIndexBuilder.html   |  12 +-
 parquet/file/metadata/struct.FileMetaData.html     |  12 +-
 .../file/metadata/struct.OffsetIndexBuilder.html   |  12 +-
 parquet/file/metadata/struct.ParquetMetaData.html  |  12 +-
 parquet/file/metadata/struct.RowGroupMetaData.html |  12 +-
 .../metadata/struct.RowGroupMetaDataBuilder.html   |  12 +-
 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        |   4 +-
 .../struct.PageEncodingStats.html                  |  12 +-
 parquet/file/page_index/index.html                 |   4 +-
 parquet/file/page_index/index/enum.Index.html      |  12 +-
 parquet/file/page_index/index/index.html           |   4 +-
 .../file/page_index/index/struct.NativeIndex.html  |  12 +-
 .../file/page_index/index/struct.PageIndex.html    |  12 +-
 .../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    |   4 +-
 .../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    |  12 +-
 parquet/file/properties/enum.WriterVersion.html    |  12 +-
 parquet/file/properties/index.html                 |   6 +-
 .../properties/struct.BloomFilterProperties.html   |  12 +-
 .../file/properties/struct.ColumnProperties.html   |  14 +-
 .../file/properties/struct.ReaderProperties.html   |  14 +-
 .../properties/struct.ReaderPropertiesBuilder.html |  12 +-
 .../file/properties/struct.WriterProperties.html   |  14 +-
 .../properties/struct.WriterPropertiesBuilder.html |  12 +-
 .../file/properties/type.ReaderPropertiesPtr.html  |   2 +-
 .../file/properties/type.WriterPropertiesPtr.html  |   2 +-
 parquet/file/reader/index.html                     |   4 +-
 parquet/file/reader/struct.FilePageIterator.html   |  14 +-
 parquet/file/reader/trait.ChunkReader.html         |   4 +-
 parquet/file/reader/trait.FileReader.html          |   2 +-
 parquet/file/reader/trait.Length.html              |   4 +-
 parquet/file/reader/trait.RowGroupReader.html      |   2 +-
 .../enum.SerializedPageReaderState.html            |  12 +-
 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          |   6 +-
 .../file/serialized_reader/struct.ReadOptions.html |  12 +-
 .../struct.ReadOptionsBuilder.html                 |  12 +-
 .../struct.SerializedFileReader.html               |  14 +-
 .../struct.SerializedPageReader.html               |  14 +-
 .../struct.SerializedRowGroupReader.html           |  12 +-
 .../serialized_reader/type.ReadGroupPredicate.html |   2 +-
 parquet/file/statistics/enum.Statistics.html       |  14 +-
 parquet/file/statistics/fn.from_thrift.html        |   2 +-
 parquet/file/statistics/fn.to_thrift.html          |   2 +-
 parquet/file/statistics/index.html                 |   4 +-
 .../statistics/macro.statistics_enum_func.html     |   2 +-
 .../file/statistics/macro.statistics_new_func.html |   2 +-
 parquet/file/statistics/private/index.html         |   4 +-
 .../private/macro.gen_make_statistics.html         |   2 +-
 .../statistics/private/trait.MakeStatistics.html   |   2 +-
 .../file/statistics/struct.ValueStatistics.html    |  14 +-
 parquet/file/statistics/type.TypedStatistics.html  |   2 +-
 parquet/file/writer/index.html                     |   6 +-
 .../file/writer/struct.SerializedColumnWriter.html |  12 +-
 .../file/writer/struct.SerializedFileWriter.html   |  12 +-
 .../file/writer/struct.SerializedPageWriter.html   |  12 +-
 .../writer/struct.SerializedRowGroupWriter.html    |  12 +-
 parquet/file/writer/struct.TrackedWrite.html       |  12 +-
 parquet/file/writer/type.OnCloseColumnChunk.html   |   2 +-
 parquet/file/writer/type.OnCloseRowGroup.html      |   2 +-
 parquet/format/enum.BloomFilterAlgorithm.html      |  12 +-
 parquet/format/enum.BloomFilterCompression.html    |  12 +-
 parquet/format/enum.BloomFilterHash.html           |  12 +-
 parquet/format/enum.ColumnCryptoMetaData.html      |  12 +-
 parquet/format/enum.ColumnOrder.html               |  12 +-
 parquet/format/enum.EncryptionAlgorithm.html       |  12 +-
 parquet/format/enum.LogicalType.html               |  12 +-
 parquet/format/enum.TimeUnit.html                  |  12 +-
 parquet/format/index.html                          |   6 +-
 parquet/format/struct.AesGcmCtrV1.html             |  12 +-
 parquet/format/struct.AesGcmV1.html                |  12 +-
 parquet/format/struct.BloomFilterHeader.html       |  12 +-
 parquet/format/struct.BoundaryOrder.html           |  14 +-
 parquet/format/struct.BsonType.html                |  12 +-
 parquet/format/struct.ColumnChunk.html             |  12 +-
 parquet/format/struct.ColumnIndex.html             |  12 +-
 parquet/format/struct.ColumnMetaData.html          |  12 +-
 parquet/format/struct.CompressionCodec.html        |  14 +-
 parquet/format/struct.ConvertedType.html           |  14 +-
 parquet/format/struct.DataPageHeader.html          |  12 +-
 parquet/format/struct.DataPageHeaderV2.html        |  12 +-
 parquet/format/struct.DateType.html                |  12 +-
 parquet/format/struct.DecimalType.html             |  12 +-
 parquet/format/struct.DictionaryPageHeader.html    |  12 +-
 parquet/format/struct.Encoding.html                |  14 +-
 parquet/format/struct.EncryptionWithColumnKey.html |  12 +-
 parquet/format/struct.EncryptionWithFooterKey.html |  12 +-
 parquet/format/struct.EnumType.html                |  12 +-
 parquet/format/struct.FieldRepetitionType.html     |  14 +-
 parquet/format/struct.FileCryptoMetaData.html      |  12 +-
 parquet/format/struct.FileMetaData.html            |  12 +-
 parquet/format/struct.Float16Type.html             |  12 +-
 parquet/format/struct.IndexPageHeader.html         |  12 +-
 parquet/format/struct.IntType.html                 |  12 +-
 parquet/format/struct.JsonType.html                |  12 +-
 parquet/format/struct.KeyValue.html                |  12 +-
 parquet/format/struct.ListType.html                |  12 +-
 parquet/format/struct.MapType.html                 |  12 +-
 parquet/format/struct.MicroSeconds.html            |  12 +-
 parquet/format/struct.MilliSeconds.html            |  12 +-
 parquet/format/struct.NanoSeconds.html             |  12 +-
 parquet/format/struct.NullType.html                |  12 +-
 parquet/format/struct.OffsetIndex.html             |  12 +-
 parquet/format/struct.PageEncodingStats.html       |  12 +-
 parquet/format/struct.PageHeader.html              |  12 +-
 parquet/format/struct.PageLocation.html            |  12 +-
 parquet/format/struct.PageType.html                |  14 +-
 parquet/format/struct.RowGroup.html                |  12 +-
 parquet/format/struct.SchemaElement.html           |  12 +-
 parquet/format/struct.SortingColumn.html           |  12 +-
 parquet/format/struct.SplitBlockAlgorithm.html     |  12 +-
 parquet/format/struct.Statistics.html              |  12 +-
 parquet/format/struct.StringType.html              |  12 +-
 parquet/format/struct.TimeType.html                |  12 +-
 parquet/format/struct.TimestampType.html           |  12 +-
 parquet/format/struct.Type.html                    |  14 +-
 parquet/format/struct.TypeDefinedOrder.html        |  12 +-
 parquet/format/struct.UUIDType.html                |  12 +-
 parquet/format/struct.Uncompressed.html            |  12 +-
 parquet/format/struct.XxHash.html                  |  12 +-
 parquet/index.html                                 |  16 +-
 parquet/macro.experimental.html                    |   2 +-
 parquet/record/api/enum.Field.html                 |  12 +-
 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                      |   8 +-
 .../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                |  12 +-
 parquet/record/api/struct.Map.html                 |  12 +-
 parquet/record/api/struct.MapList.html             |  12 +-
 parquet/record/api/struct.Row.html                 |  16 +-
 parquet/record/api/struct.RowColumnIter.html       |  14 +-
 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         |   4 +-
 parquet/record/enum.Field.html                     |  12 +-
 parquet/record/index.html                          |   6 +-
 .../record/reader/constant.DEFAULT_BATCH_SIZE.html |   2 +-
 parquet/record/reader/enum.Either.html             |  12 +-
 parquet/record/reader/enum.Reader.html             |  12 +-
 parquet/record/reader/index.html                   |   8 +-
 parquet/record/reader/struct.ReaderIter.html       |  14 +-
 parquet/record/reader/struct.RowIter.html          |  16 +-
 parquet/record/reader/struct.TreeBuilder.html      |  12 +-
 parquet/record/record_reader/index.html            |   4 +-
 .../record/record_reader/trait.RecordReader.html   |   2 +-
 parquet/record/record_writer/index.html            |   4 +-
 .../record/record_writer/trait.RecordWriter.html   |   2 +-
 parquet/record/struct.List.html                    |  12 +-
 parquet/record/struct.Map.html                     |  12 +-
 parquet/record/struct.Row.html                     |  16 +-
 parquet/record/struct.RowColumnIter.html           |  14 +-
 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             |   4 +-
 parquet/record/triplet/enum.TripletIter.html       |  12 +-
 parquet/record/triplet/index.html                  |   8 +-
 .../record/triplet/macro.triplet_enum_func.html    |   2 +-
 .../record/triplet/struct.TypedTripletIter.html    |  12 +-
 parquet/schema/index.html                          |   6 +-
 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                   |   8 +-
 parquet/schema/parser/struct.Parser.html           |  12 +-
 parquet/schema/parser/struct.Tokenizer.html        |  14 +-
 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                  |   6 +-
 parquet/schema/printer/struct.Printer.html         |  12 +-
 parquet/schema/types/enum.Type.html                |  12 +-
 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                    |  10 +-
 parquet/schema/types/struct.BasicTypeInfo.html     |  12 +-
 parquet/schema/types/struct.ColumnDescriptor.html  |  12 +-
 parquet/schema/types/struct.ColumnPath.html        |  14 +-
 parquet/schema/types/struct.GroupTypeBuilder.html  |  12 +-
 .../schema/types/struct.PrimitiveTypeBuilder.html  |  12 +-
 parquet/schema/types/struct.SchemaDescriptor.html  |  12 +-
 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                  |   4 +-
 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                          |   4 +-
 .../thrift/struct.TCompactSliceInputProtocol.html  |  12 +-
 parquet/thrift/trait.TSerializable.html            |   2 +-
 parquet_concat/all.html                            |   2 +-
 parquet_concat/fn.main.html                        |   2 +-
 parquet_concat/index.html                          |   6 +-
 parquet_concat/struct.Args.html                    |  12 +-
 parquet_derive/all.html                            |   2 +-
 parquet_derive/derive.ParquetRecordReader.html     |   2 +-
 parquet_derive/derive.ParquetRecordWriter.html     |   2 +-
 parquet_derive/index.html                          |   4 +-
 .../parquet_field/enum.ThirdPartyType.html         |  12 +-
 parquet_derive/parquet_field/enum.Type.html        |  12 +-
 parquet_derive/parquet_field/index.html            |   4 +-
 parquet_derive/parquet_field/struct.Field.html     |  12 +-
 parquet_derive_test/all.html                       |   2 +-
 parquet_derive_test/index.html                     |   4 +-
 parquet_derive_test/struct.ACompleteRecord.html    |  12 +-
 .../struct.APartiallyCompleteRecord.html           |  12 +-
 parquet_fromcsv/all.html                           |   2 +-
 parquet_fromcsv/enum.CsvDialect.html               |  12 +-
 parquet_fromcsv/enum.ParquetFromCsvError.html      |  14 +-
 parquet_fromcsv/enum.RecordTerminator.html         |  12 +-
 parquet_fromcsv/fn.arrow_schema_from_string.html   |   2 +-
 parquet_fromcsv/fn.compression_from_str.html       |   2 +-
 parquet_fromcsv/fn.configure_reader_builder.html   |   2 +-
 .../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                         |  12 +-
 parquet_fromcsv/struct.Args.html                   |  12 +-
 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                           |   6 +-
 parquet_index/struct.Args.html                     |  12 +-
 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                          |   6 +-
 parquet_layout/struct.Args.html                    |  12 +-
 parquet_layout/struct.ColumnChunk.html             |  12 +-
 parquet_layout/struct.Page.html                    |  12 +-
 parquet_layout/struct.ParquetFile.html             |  12 +-
 parquet_layout/struct.RowGroup.html                |  12 +-
 parquet_read/all.html                              |   2 +-
 parquet_read/fn.main.html                          |   2 +-
 parquet_read/fn.print_row.html                     |   2 +-
 parquet_read/index.html                            |   6 +-
 parquet_read/struct.Args.html                      |  12 +-
 parquet_rewrite/all.html                           |   2 +-
 parquet_rewrite/enum.CompressionArgs.html          |  12 +-
 parquet_rewrite/enum.EnabledStatisticsArgs.html    |  12 +-
 parquet_rewrite/enum.WriterVersionArgs.html        |  12 +-
 parquet_rewrite/fn.main.html                       |   2 +-
 parquet_rewrite/index.html                         |   6 +-
 parquet_rewrite/struct.Args.html                   |  12 +-
 parquet_rowcount/all.html                          |   2 +-
 parquet_rowcount/fn.main.html                      |   2 +-
 parquet_rowcount/index.html                        |   6 +-
 parquet_rowcount/struct.Args.html                  |  12 +-
 parquet_schema/all.html                            |   2 +-
 parquet_schema/fn.main.html                        |   2 +-
 parquet_schema/index.html                          |   6 +-
 parquet_schema/struct.Args.html                    |  12 +-
 parquet_show_bloom_filter/all.html                 |   2 +-
 parquet_show_bloom_filter/fn.main.html             |   2 +-
 parquet_show_bloom_filter/index.html               |   6 +-
 parquet_show_bloom_filter/struct.Args.html         |  12 +-
 search-index.js                                    |  34 +-
 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 +-
 .../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         | 170 +++-
 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         |  46 +-
 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 +-
 ...2b497cc83f.css => rustdoc-b1a3e7f8283b8434.css} |   2 +-
 .../record_batch/trait.RecordBatchReader.js        |   2 +-
 .../record_batch/trait.RecordBatchWriter.js        |   2 +-
 .../flight_service_server/trait.FlightService.js   |   2 +-
 trait.impl/clap_builder/derive/trait.Args.js       |   2 +-
 .../clap_builder/derive/trait.CommandFactory.js    |   2 +-
 .../clap_builder/derive/trait.FromArgMatches.js    |   2 +-
 trait.impl/core/clone/trait.Clone.js               |  34 +-
 trait.impl/core/cmp/trait.Eq.js                    |  16 +-
 trait.impl/core/cmp/trait.Ord.js                   |  12 +-
 trait.impl/core/cmp/trait.PartialEq.js             |  24 +-
 trait.impl/core/cmp/trait.PartialOrd.js            |  10 +-
 trait.impl/core/convert/trait.AsRef.js             |   4 +-
 trait.impl/core/convert/trait.From.js              |  18 +-
 trait.impl/core/convert/trait.TryFrom.js           |   6 +-
 trait.impl/core/default/trait.Default.js           |  22 +-
 trait.impl/core/fmt/trait.Debug.js                 |  42 +-
 trait.impl/core/fmt/trait.Display.js               |   8 +-
 trait.impl/core/hash/trait.Hash.js                 |  12 +-
 .../core/iter/traits/collect/trait.Extend.js       |   6 +-
 .../core/iter/traits/collect/trait.FromIterator.js |   6 +-
 .../core/iter/traits/collect/trait.IntoIterator.js |   6 +-
 .../double_ended/trait.DoubleEndedIterator.js      |   2 +-
 .../core/iter/traits/iterator/trait.Iterator.js    |   8 +-
 trait.impl/core/marker/trait.Copy.js               |  20 +-
 trait.impl/core/marker/trait.Freeze.js             |   2 +-
 trait.impl/core/marker/trait.Send.js               |   4 +-
 trait.impl/core/marker/trait.StructuralEq.js       |  16 +-
 .../core/marker/trait.StructuralPartialEq.js       |  22 +-
 trait.impl/core/marker/trait.Sync.js               |   4 +-
 trait.impl/core/marker/trait.Unpin.js              |   2 +-
 trait.impl/core/ops/arith/trait.Add.js             |   2 +-
 trait.impl/core/ops/arith/trait.Div.js             |   2 +-
 trait.impl/core/ops/arith/trait.Mul.js             |   2 +-
 trait.impl/core/ops/arith/trait.Rem.js             |   2 +-
 trait.impl/core/ops/bit/trait.BitXor.js            |   2 +-
 trait.impl/core/ops/deref/trait.Deref.js           |   2 +-
 trait.impl/core/ops/deref/trait.DerefMut.js        |   2 +-
 trait.impl/core/ops/drop/trait.Drop.js             |   2 +-
 .../core/panic/unwind_safe/trait.RefUnwindSafe.js  |   2 +-
 .../core/panic/unwind_safe/trait.UnwindSafe.js     |   2 +-
 trait.impl/core/str/traits/trait.FromStr.js        |   2 +-
 .../endian_scalar/trait.EndianScalar.js            |   2 +-
 trait.impl/flatbuffers/follow/trait.Follow.js      |   2 +-
 trait.impl/flatbuffers/push/trait.Push.js          |   2 +-
 .../verifier/trait.SimpleToVerifyInSlice.js        |   2 +-
 .../flatbuffers/verifier/trait.Verifiable.js       |   2 +-
 trait.impl/futures_core/stream/trait.Stream.js     |   2 +-
 trait.impl/num_traits/cast/trait.AsPrimitive.js    |   2 +-
 trait.impl/prost/message/trait.Message.js          |   2 +-
 trait.impl/pyo3/conversion/trait.IntoPy.js         |   2 +-
 trait.impl/serde/de/trait.Deserialize.js           |   6 +-
 trait.impl/serde/ser/trait.Serialize.js            |   8 +-
 trait.impl/std/io/trait.Write.js                   |   2 +-
 type.impl/alloc/boxed/struct.Box.js                |  16 +-
 type.impl/alloc/sync/struct.Arc.js                 |  12 +-
 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 +-
 type.impl/arrow/pyarrow/struct.ArrowException.js   |   2 +-
 .../array/binary_array/type.GenericBinaryArray.js  |   2 +-
 .../array/byte_array/struct.GenericByteArray.js    |   2 +-
 .../dictionary_array/struct.DictionaryArray.js     |   2 +-
 .../array/list_array/struct.GenericListArray.js    |   2 +-
 .../array/primitive_array/struct.PrimitiveArray.js |   2 +-
 .../arrow_array/array/run_array/struct.RunArray.js |   2 +-
 .../array/string_array/type.GenericStringArray.js  |   2 +-
 .../struct.GenericByteRunBuilder.js                |   2 +-
 .../struct.GenericByteBuilder.js                   |   2 +-
 .../struct.GenericByteDictionaryBuilder.js         |   2 +-
 .../struct.GenericListBuilder.js                   |   2 +-
 .../primitive_builder/struct.PrimitiveBuilder.js   |   2 +-
 .../arrow_array/builder/struct.BufferBuilder.js    |   2 +-
 type.impl/arrow_array/iterator/struct.ArrayIter.js |   2 +-
 .../arrow_array/types/struct.GenericStringType.js  |   2 +-
 type.impl/arrow_csv/reader/struct.BufReader.js     |   2 +-
 type.impl/core/iter/adapters/chain/struct.Chain.js |   4 +-
 type.impl/core/option/enum.Option.js               |   4 +-
 type.impl/core/pin/struct.Pin.js                   |   2 +-
 type.impl/core/result/enum.Result.js               |  14 +-
 .../record_reader/struct.GenericRecordReader.js    |   2 +-
 .../column/reader/struct.GenericColumnReader.js    |   2 +-
 .../file/statistics/struct.ValueStatistics.js      |   2 +-
 type.impl/parquet/format/struct.KeyValue.js        |   2 +-
 4467 files changed, 17181 insertions(+), 17939 deletions(-)

diff --git a/arrow/all.html b/arrow/all.html
index c296970d9f..c734092fb6 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 5f50d44899..e42056649e 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 4cdb2a0132..4bd92d90a5 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 [...]
+<!DOCTYPE html><html lang="en"><head><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"><a href="#constants">Constants</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"><a href="#traits">Traits</a></h2><ul class="item-table"><li><div class="item-name"><a class="trait" hr [...]
+</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 5f67ba433a..bcffcba46c 100644
--- a/arrow/alloc/trait.Allocation.html
+++ b/arrow/alloc/trait.Allocation.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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= [...]
diff --git a/arrow/array/array/fn.make_array.html b/arrow/array/array/fn.make_array.html
index 8f2befd9dc..c285a8d09e 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 34c94599cb..9a544f1a2f 100644
--- a/arrow/array/array/fn.new_empty_array.html
+++ b/arrow/array/array/fn.new_empty_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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;
diff --git a/arrow/array/array/fn.new_null_array.html b/arrow/array/array/fn.new_null_array.html
index bd9a53f21f..f24c1df7b6 100644
--- a/arrow/array/array/fn.new_null_array.html
+++ b/arrow/array/array/fn.new_null_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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
 
diff --git a/arrow/array/array/index.html b/arrow/array/array/index.html
index d3f0d6e9e8..e62ff17504 100644
--- a/arrow/array/array/index.html
+++ b/arrow/array/array/index.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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"><a href="#structs">Structs</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="struct.Dictionar [...]
+</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 [...]
-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>.</div></li><li><div class="item-name"><a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::array::OffsetSizeTrait">OffsetSizeTrait</a> [...]
+(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 [...]
+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>.</div></li><li><div class="item-name"><a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::array::OffsetSizeTrait">OffsetSizeTrait</a> [...]
 Returns a reference-counted <code>Array</code> instance.</div></li><li><div class="item-name"><a class="fn" href="fn.new_empty_array.html" title="fn arrow::array::array::new_empty_array">new_empty_array</a></div><div class="desc docblock-short">Creates a new empty array</div></li><li><div class="item-name"><a class="fn" href="fn.new_null_array.html" title="fn arrow::array::array::new_null_array">new_null_array</a></div><div class="desc docblock-short">Creates a new array of <code>data_ty [...]
-entirely of <code>NULL</code> values</div></li></ul><h2 id="types" class="section-header"><a href="#types">Type Aliases</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.ArrayRef.html" title="type arrow::array::array::ArrayRef">ArrayRef</a></div><div class="desc docblock-short">A reference-counted reference to a generic <code>Array</code></div></li><li><div class="item-name"><a class="type" href="type.BinaryArray.html" title="type arrow::array::array::B [...]
\ No newline at end of file
+entirely of <code>NULL</code> values</div></li></ul><h2 id="types" class="section-header">Type Aliases<a href="#types" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.ArrayRef.html" title="type arrow::array::array::ArrayRef">ArrayRef</a></div><div class="desc docblock-short">A reference-counted reference to a generic <code>Array</code></div></li><li><div class="item-name"><a class="type" href="type.BinaryArray.html" title="type arrow: [...]
\ No newline at end of file
diff --git a/arrow/array/array/struct.BooleanArray.html b/arrow/array/array/struct.BooleanArray.html
index 4ac46ab7d5..130b9c7b58 100644
--- a/arrow/array/array/struct.BooleanArray.html
+++ b/arrow/array/array/struct.BooleanArray.html
@@ -1,17 +1,17 @@
-<!DOCTYPE html><html lang="en"><head><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=" [...]
+<!DOCTYPE html><html lang="en"><head><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>
-<h2 id="example-from-a-vec"><a href="#example-from-a-vec">Example: From a Vec</a></h2>
+<h2 id="example-from-a-vec"><a class="doc-anchor" href="#example-from-a-vec">§</a>Example: From a Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: BooleanArray = <span class="macro">vec!</span>[<span class="bool-val">true</span>, <span class="bool-val">true</span>, <span class="bool-val">false</span>].into();</code></pre></div>
-<h2 id="example-from-an-optional-vec"><a href="#example-from-an-optional-vec">Example: From an optional Vec</a></h2>
+<h2 id="example-from-an-optional-vec"><a class="doc-anchor" href="#example-from-an-optional-vec">§</a>Example: From an optional Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: BooleanArray = <span class="macro">vec!</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>)].into();</code></pre></div>
-<h2 id="example-from-an-iterator"><a href="#example-from-an-iterator">Example: From an iterator</a></h2>
+<h2 id="example-from-an-iterator"><a class="doc-anchor" href="#example-from-an-iterator">§</a>Example: From an iterator</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: BooleanArray = (<span class="number">0</span>..<span class="number">5</span>).map(|x| (x % <span class="number">2 </span>== <span class="number">0</span>).then(|| x % <span class="number">3 </span>== <span class="number">0</span>)).collect();
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = arr.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>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="bool-val">false</span>)])</code></pre></div>
-<h2 id="example-using-builder"><a href="#example-using-builder">Example: Using Builder</a></h2>
+<h2 id="example-using-builder"><a class="doc-anchor" href="#example-using-builder">§</a>Example: Using Builder</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>builder = BooleanBuilder::new();
 builder.append_value(<span class="bool-val">true</span>);
 builder.append_null();
@@ -20,7 +20,7 @@ builder.append_value(<span class="bool-val">false</span>);
 <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  [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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"> [...]
@@ -32,10 +32,10 @@ builder.append_value(<span class="bool-val">false</span>);
 </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 [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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;(
     &amp;'a self,
@@ -45,7 +45,7 @@ builder.append_value(<span class="bool-val">false</span>);
     &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 href="#safety-1">Safety</a></h5>
+<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
     T: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
@@ -67,7 +67,7 @@ each element of the provided arrays</p>
 <span class="kw">let </span>b = Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">0</span>, <span class="number">2</span>, <span class="number">5</span>]);
 <span class="kw">let </span>r = BooleanArray::from_binary(<span class="kw-2">&amp;</span>a, <span class="kw-2">&amp;</span>b, |a, b| a == b);
 <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 href="#panics-2">Panics</a></h5>
+<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 [...]
@@ -81,7 +81,7 @@ includes the overhead of the data structures that contain the pointers to the va
 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 [...]
     &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 [...]
+) -&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#242">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= [...]
@@ -89,15 +89,15 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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: <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 2cdfc246e5..cfc82701b1 100644
--- a/arrow/array/array/struct.DictionaryArray.html
+++ b/arrow/array/array/struct.DictionaryArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -32,15 +32,15 @@ the corresponding logical value, as shown here:</p>
                                                Contents
           DictionaryArray
              length = 6
-</code></pre></div><h2 id="example-from-nullable-data"><a href="#example-from-nullable-data">Example: From Nullable Data</a></h2>
+</code></pre></div><h2 id="example-from-nullable-data"><a class="doc-anchor" href="#example-from-nullable-data">§</a>Example: From Nullable Data</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><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="kw">let </span>array : DictionaryArray&lt;Int8Type&gt; = test.iter().map(|<span class="kw-2">&amp;</span>x| <span class="kw">if </span>x == <span class="string">"b" </span>{<span class="prelude-val">None</span>} <span class="kw">else </span>{<span class="prelude-val">Some</span>(x)}).collect();
 <span class="macro">assert_eq!</span>(array.keys(), <span class="kw-2">&amp;</span>Int8Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">0</span>), <span class="prelude-val">Some</span>(<span class="number">0</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="number">1</span>)]));</code></pre></div>
-<h2 id="example-from-non-nullable-data"><a href="#example-from-non-nullable-data">Example: From Non-Nullable Data</a></h2>
+<h2 id="example-from-non-nullable-data"><a class="doc-anchor" href="#example-from-non-nullable-data">§</a>Example: From Non-Nullable Data</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><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="kw">let </span>array : DictionaryArray&lt;Int8Type&gt; = test.into_iter().collect();
 <span class="macro">assert_eq!</span>(array.keys(), <span class="kw-2">&amp;</span>Int8Array::from(<span class="macro">vec!</span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>]));</code></pre></div>
-<h2 id="example-from-existing-arrays"><a href="#example-from-existing-arrays">Example: From Existing Arrays</a></h2>
+<h2 id="example-from-existing-arrays"><a class="doc-anchor" href="#example-from-existing-arrays">§</a>Example: From Existing Arrays</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// You can form your own DictionaryArray by providing the
 // values (dictionary) and keys (indexes into the dictionary):
 </span><span class="kw">let </span>values = StringArray::from_iter_values([<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]);
@@ -48,7 +48,7 @@ the corresponding logical value, as shown here:</p>
 <span class="kw">let </span>array = DictionaryArray::&lt;Int8Type&gt;::try_new(keys, Arc::new(values)).unwrap();
 <span class="kw">let </span>expected: DictionaryArray::&lt;Int8Type&gt; = <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();
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>array, <span class="kw-2">&amp;</span>expected);</code></pre></div>
-<h2 id="example-using-builder"><a href="#example-using-builder">Example: Using Builder</a></h2>
+<h2 id="example-using-builder"><a class="doc-anchor" href="#example-using-builder">§</a>Example: Using Builder</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>builder = StringDictionaryBuilder::&lt;Int32Type&gt;::new();
 builder.append_value(<span class="string">"a"</span>);
 builder.append_null();
@@ -65,7 +65,7 @@ builder.append_value(<span class="string">"b"</span>);
 ) -&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
 (indexes into the dictionary) and values (dictionary)
 array.</p>
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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>(
     keys: <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;,
@@ -73,13 +73,13 @@ array.</p>
 ) -&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
 (indexes into the dictionary) and values (dictionary)
 array.</p>
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<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>(
     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 href="#safety">Safety</a></h5>
+<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 [...]
@@ -113,7 +113,7 @@ cast to <code>usize</code>, <code>None</code> if the value at <code>i</code> is
 </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 [...]
 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 href="#panics-1">Panics</a></h5>
+<h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>Panics if <code>values</code> has a length less than the current values</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -150,11 +150,11 @@ its keys and values if the underlying data buffer is not shared by others.</p>
     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;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; &lt;V as <a cla [...]
 Mutable dictionary array means that the buffers are not shared with other arrays.
 As a result, this mutates the buffers directly without allocating new buffers.</p>
-<h5 id="implementation"><a href="#implementation">Implementation</a></h5>
+<h5 id="implementation"><a class="doc-anchor" href="#implementation">§</a>Implementation</h5>
 <p>This will apply the function for all dictionary values, including those on null slots.
 This implies that the operation must be infallible for any value of the corresponding type
 or this function may panic.</p>
-<h5 id="example"><a href="#example">Example</a></h5>
+<h5 id="example"><a class="doc-anchor" href="#example">§</a>Example</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>values = Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">10</span>), <span class="prelude-val">Some</span>(<span class="number">20</span>), <span class="prelude-val">None</span>]);
 <span class="kw">let </span>keys = Int8Array::from_iter_values([<span class="number">0</span>, <span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>]);
 <span class="kw">let </span>dictionary = DictionaryArray::&lt;Int8Type&gt;::try_new(keys, Arc::new(values)).unwrap();
@@ -179,10 +179,10 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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  [...]
     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-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#571">source</a><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>(data: <a class="struct" href="../struct.ArrayData.html" title="struct arrow [...]
-    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" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#619">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">f [...]
+</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 [...]
     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-2"><a href="#example-2">Example:</a></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>];
@@ -194,7 +194,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 </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#672">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 = &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-1"><a href="#example-1">Example:</a></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>];
@@ -215,14 +215,14 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 0c80989183..e8b0a38197 100644
--- a/arrow/array/array/struct.FixedSizeBinaryArray.html
+++ b/arrow/array/array/struct.FixedSizeBinaryArray.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="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"  [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -6,7 +6,7 @@
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     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>An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#fixed-size-primitive-layout">fixed size binary arrays</a></p>
-<h2 id="examples"><a href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Create an array from an iterable argument of byte slices.</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>   <span class="kw">use </span>arrow_array::{Array, FixedSizeBinaryArray};
@@ -28,20 +28,20 @@ Sparsity means that the input argument can contain <code>None</code> items.</p>
     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 href="#panics">Panics</a></h5>
+<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>(
     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="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;</h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.FixedSizeBinaryArra [...]
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <ul>
 <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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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>
@@ -49,10 +49,10 @@ Sparsity means that the input argument can contain <code>None</code> items.</p>
 </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 [...]
-<h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
+<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 [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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 [...]
 <p>Note this doesn’t do any bound checking, for performance reason.</p>
@@ -70,7 +70,7 @@ allowing for zero-copy cloning.</p>
     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><span class="item-info"><div class="stab deprecated"><span class="emoji">👎</span><span>Deprecated: This function will fail if the iterator produces only None values; prefer <code>try_from_sparse_iter_with_size</code></span></div></ [...]
 Sparsity means that items returned by the iterator are optional, i.e input argument can
 contain <code>None</code> items.</p>
-<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
+<h5 id="examples-1"><a class="doc-anchor" href="#examples-1">§</a>Examples</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::FixedSizeBinaryArray;
 <span class="kw">let </span>input_arg = <span class="macro">vec!</span>[
     <span class="prelude-val">None</span>,
@@ -81,7 +81,7 @@ contain <code>None</code> items.</p>
     <span class="prelude-val">None</span>,
 ];
 <span class="kw">let </span>array = FixedSizeBinaryArray::try_from_sparse_iter(input_arg.into_iter()).unwrap();</code></pre></div>
-<h5 id="errors-1"><a href="#errors-1">Errors</a></h5>
+<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;(
     iter: T,
@@ -93,7 +93,7 @@ Sparsity means that items returned by the iterator are optional, i.e input argum
 contain <code>None</code> items. In cases where the iterator returns only <code>None</code> values, this
 also takes a size parameter to ensure that the a valid FixedSizeBinaryArray is still
 created.</p>
-<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
+<h5 id="examples-2"><a class="doc-anchor" href="#examples-2">§</a>Examples</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::FixedSizeBinaryArray;
 <span class="kw">let </span>input_arg = <span class="macro">vec!</span>[
     <span class="prelude-val">None</span>,
@@ -104,12 +104,12 @@ created.</p>
     <span class="prelude-val">None</span>,
 ];
 <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 href="#errors-2">Errors</a></h5>
+<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 [...]
     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 href="#examples-3">Examples</a></h5>
+<h5 id="examples-3"><a class="doc-anchor" href="#examples-3">§</a>Examples</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::FixedSizeBinaryArray;
 <span class="kw">let </span>input_arg = <span class="macro">vec!</span>[
     <span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>],
@@ -117,7 +117,7 @@ created.</p>
     <span class="macro">vec!</span>[<span class="number">5</span>, <span class="number">6</span>],
 ];
 <span class="kw">let </span>array = FixedSizeBinaryArray::try_from_iter(input_arg.into_iter()).unwrap();</code></pre></div>
-<h5 id="errors-3"><a href="#errors-3">Errors</a></h5>
+<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=" [...]
@@ -133,22 +133,22 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 ) -&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-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= [...]
 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#242">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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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: <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 665493fbee..4ac765f569 100644
--- a/arrow/array/array/struct.FixedSizeListArray.html
+++ b/arrow/array/array/struct.FixedSizeListArray.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="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. [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -10,7 +10,7 @@
 <p>Lists are represented using a <code>values</code> child
 array where each list has a fixed size of <code>value_length</code>.</p>
 <p>Use <a href="../builder/struct.FixedSizeListBuilder.html" title="struct arrow::array::builder::FixedSizeListBuilder"><code>FixedSizeListBuilder</code></a> to construct a <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a>.</p>
-<h2 id="representation"><a href="#representation">Representation</a></h2>
+<h2 id="representation"><a class="doc-anchor" href="#representation">§</a>Representation</h2>
 <p>A <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a> can represent a list of values of any other
 supported Arrow type. Each element of the <code>FixedSizeListArray</code> itself is
 a list which may contain NULL and non-null values,
@@ -47,7 +47,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
                                 │   FixedSizeListArray        (Array)         │
                                                         └ ─ ─ ─ ─ ─ ─ ─ ─┘    
                                 └ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ─ ┘
-</code></pre></div><h2 id="example"><a href="#example">Example</a></h2>
+</code></pre></div><h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Construct a value array
 </span><span class="kw">let </span>value_data = ArrayData::builder(DataType::Int32)
     .len(<span class="number">9</span>)
@@ -78,7 +78,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
     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;
 ) -&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 href="#panics">Panics</a></h5>
+<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>(
     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;,
@@ -86,7 +86,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
     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;
 ) -&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.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a>, <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.FixedSizeListArray.html"  [...]
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <ul>
 <li><code>size &lt; 0</code></li>
 <li><code>values.len() / size != nulls.len()</code></li>
@@ -94,7 +94,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
 <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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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>
@@ -113,7 +113,7 @@ are shown on the left, and the actual <code>FixedSizeListArray</code> encoding o
     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 [...]
-<h5 id="example-1"><a href="#example-1">Example</a></h5>
+<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">let </span>data = <span class="macro">vec!</span>[
    <span class="prelude-val">Some</span>(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">0</span>), <span class="prelude-val">Some</span>(<span class="number">1</span>), <span class="prelude-val">Some</span>(<span class="number">2</span>)]),
@@ -131,28 +131,28 @@ This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">R
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</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" [...]
 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 [...]
+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 [...]
     &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= [...]
+) -&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 class="src rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#502">source</a><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= [...]
     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 [...]
 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#242">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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 31c96e2864..325fe0a577 100644
--- a/arrow/array/array/struct.GenericByteArray.html
+++ b/arrow/array/array/struct.GenericByteArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -8,23 +8,23 @@
 }</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#variable-size-binary-layout">variable length byte arrays</a></p>
 <p>See <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> for storing utf8 encoded string data</p>
 <p>See <a href="../type.BinaryArray.html" title="type arrow::array::BinaryArray"><code>BinaryArray</code></a> and <a href="../type.LargeBinaryArray.html" title="type arrow::array::LargeBinaryArray"><code>LargeBinaryArray</code></a> for storing arbitrary bytes</p>
-<h2 id="example-from-a-vec"><a href="#example-from-a-vec">Example: From a Vec</a></h2>
+<h2 id="example-from-a-vec"><a class="doc-anchor" href="#example-from-a-vec">§</a>Example: From a Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: GenericByteArray&lt;Utf8Type&gt; = <span class="macro">vec!</span>[<span class="string">"hello"</span>, <span class="string">"world"</span>, <span class="string">""</span>].into();
 <span class="macro">assert_eq!</span>(arr.value_data(), <span class="string">b"helloworld"</span>);
 <span class="macro">assert_eq!</span>(arr.value_offsets(), <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">5</span>, <span class="number">10</span>, <span class="number">10</span>]);
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = arr.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">Some</span>(<span class="string">"world"</span>), <span class="prelude-val">Some</span>(<span class="string">""</span>)]);</code></pre></div>
-<h2 id="example-from-an-optional-vec"><a href="#example-from-an-optional-vec">Example: From an optional Vec</a></h2>
+<h2 id="example-from-an-optional-vec"><a class="doc-anchor" href="#example-from-an-optional-vec">§</a>Example: From an optional Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: GenericByteArray&lt;Utf8Type&gt; = <span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"hello"</span>), <span class="prelude-val">Some</span>(<span class="string">"world"</span>), <span class="prelude-val">Some</span>(<span class="string">""</span>), <span class="prelude-val">None</span>].into();
 <span class="macro">assert_eq!</span>(arr.value_data(), <span class="string">b"helloworld"</span>);
 <span class="macro">assert_eq!</span>(arr.value_offsets(), <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">5</span>, <span class="number">10</span>, <span class="number">10</span>, <span class="number">10</span>]);
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = arr.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">Some</span>(<span class="string">"world"</span>), <span class="prelude-val">Some</span>(<span class="string">""</span>), <span class="prelude-val">None</span>]);</code></pre></div>
-<h2 id="example-from-an-iterator-of-option"><a href="#example-from-an-iterator-of-option">Example: From an iterator of option</a></h2>
+<h2 id="example-from-an-iterator-of-option"><a class="doc-anchor" href="#example-from-an-iterator-of-option">§</a>Example: From an iterator of option</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: GenericByteArray&lt;Utf8Type&gt; = (<span class="number">0</span>..<span class="number">5</span>).map(|x| (x % <span class="number">2 </span>== <span class="number">0</span>).then(|| x.to_string())).collect();
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = arr.iter().collect();
 <span class="macro">assert_eq!</span>(values, <span class="kw-2">&amp;</span>[<span class="prelude-val">Some</span>(<span class="string">"0"</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="string">"2"</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="string">"4"</span>)]);</code></pre></div>
-<h2 id="example-using-builder"><a href="#example-using-builder">Example: Using Builder</a></h2>
+<h2 id="example-using-builder"><a class="doc-anchor" href="#example-using-builder">§</a>Example: Using Builder</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>builder = GenericByteBuilder::&lt;Utf8Type&gt;::new();
 builder.append_value(<span class="string">"hello"</span>);
 builder.append_null();
@@ -49,7 +49,7 @@ builder.append_value(<span class="string">"world"</span>);
     &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 href="#safety">Safety</a></h5>
+<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 [...]
@@ -58,14 +58,14 @@ builder.append_value(<span class="string">"world"</span>);
     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 href="#panics">Panics</a></h5>
+<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>(
     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="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;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.GenericByteArray.html" [...]
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <ul>
 <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>
@@ -75,7 +75,7 @@ builder.append_value(<span class="string">"world"</span>);
     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 href="#safety-1">Safety</a></h5>
+<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>(
@@ -88,7 +88,7 @@ builder.append_value(<span class="string">"world"</span>);
     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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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 [...]
 <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>
@@ -100,10 +100,10 @@ allowing for zero-copy cloning</p>
 </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 [...]
-<h5 id="safety-2"><a href="#safety-2">Safety</a></h5>
+<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  [...]
-<h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
+<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 [...]
@@ -112,7 +112,7 @@ 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 [...]
-<h5 id="performance"><a href="#performance">Performance</a></h5>
+<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>
@@ -124,7 +124,7 @@ please use the function <a href="#method.value_length"><code>value_length</code>
     &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 href="#safety-3">Safety</a></h5>
+<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>(
     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;
@@ -148,28 +148,28 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 ) -&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-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-7" 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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#79">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-4" 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-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#79">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     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-6" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-6" 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-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
     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-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-1" 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- [...]
+    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 class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-9" 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-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     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" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/night [...]
-    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/binary_array.rs.html#110">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-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#91">source</a><a href="#method.from-2" 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-10" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#110">source</a><a href="#method.from-10" 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-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-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#104">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
     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-9" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#85">source</a><a href="#method.from-9" 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-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#97">source</a><a href="#method.from-8" 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-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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#97">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#103">source</a><a href="#method.from-4" 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#103">source</a><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
     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 [...]
@@ -177,11 +177,11 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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 class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#486">source</a><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/night [...]
-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#242">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 class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#479">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" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#480">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/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 method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#486">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#242">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#479">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#480">source</a><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/night [...]
+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#242">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="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 [...]
@@ -189,15 +189,15 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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: <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 ed78494d02..355de50069 100644
--- a/arrow/array/array/struct.GenericListArray.html
+++ b/arrow/array/array/struct.GenericListArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -13,7 +13,7 @@ array. Offsets are stored in two adjacent entries of an
 <p>Arrow defines <a href="../type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a> with <code>i32</code> offsets and
 <a href="../type.LargeListArray.html" title="type arrow::array::LargeListArray"><code>LargeListArray</code></a> with <code>i64</code> offsets.</p>
 <p>Use <a href="../builder/struct.GenericListBuilder.html" title="struct arrow::array::builder::GenericListBuilder"><code>GenericListBuilder</code></a> to construct a <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray</code></a>.</p>
-<h2 id="representation"><a href="#representation">Representation</a></h2>
+<h2 id="representation"><a class="doc-anchor" href="#representation">§</a>Representation</h2>
 <p>A <a href="../type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a> can represent a list of values of any other
 supported Arrow type. Each element of the <code>ListArray</code> itself is
 a list which may be empty, may contain NULL and non-null values,
@@ -70,7 +70,7 @@ the output is the <a href="../../datatypes/enum.DataType.html" title="enum arrow
     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;
 ) -&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.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&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.GenericListAr [...]
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <p>Errors if</p>
 <ul>
 <li><code>offsets.len() - 1 != nulls.len()</code></li>
@@ -84,7 +84,7 @@ the output is the <a href="../../datatypes/enum.DataType.html" title="enum arrow
     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;
 ) -&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 href="#panics">Panics</a></h5>
+<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>(
@@ -96,7 +96,7 @@ 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 [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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 [...]
@@ -111,7 +111,7 @@ allowing for zero-copy cloning</p>
     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 [...]
-<h5 id="example"><a href="#example">Example</a></h5>
+<h5 id="example"><a class="doc-anchor" href="#example">§</a>Example</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>data = <span class="macro">vec!</span>[
    <span class="prelude-val">Some</span>(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">0</span>), <span class="prelude-val">Some</span>(<span class="number">1</span>), <span class="prelude-val">Some</span>(<span class="number">2</span>)]),
@@ -140,12 +140,12 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#374">source</a><a href="#method.from-3" 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-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#381">source</a><a href="#method.from-1" 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-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#394">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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#381">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-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 [...]
     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-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
+    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" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/night [...]
     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#498">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#242">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 [...]
@@ -153,14 +153,14 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 04803feaac..c751227d35 100644
--- a/arrow/array/array/struct.MapArray.html
+++ b/arrow/array/array/struct.MapArray.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="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="../. [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -18,7 +18,7 @@
 ) -&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>Create a new <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><c [...]
 <p>See <a href="../builder/struct.MapBuilder.html" title="struct arrow::array::builder::MapBuilder"><code>MapBuilder</code></a> for a higher-level interface
 to construct a <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a></p>
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <p>Errors if</p>
 <ul>
 <li><code>offsets.len() - 1 != nulls.len()</code></li>
@@ -37,7 +37,7 @@ to construct a <a href="../struct.MapArray.html" title="struct arrow::array::Map
 ) -&gt; <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a></h4></section></summary><div class="docblock"><p>Create a new <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a> from the provided parts</p>
 <p>See <a href="../builder/struct.MapBuilder.html" title="struct arrow::array::builder::MapBuilder"><code>MapBuilder</code></a> for a higher-level interface
 to construct a <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a></p>
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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>(
     self
@@ -51,7 +51,7 @@ allowing for zero-copy cloning</p>
 </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 [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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"> [...]
 <p>This is a <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> containing two fields</p>
@@ -74,20 +74,20 @@ includes the overhead of the data structures that contain the pointers to the va
 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 [...]
     &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#242">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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 d0a60c842c..30e0346fec 100644
--- a/arrow/array/array/struct.NativeAdapter.html
+++ b/arrow/array/array/struct.NativeAdapter.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -11,21 +11,21 @@ the type can be collected to <code>PrimitiveArray</code>.</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-Debug-for-NativeAdapter%3CT%3E" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1166">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-header">im [...]
     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-9" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1205">source</a><a href="#method.from-9" 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-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1199">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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1205">source</a><a href="#method.from-3" 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#1199">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/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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 b2f7dd6d3f..040c4a5d8b 100644
--- a/arrow/array/array/struct.NullArray.html
+++ b/arrow/array/array/struct.NullArray.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="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="../../ [...]
+<!DOCTYPE html><html lang="en"><head><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>
-<h2 id="example-create-an-array"><a href="#example-create-an-array">Example: Create an array</a></h2>
+<h2 id="example-create-an-array"><a class="doc-anchor" href="#example-create-an-array">§</a>Example: Create an array</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, NullArray};
 
 <span class="kw">let </span>array = NullArray::new(<span class="number">10</span>);
@@ -24,21 +24,21 @@ This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">R
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</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" [...]
 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 [...]
+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 [...]
 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#242">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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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: <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 c8dc9aba95..1617bab39b 100644
--- a/arrow/array/array/struct.PrimitiveArray.html
+++ b/arrow/array/array/struct.PrimitiveArray.html
@@ -1,35 +1,35 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
     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">primitive values</a></p>
-<h2 id="example-from-a-vec"><a href="#example-from-a-vec">Example: From a Vec</a></h2>
+<h2 id="example-from-a-vec"><a class="doc-anchor" href="#example-from-a-vec">§</a>Example: From a Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: PrimitiveArray&lt;Int32Type&gt; = <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="macro">assert_eq!</span>(<span class="number">4</span>, arr.len());
 <span class="macro">assert_eq!</span>(<span class="number">0</span>, arr.null_count());
 <span class="macro">assert_eq!</span>(arr.values(), <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>])</code></pre></div>
-<h2 id="example-from-an-optional-vec"><a href="#example-from-an-optional-vec">Example: From an optional Vec</a></h2>
+<h2 id="example-from-an-optional-vec"><a class="doc-anchor" href="#example-from-an-optional-vec">§</a>Example: From an optional Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: PrimitiveArray&lt;Int32Type&gt; = <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">Some</span>(<span class="number">3</span>), <span class="prelude-val">None</span>].into();
 <span class="macro">assert_eq!</span>(<span class="number">4</span>, arr.len());
 <span class="macro">assert_eq!</span>(<span class="number">2</span>, arr.null_count());
 <span class="comment">// Note: values for null indexes are arbitrary
 </span><span class="macro">assert_eq!</span>(arr.values(), <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">0</span>, <span class="number">3</span>, <span class="number">0</span>])</code></pre></div>
-<h2 id="example-from-an-iterator-of-values"><a href="#example-from-an-iterator-of-values">Example: From an iterator of values</a></h2>
+<h2 id="example-from-an-iterator-of-values"><a class="doc-anchor" href="#example-from-an-iterator-of-values">§</a>Example: From an iterator of values</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: PrimitiveArray&lt;Int32Type&gt; = (<span class="number">0</span>..<span class="number">10</span>).map(|x| x + <span class="number">1</span>).collect();
 <span class="macro">assert_eq!</span>(<span class="number">10</span>, arr.len());
 <span class="macro">assert_eq!</span>(<span class="number">0</span>, arr.null_count());
 <span class="kw">for </span>i <span class="kw">in </span><span class="number">0</span>..<span class="number">10i32 </span>{
     <span class="macro">assert_eq!</span>(i + <span class="number">1</span>, arr.value(i <span class="kw">as </span>usize));
 }</code></pre></div>
-<h2 id="example-from-an-iterator-of-option"><a href="#example-from-an-iterator-of-option">Example: From an iterator of option</a></h2>
+<h2 id="example-from-an-iterator-of-option"><a class="doc-anchor" href="#example-from-an-iterator-of-option">§</a>Example: From an iterator of option</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: PrimitiveArray&lt;Int32Type&gt; = (<span class="number">0</span>..<span class="number">10</span>).map(|x| (x % <span class="number">2 </span>== <span class="number">0</span>).then_some(x)).collect();
 <span class="macro">assert_eq!</span>(<span class="number">10</span>, arr.len());
 <span class="macro">assert_eq!</span>(<span class="number">5</span>, arr.null_count());
 <span class="comment">// Note: values for null indexes are arbitrary
 </span><span class="macro">assert_eq!</span>(arr.values(), <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">2</span>, <span class="number">0</span>, <span class="number">4</span>, <span class="number">0</span>, <span class="number">6</span>, <span class="number">0</span>, <span class="number">8</span>, <span class="number">0</span>])</code></pre></div>
-<h2 id="example-using-builder"><a href="#example-using-builder">Example: Using Builder</a></h2>
+<h2 id="example-using-builder"><a class="doc-anchor" href="#example-using-builder">§</a>Example: Using Builder</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>builder = PrimitiveBuilder::&lt;Int32Type&gt;::new();
 builder.append_value(<span class="number">1</span>);
 builder.append_null();
@@ -43,9 +43,9 @@ builder.append_value(<span class="number">2</span>);
     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>
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <a href="../struct.PrimitiveArray.html#method.try_new" title="associated function arrow::array::PrimitiveArray::try_new"><code>Self::try_new</code></a> returns an error</p>
-<h5 id="example"><a href="#example">Example</a></h5>
+<h5 id="example"><a class="doc-anchor" href="#example">§</a>Example</h5>
 <p>Creating a <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> directly from a <a href="../../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer"><code>ScalarBuffer</code></a> and <a href="../../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer"><code>NullBuffer</code></a> using
 this constructor is the most performant approach, avoiding any additional allocations</p>
 
@@ -59,7 +59,7 @@ this constructor is the most performant approach, avoiding any additional alloca
     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=" [...]
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <p>Errors if:</p>
 <ul>
 <li><code>values.len() != nulls.len()</code></li>
@@ -73,7 +73,7 @@ this constructor is the most performant approach, avoiding any additional alloca
 </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 [...]
 <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 href="#panics-1">Panics</a></h5>
+<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>
@@ -86,10 +86,10 @@ timezones and decimal precision and scale</p>
     &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 href="#safety">Safety</a></h5>
+<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 [...]
-<h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
+<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
     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 [...]
@@ -105,7 +105,7 @@ timezones and decimal precision and scale</p>
     &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 href="#safety-1">Safety</a></h5>
+<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 [...]
@@ -125,11 +125,11 @@ will become 100 seconds in a <a href="../type.TimestampSecondArray.html" title="
     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
 the benefits of a vectorized operation outweigh the cost of branching nulls and non-nulls.</p>
-<h5 id="implementation"><a href="#implementation">Implementation</a></h5>
+<h5 id="implementation"><a class="doc-anchor" href="#implementation">§</a>Implementation</h5>
 <p>This will apply the function for all values, including those on null slots.
 This implies that the operation must be infallible for any value of the corresponding type
 or this function may panic.</p>
-<h5 id="example-1"><a href="#example-1">Example</a></h5>
+<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">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>
@@ -137,11 +137,11 @@ or this function may panic.</p>
     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>
-<h5 id="implementation-1"><a href="#implementation-1">Implementation</a></h5>
+<h5 id="implementation-1"><a class="doc-anchor" href="#implementation-1">§</a>Implementation</h5>
 <p>This will apply the function for all values, including those on null slots.
 This implies that the operation must be infallible for any value of the corresponding type
 or this function may panic.</p>
-<h5 id="example-2"><a href="#example-2">Example</a></h5>
+<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>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>
@@ -200,7 +200,7 @@ the passed tz to the to-be-returned NaiveDateTime</p>
     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#1255-1258">source</a><h4 class="code-header">pub unsafe fn <a href="#method.from_trusted_l [...]
     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 href="#safety-2">Safety</a></h5>
+<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#1328">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
@@ -250,126 +250,126 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_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.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#1093">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="htt [...]
     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-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1376">source</a><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>(data: <a class="struct" href="../struct.ArrayData.html" title="struct 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.from-23" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#977">source</a><a href="#method.from-23" 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-47" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1376">source</a><a href="#method.from-47" 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-9" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#977">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href [...]
     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 [...]
     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 [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
@@ -385,15 +385,15 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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: <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 9d78aba690..4b50fe74db 100644
--- a/arrow/array/array/struct.RunArray.html
+++ b/arrow/array/array/struct.RunArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -81,10 +81,10 @@ includes the overhead of the data structures that contain the pointers to the va
 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-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#259">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.r [...]
-    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#286">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" 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 [...]
     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 href="#example-1">Example:</a></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>];
@@ -96,7 +96,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 </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 [...]
     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 href="#example">Example:</a></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>, <span class="string">"c"</span>];
@@ -114,14 +114,14 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 14a0b7490e..eb5750187c 100644
--- a/arrow/array/array/struct.StructArray.html
+++ b/arrow/array/array/struct.StructArray.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="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="../../.. [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -6,7 +6,7 @@
     fields: <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;,
 }</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#struct-layout">structs</a></p>
 <p>Each child (called <em>field</em>) is represented by a separate array.</p>
-<h2 id="comparison-with-recordbatch"><a href="#comparison-with-recordbatch">Comparison with RecordBatch</a></h2>
+<h2 id="comparison-with-recordbatch"><a class="doc-anchor" href="#comparison-with-recordbatch">§</a>Comparison with <a href="../../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a></h2>
 <p>Both <a href="../../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch"><code>RecordBatch</code></a> and <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> represent a collection of columns / arrays with the
 same length.</p>
 <p>However, there are a couple of key differences:</p>
@@ -22,7 +22,7 @@ code that needs to handle both will typically share an implementation in terms o
 <p><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From"><code>From</code></a> implementations are provided to facilitate this conversion, however, converting
 from a <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a> containing top-level nulls to a <a href="../../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch"><code>RecordBatch</code></a> will panic, as there
 is no way to preserve them.</p>
-<h2 id="example-create-an-array-from-a-vector-of-fields"><a href="#example-create-an-array-from-a-vector-of-fields">Example: Create an array from a vector of fields</a></h2>
+<h2 id="example-create-an-array-from-a-vector-of-fields"><a class="doc-anchor" href="#example-create-an-array-from-a-vector-of-fields">§</a>Example: Create an array from a vector of fields</h2>
 <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_array::{Array, ArrayRef, BooleanArray, Int32Array, StructArray};
 <span class="kw">use </span>arrow_schema::{DataType, Field};
@@ -50,14 +50,14 @@ is no way to preserve them.</p>
     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 href="#panics">Panics</a></h5>
+<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>(
     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="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>Create a new <a href="../struct.StructArray.html" title="struct arrow::array:: [...]
-<h5 id="errors"><a href="#errors">Errors</a></h5>
+<h5 id="errors"><a class="doc-anchor" href="#errors">§</a>Errors</h5>
 <p>Errors if</p>
 <ul>
 <li><code>fields.len() != arrays.len()</code></li>
@@ -72,10 +72,10 @@ is no way to preserve them.</p>
     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 href="#safety">Safety</a></h5>
+<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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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. [...]
@@ -96,11 +96,11 @@ This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">R
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</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="f [...]
 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 [...]
+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 [...]
 <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 href="#panics-2">Panics</a></h5>
+<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 [...]
 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#242">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= [...]
@@ -111,14 +111,14 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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-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 b7d3c0f63e..8e4d47a4f2 100644
--- a/arrow/array/array/struct.TypedDictionaryArray.html
+++ b/arrow/array/array/struct.TypedDictionaryArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -50,14 +50,14 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 24bb3db4da..1e1737877a 100644
--- a/arrow/array/array/struct.TypedRunArray.html
+++ b/arrow/array/array/struct.TypedRunArray.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="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/ [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -53,14 +53,14 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 5d1fc6fd57..9e86847121 100644
--- a/arrow/array/array/struct.UnionArray.html
+++ b/arrow/array/array/struct.UnionArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -15,7 +15,7 @@ information on please see the
 create <a href="../struct.UnionArray.html" title="struct arrow::array::UnionArray">UnionArray</a>’s of primitive types. <code>UnionArray</code>’s of nested
 types are also supported but not via <code>UnionBuilder</code>, see the tests
 for examples.</p>
-<h2 id="examples"><a href="#examples">Examples</a></h2><h3 id="create-a-dense-unionarray-1-32-34"><a href="#create-a-dense-unionarray-1-32-34">Create a dense UnionArray <code>[1, 3.2, 34]</code></a></h3>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2><h3 id="create-a-dense-unionarray-1-32-34"><a class="doc-anchor" href="#create-a-dense-unionarray-1-32-34">§</a>Create a dense UnionArray <code>[1, 3.2, 34]</code></h3>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_buffer::Buffer;
 <span class="kw">use </span>arrow_schema::<span class="kw-2">*</span>;
 <span class="kw">use </span>std::sync::Arc;
@@ -46,7 +46,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>
-<h3 id="create-a-sparse-unionarray-1-32-34"><a href="#create-a-sparse-unionarray-1-32-34">Create a sparse UnionArray <code>[1, 3.2, 34]</code></a></h3>
+<h3 id="create-a-sparse-unionarray-1-32-34"><a class="doc-anchor" href="#create-a-sparse-unionarray-1-32-34">§</a>Create a sparse UnionArray <code>[1, 3.2, 34]</code></h3>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_buffer::Buffer;
 <span class="kw">use </span>arrow_schema::<span class="kw-2">*</span>;
 <span class="kw">use </span>std::sync::Arc;
@@ -86,7 +86,7 @@ for examples.</p>
 a new <code>UnionArray</code>.  This method makes no attempt to validate the data provided by the
 caller and assumes that each of the components are correct and consistent with each other.
 See <code>try_new</code> for an alternative that validates the data provided.</p>
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>The <code>type_ids</code> <code>Buffer</code> should contain <code>i8</code> values.  These values should be greater than
 zero and must be less than the number of children provided in <code>child_arrays</code>.  These values
 are used to index into the <code>child_arrays</code>.</p>
@@ -106,19 +106,19 @@ to ensure that the data provided is valid.</p>
     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"  [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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 [...]
-<h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
+<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 [...]
-<h5 id="panics-3"><a href="#panics-3">Panics</a></h5>
+<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 [...]
@@ -134,18 +134,18 @@ 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: [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</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 [...]
 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 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 [...]
     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="../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; [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 2c98654900..66b062a3d9 100644
--- a/arrow/array/array/trait.AnyDictionaryArray.html
+++ b/arrow/array/array/trait.AnyDictionaryArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>;
@@ -43,7 +43,7 @@ dict.extend([<span class="prelude-val">Some</span>(<span class="number">1</span>
 </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 [...]
 <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 href="#panic">Panic</a></h5>
+<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 [...]
 <p>See <a href="../struct.DictionaryArray.html#method.with_values" title="method arrow::array::DictionaryArray::with_values"><code>DictionaryArray::with_values</code></a></p>
diff --git a/arrow/array/array/trait.Array.html b/arrow/array/array/trait.Array.html
index fba7080bea..77798e4c35 100644
--- a/arrow/array/array/trait.Array.html
+++ b/arrow/array/array/trait.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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);
@@ -22,7 +22,7 @@
 </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/ [...]
 downcasted to a specific implementation.</p>
-<h5 id="example"><a href="#example">Example:</a></h5>
+<h5 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>id = 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>batch = RecordBatch::try_new(
@@ -39,7 +39,7 @@ downcasted to a specific implementation.</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>
 <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  [...]
-<h5 id="example-1"><a href="#example-1">Example:</a></h5>
+<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};
 
@@ -47,7 +47,7 @@ downcasted to a specific implementation.</p>
 
 <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 [...]
-<h5 id="example-2"><a href="#example-2">Example:</a></h5>
+<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};
 
 <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>]);
@@ -56,14 +56,14 @@ downcasted to a specific implementation.</p>
 
 <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>
-<h5 id="example-3"><a href="#example-3">Example:</a></h5>
+<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>
-<h5 id="example-4"><a href="#example-4">Example:</a></h5>
+<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>]);
@@ -72,7 +72,7 @@ downcasted to a specific implementation.</p>
 </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 [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>.</p>
-<h5 id="example-5"><a href="#example-5">Example:</a></h5>
+<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">use </span>arrow_array::{Array, BooleanArray};
 
 <span class="kw">let </span>array = 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>]);
@@ -105,7 +105,7 @@ of these arrays, beyond what is encoded in <a href="../trait.Array.html#tymethod
 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
 encode nullability in their children. See <a href="../trait.Array.html#method.logical_nulls" title="method arrow_array::array::Array::logical_nulls::logical_nulls"><code>Self::logical_nulls</code></a> for more information.</p>
-<h5 id="example-6"><a href="#example-6">Example:</a></h5>
+<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><span class="kw">use </span>arrow_array::{Array, Int32Array, NullArray};
 
 <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>]);
@@ -118,7 +118,7 @@ encode nullability in their children. See <a href="../trait.Array.html#method.lo
 <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 [...]
 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 href="#example-7">Example:</a></h5>
+<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};
 
 <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>]);
@@ -128,7 +128,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 </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 [...]
 <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 href="#example-8">Example:</a></h5>
+<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">use </span>arrow_array::{Array, Int32Array};
 
 <span class="comment">// Construct an array with values [1, NULL, NULL]
@@ -154,11 +154,11 @@ and therefore would not appear in <a href="../trait.Array.html#method.logical_nu
     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#450">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#242">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#443">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 [...]
+    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 class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#450">source</a><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.e [...]
 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#242">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-dyn+Array" class="impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#443">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 [...]
+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#242">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 class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#287">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#288">source</a><a href="#method.as_any" class="anchor">§</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><section id="method.to_data [...]
     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#354">source</a><a href="#method.as_any-1" class="anchor">§</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.or [...]
diff --git a/arrow/array/array/trait.ArrayAccessor.html b/arrow/array/array/trait.ArrayAccessor.html
index 55b2a9e289..4c4d9d7d5e 100644
--- a/arrow/array/array/trait.ArrayAccessor.html
+++ b/arrow/array/array/trait.ArrayAccessor.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>;
 
@@ -6,17 +6,17 @@
     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="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a>;
 <span class="item-spacer"></span>    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>;
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A generic trait for accessing the values of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a></p>
-<h2 id="validity"><a href="#validity">Validity</a></h2>
+<h2 id="validity"><a class="doc-anchor" href="#validity">§</a>Validity</h2>
 <p>An <a href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor"><code>ArrayAccessor</code></a> must always return a well-defined value for an index that is
 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#430">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#435">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 [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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#440">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 [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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 [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
diff --git a/arrow/array/array/trait.ArrowPrimitiveType.html b/arrow/array/array/trait.ArrowPrimitiveType.html
index 0ffba9bdc4..1165cd1b4a 100644
--- a/arrow/array/array/trait.ArrowPrimitiveType.html
+++ b/arrow/array/array/trait.ArrowPrimitiveType.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="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" [...]
+<!DOCTYPE html><html lang="en"><head><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>;
 
diff --git a/arrow/array/array/trait.OffsetSizeTrait.html b/arrow/array/array/trait.OffsetSizeTrait.html
index 0b7b7da273..c1d79bff89 100644
--- a/arrow/array/array/trait.OffsetSizeTrait.html
+++ b/arrow/array/array/trait.OffsetSizeTrait.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>;
diff --git a/arrow/array/array/type.ArrayRef.html b/arrow/array/array/type.ArrayRef.html
index 6030c27b61..e419f398c3 100644
--- a/arrow/array/array/type.ArrayRef.html
+++ b/arrow/array/array/type.ArrayRef.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/array/type.BinaryArray.html b/arrow/array/array/type.BinaryArray.html
index f886e31e38..7e09b8b86a 100644
--- a/arrow/array/array/type.BinaryArray.html
+++ b/arrow/array/array/type.BinaryArray.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 `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/ [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Create a BinaryArray from a vector of byte slices.</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, BinaryArray};
diff --git a/arrow/array/array/type.Date32Array.html b/arrow/array/array/type.Date32Array.html
index 355a2b38bf..ffa9bf00fd 100644
--- a/arrow/array/array/type.Date32Array.html
+++ b/arrow/array/array/type.Date32Array.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/array/type.Date64Array.html b/arrow/array/array/type.Date64Array.html
index 50e6f40f71..4283b56205 100644
--- a/arrow/array/array/type.Date64Array.html
+++ b/arrow/array/array/type.Date64Array.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/array/type.Decimal128Array.html b/arrow/array/array/type.Decimal128Array.html
index 6586fd4500..58c54324b5 100644
--- a/arrow/array/array/type.Decimal128Array.html
+++ b/arrow/array/array/type.Decimal128Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;i18&gt;&gt;
diff --git a/arrow/array/array/type.Decimal256Array.html b/arrow/array/array/type.Decimal256Array.html
index 56380f5cb5..f9f60113cd 100644
--- a/arrow/array/array/type.Decimal256Array.html
+++ b/arrow/array/array/type.Decimal256Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_buffer::i256;
diff --git a/arrow/array/array/type.DurationMicrosecondArray.html b/arrow/array/array/type.DurationMicrosecondArray.html
index 7ae2b31d22..9982129b8a 100644
--- a/arrow/array/array/type.DurationMicrosecondArray.html
+++ b/arrow/array/array/type.DurationMicrosecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.DurationMillisecondArray.html b/arrow/array/array/type.DurationMillisecondArray.html
index 3e07a5c0fc..260be5c886 100644
--- a/arrow/array/array/type.DurationMillisecondArray.html
+++ b/arrow/array/array/type.DurationMillisecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.DurationNanosecondArray.html b/arrow/array/array/type.DurationNanosecondArray.html
index fd6a610915..1fa2b1108a 100644
--- a/arrow/array/array/type.DurationNanosecondArray.html
+++ b/arrow/array/array/type.DurationNanosecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.DurationSecondArray.html b/arrow/array/array/type.DurationSecondArray.html
index edf9f1d503..295c18918a 100644
--- a/arrow/array/array/type.DurationSecondArray.html
+++ b/arrow/array/array/type.DurationSecondArray.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="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= [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.Float16Array.html b/arrow/array/array/type.Float16Array.html
index a2b79f22f1..5359d08436 100644
--- a/arrow/array/array/type.Float16Array.html
+++ b/arrow/array/array/type.Float16Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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= [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>half::f16;
@@ -10,7 +10,7 @@
 </span><span class="kw">let </span>arr = Float16Array::from(<span class="macro">vec!</span>[f16::from_f64(<span class="number">1.0</span>), f16::from_f64(<span class="number">2.0</span>), f16::from_f64(<span class="number">3.0</span>)]);
 <span class="comment">// Create iter/collect
 </span><span class="kw">let </span>arr: Float16Array = std::iter::repeat(f16::from_f64(<span class="number">1.0</span>)).take(<span class="number">10</span>).collect();</code></pre></div>
-<h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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">use </span>half::f16;
 <span class="kw">let </span>arr : Float16Array = [<span class="prelude-val">Some</span>(f16::from_f64(<span class="number">1.0</span>)), <span class="prelude-val">Some</span>(f16::from_f64(<span class="number">2.0</span>))].into_iter().collect();</code></pre></div>
 <p>See <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a> for more information and examples</p>
diff --git a/arrow/array/array/type.Float32Array.html b/arrow/array/array/type.Float32Array.html
index ea9ec7db7a..fb05ecc019 100644
--- a/arrow/array/array/type.Float32Array.html
+++ b/arrow/array/array/type.Float32Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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= [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;f32&gt;&gt;
diff --git a/arrow/array/array/type.Float64Array.html b/arrow/array/array/type.Float64Array.html
index 10373ce9fe..66f35f31ea 100644
--- a/arrow/array/array/type.Float64Array.html
+++ b/arrow/array/array/type.Float64Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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= [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;f32&gt;&gt;
diff --git a/arrow/array/array/type.GenericBinaryArray.html b/arrow/array/array/type.GenericBinaryArray.html
index a101a9ec33..6cdefbe0cf 100644
--- a/arrow/array/array/type.GenericBinaryArray.html
+++ b/arrow/array/array/type.GenericBinaryArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.GenericStringArray.html b/arrow/array/array/type.GenericStringArray.html
index 561b95d382..86a0428bbd 100644
--- a/arrow/array/array/type.GenericStringArray.html
+++ b/arrow/array/array/type.GenericStringArray.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="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"  [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.Int16Array.html b/arrow/array/array/type.Int16Array.html
index 86cf95db29..c6ba3d3559 100644
--- a/arrow/array/array/type.Int16Array.html
+++ b/arrow/array/array/type.Int16Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=". [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;i16&gt;&gt;
diff --git a/arrow/array/array/type.Int16DictionaryArray.html b/arrow/array/array/type.Int16DictionaryArray.html
index 4df3d8e18c..0a06b7b79a 100644
--- a/arrow/array/array/type.Int16DictionaryArray.html
+++ b/arrow/array/array/type.Int16DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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"  [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.Int16RunArray.html b/arrow/array/array/type.Int16RunArray.html
index b04f06be96..ff3e58dd50 100644
--- a/arrow/array/array/type.Int16RunArray.html
+++ b/arrow/array/array/type.Int16RunArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.Int32Array.html b/arrow/array/array/type.Int32Array.html
index b8c41aa07e..b506b2b938 100644
--- a/arrow/array/array/type.Int32Array.html
+++ b/arrow/array/array/type.Int32Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=". [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;i32&gt;&gt;
diff --git a/arrow/array/array/type.Int32DictionaryArray.html b/arrow/array/array/type.Int32DictionaryArray.html
index e9e77e251f..622f54395c 100644
--- a/arrow/array/array/type.Int32DictionaryArray.html
+++ b/arrow/array/array/type.Int32DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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"  [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.Int32RunArray.html b/arrow/array/array/type.Int32RunArray.html
index c717c96403..eafde8f607 100644
--- a/arrow/array/array/type.Int32RunArray.html
+++ b/arrow/array/array/type.Int32RunArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.Int64Array.html b/arrow/array/array/type.Int64Array.html
index 8ff14d094a..df2d72fe86 100644
--- a/arrow/array/array/type.Int64Array.html
+++ b/arrow/array/array/type.Int64Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=". [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;i64&gt;&gt;
diff --git a/arrow/array/array/type.Int64DictionaryArray.html b/arrow/array/array/type.Int64DictionaryArray.html
index ec48ab4de0..3364f957b9 100644
--- a/arrow/array/array/type.Int64DictionaryArray.html
+++ b/arrow/array/array/type.Int64DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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"  [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.Int64RunArray.html b/arrow/array/array/type.Int64RunArray.html
index 150b6adb38..15b1a63f30 100644
--- a/arrow/array/array/type.Int64RunArray.html
+++ b/arrow/array/array/type.Int64RunArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.Int8Array.html b/arrow/array/array/type.Int8Array.html
index 9d9605c6ff..6f1961e394 100644
--- a/arrow/array/array/type.Int8Array.html
+++ b/arrow/array/array/type.Int8Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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="../ [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;i8&gt;&gt;
diff --git a/arrow/array/array/type.Int8DictionaryArray.html b/arrow/array/array/type.Int8DictionaryArray.html
index 558143752b..05b1a2b7df 100644
--- a/arrow/array/array/type.Int8DictionaryArray.html
+++ b/arrow/array/array/type.Int8DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.IntervalDayTimeArray.html b/arrow/array/array/type.IntervalDayTimeArray.html
index 7b4112d012..f71248b938 100644
--- a/arrow/array/array/type.IntervalDayTimeArray.html
+++ b/arrow/array/array/type.IntervalDayTimeArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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 {
diff --git a/arrow/array/array/type.IntervalMonthDayNanoArray.html b/arrow/array/array/type.IntervalMonthDayNanoArray.html
index 607a689744..39acdeb66f 100644
--- a/arrow/array/array/type.IntervalMonthDayNanoArray.html
+++ b/arrow/array/array/type.IntervalMonthDayNanoArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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 {
diff --git a/arrow/array/array/type.IntervalYearMonthArray.html b/arrow/array/array/type.IntervalYearMonthArray.html
index 4574685c40..bacb26c11f 100644
--- a/arrow/array/array/type.IntervalYearMonthArray.html
+++ b/arrow/array/array/type.IntervalYearMonthArray.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="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"  [...]
+<!DOCTYPE html><html lang="en"><head><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 {
diff --git a/arrow/array/array/type.LargeBinaryArray.html b/arrow/array/array/type.LargeBinaryArray.html
index fe05e4a5a9..7b7f46b59a 100644
--- a/arrow/array/array/type.LargeBinaryArray.html
+++ b/arrow/array/array/type.LargeBinaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Create a LargeBinaryArray from a vector of byte slices.</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{Array, LargeBinaryArray};
diff --git a/arrow/array/array/type.LargeListArray.html b/arrow/array/array/type.LargeListArray.html
index ba21ef89f6..b9f544d722 100644
--- a/arrow/array/array/type.LargeListArray.html
+++ b/arrow/array/array/type.LargeListArray.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="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"  [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.LargeStringArray.html b/arrow/array/array/type.LargeStringArray.html
index 62fbf6dce8..c8e1374374 100644
--- a/arrow/array/array/type.LargeStringArray.html
+++ b/arrow/array/array/type.LargeStringArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;&amp;str&gt;&gt;
diff --git a/arrow/array/array/type.ListArray.html b/arrow/array/array/type.ListArray.html
index 183558f03f..30bef4e861 100644
--- a/arrow/array/array/type.ListArray.html
+++ b/arrow/array/array/type.ListArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/array/type.StringArray.html b/arrow/array/array/type.StringArray.html
index 6c6631d997..7d6556524e 100644
--- a/arrow/array/array/type.StringArray.html
+++ b/arrow/array/array/type.StringArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;&amp;str&gt;&gt;
diff --git a/arrow/array/array/type.Time32MillisecondArray.html b/arrow/array/array/type.Time32MillisecondArray.html
index b2375a5b8a..9f14cc9660 100644
--- a/arrow/array/array/type.Time32MillisecondArray.html
+++ b/arrow/array/array/type.Time32MillisecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/array/type.Time32SecondArray.html b/arrow/array/array/type.Time32SecondArray.html
index 40ce6852f2..a0e7482938 100644
--- a/arrow/array/array/type.Time32SecondArray.html
+++ b/arrow/array/array/type.Time32SecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/array/type.Time64MicrosecondArray.html b/arrow/array/array/type.Time64MicrosecondArray.html
index 7f40d723c6..e96440152f 100644
--- a/arrow/array/array/type.Time64MicrosecondArray.html
+++ b/arrow/array/array/type.Time64MicrosecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/array/type.Time64NanosecondArray.html b/arrow/array/array/type.Time64NanosecondArray.html
index 2f80e6ba1b..6dcdd51be3 100644
--- a/arrow/array/array/type.Time64NanosecondArray.html
+++ b/arrow/array/array/type.Time64NanosecondArray.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="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" [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/array/type.TimestampMicrosecondArray.html b/arrow/array/array/type.TimestampMicrosecondArray.html
index f81140b5ff..084439dce9 100644
--- a/arrow/array/array/type.TimestampMicrosecondArray.html
+++ b/arrow/array/array/type.TimestampMicrosecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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 {
diff --git a/arrow/array/array/type.TimestampMillisecondArray.html b/arrow/array/array/type.TimestampMillisecondArray.html
index cebab2420f..dcd906425c 100644
--- a/arrow/array/array/type.TimestampMillisecondArray.html
+++ b/arrow/array/array/type.TimestampMillisecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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 {
diff --git a/arrow/array/array/type.TimestampNanosecondArray.html b/arrow/array/array/type.TimestampNanosecondArray.html
index b7214865e8..5976e8b825 100644
--- a/arrow/array/array/type.TimestampNanosecondArray.html
+++ b/arrow/array/array/type.TimestampNanosecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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 {
diff --git a/arrow/array/array/type.TimestampSecondArray.html b/arrow/array/array/type.TimestampSecondArray.html
index d41e2c716d..9e4cec7fba 100644
--- a/arrow/array/array/type.TimestampSecondArray.html
+++ b/arrow/array/array/type.TimestampSecondArray.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
-<h2 id="example-utc-timestamps-post-epoch"><a href="#example-utc-timestamps-post-epoch">Example: UTC timestamps post epoch</a></h2>
+<h2 id="example-utc-timestamps-post-epoch"><a class="doc-anchor" href="#example-utc-timestamps-post-epoch">§</a>Example: UTC timestamps post epoch</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::timezone::Tz;
 <span class="comment">// Corresponds to single element array with entry 1970-05-09T14:25:11+0:00
 </span><span class="kw">let </span>arr = TimestampSecondArray::from(<span class="macro">vec!</span>[<span class="number">11111111</span>]);
@@ -12,7 +12,7 @@ values such as <code>1970-05-09 14:25:11 +01:00</code></p>
 <span class="kw">let </span>utc_tz: Tz = <span class="string">"+00:00"</span>.parse().unwrap();
 
 <span class="macro">assert_eq!</span>(arr.value_as_datetime_with_tz(<span class="number">0</span>, utc_tz).map(|v| v.to_string()).unwrap(), <span class="string">"1970-05-09 14:25:11 +00:00"</span>)</code></pre></div>
-<h2 id="example-utc-timestamps-pre-epoch"><a href="#example-utc-timestamps-pre-epoch">Example: UTC timestamps pre epoch</a></h2>
+<h2 id="example-utc-timestamps-pre-epoch"><a class="doc-anchor" href="#example-utc-timestamps-pre-epoch">§</a>Example: UTC timestamps pre epoch</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::timezone::Tz;
 <span class="comment">// Corresponds to single element array with entry 1969-08-25T09:34:49+0:00
 </span><span class="kw">let </span>arr = TimestampSecondArray::from(<span class="macro">vec!</span>[-<span class="number">11111111</span>]);
@@ -21,7 +21,7 @@ values such as <code>1970-05-09 14:25:11 +01:00</code></p>
 <span class="kw">let </span>utc_tz: Tz = <span class="string">"+00:00"</span>.parse().unwrap();
 
 <span class="macro">assert_eq!</span>(arr.value_as_datetime_with_tz(<span class="number">0</span>, utc_tz).map(|v| v.to_string()).unwrap(), <span class="string">"1969-08-25 09:34:49 +00:00"</span>)</code></pre></div>
-<h2 id="example-with-timezone-specified"><a href="#example-with-timezone-specified">Example: With timezone specified</a></h2>
+<h2 id="example-with-timezone-specified"><a class="doc-anchor" href="#example-with-timezone-specified">§</a>Example: With timezone specified</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::timezone::Tz;
 <span class="comment">// Corresponds to single element array with entry 1970-05-10T00:25:11+10:00
 </span><span class="kw">let </span>arr = TimestampSecondArray::from(<span class="macro">vec!</span>[<span class="number">11111111</span>]).with_timezone(<span class="string">"+10:00"</span>.to_string());
diff --git a/arrow/array/array/type.UInt16Array.html b/arrow/array/array/type.UInt16Array.html
index 83d2b21b81..d9a838d2d4 100644
--- a/arrow/array/array/type.UInt16Array.html
+++ b/arrow/array/array/type.UInt16Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;u16&gt;&gt;
diff --git a/arrow/array/array/type.UInt16DictionaryArray.html b/arrow/array/array/type.UInt16DictionaryArray.html
index 89e26710c4..f1c7354eb5 100644
--- a/arrow/array/array/type.UInt16DictionaryArray.html
+++ b/arrow/array/array/type.UInt16DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.UInt32Array.html b/arrow/array/array/type.UInt32Array.html
index 4d258d43ee..602fe0e92f 100644
--- a/arrow/array/array/type.UInt32Array.html
+++ b/arrow/array/array/type.UInt32Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;u32&gt;&gt;
diff --git a/arrow/array/array/type.UInt32DictionaryArray.html b/arrow/array/array/type.UInt32DictionaryArray.html
index e8058594bd..9ff485b192 100644
--- a/arrow/array/array/type.UInt32DictionaryArray.html
+++ b/arrow/array/array/type.UInt32DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.UInt64Array.html b/arrow/array/array/type.UInt64Array.html
index b60832c283..314b9da38b 100644
--- a/arrow/array/array/type.UInt64Array.html
+++ b/arrow/array/array/type.UInt64Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;u64&gt;&gt;
diff --git a/arrow/array/array/type.UInt64DictionaryArray.html b/arrow/array/array/type.UInt64DictionaryArray.html
index 17d2d17f76..3c682a85db 100644
--- a/arrow/array/array/type.UInt64DictionaryArray.html
+++ b/arrow/array/array/type.UInt64DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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" [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/array/type.UInt8Array.html b/arrow/array/array/type.UInt8Array.html
index 8073616e3e..6d609c2be9 100644
--- a/arrow/array/array/type.UInt8Array.html
+++ b/arrow/array/array/type.UInt8Array.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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=".. [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#examples">Examples</a></h2>
+<h2 id="examples"><a class="doc-anchor" href="#examples">§</a>Examples</h2>
 <p>Construction</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create from Vec&lt;Option&lt;u8&gt;&gt;
diff --git a/arrow/array/array/type.UInt8DictionaryArray.html b/arrow/array/array/type.UInt8DictionaryArray.html
index 40e4c94234..36ae12b21f 100644
--- a/arrow/array/array/type.UInt8DictionaryArray.html
+++ b/arrow/array/array/type.UInt8DictionaryArray.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example-using-collect">Example: Using <code>collect</code></a></h2>
+<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();
 <span class="kw">let </span>values: Arc&lt;<span class="kw">dyn </span>Array&gt; = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">"a"</span>, <span class="string">"b"</span>, <span class="string">"c"</span>]));
diff --git a/arrow/array/builder/fn.make_builder.html b/arrow/array/builder/fn.make_builder.html
index cd0896f985..340d1885f0 100644
--- a/arrow/array/builder/fn.make_builder.html
+++ b/arrow/array/builder/fn.make_builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/builder/index.html b/arrow/array/builder/index.html
index 9dc5cdd866..425180ffd7 100644
--- a/arrow/array/builder/index.html
+++ b/arrow/array/builder/index.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#basic-usage">Basic Usage</a></h2>
+<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>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>a = Int32Builder::new();
@@ -18,7 +18,7 @@ a.append_null();
 <span class="kw">let </span>a = a.finish();
 
 <span class="macro">assert_eq!</span>(a, StringArray::from_iter([<span class="prelude-val">Some</span>(<span class="string">"foo"</span>), <span class="prelude-val">Some</span>(<span class="string">"bar"</span>), <span class="prelude-val">None</span>]));</code></pre></div>
-<h2 id="nested-usage"><a href="#nested-usage">Nested Usage</a></h2>
+<h2 id="nested-usage"><a class="doc-anchor" href="#nested-usage">§</a>Nested Usage</h2>
 <p>Builders can also be used to build more complex nested arrays, such as lists</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>a = ListBuilder::new(Int32Builder::new());
@@ -44,7 +44,7 @@ a.append(<span class="bool-val">true</span>);
     <span class="prelude-val">Some</span>(<span class="macro">vec!</span>[]),
     <span class="prelude-val">Some</span>(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">3</span>), <span class="prelude-val">None</span>])]
 ))</code></pre></div>
-<h2 id="custom-builders"><a href="#custom-builders">Custom Builders</a></h2>
+<h2 id="custom-builders"><a class="doc-anchor" href="#custom-builders">§</a>Custom Builders</h2>
 <p>It is common to have a collection of statically defined Rust types that
 you want to convert to Arrow arrays.</p>
 <p>An example of doing so is below</p>
@@ -104,6 +104,6 @@ you want to convert to Arrow arrays.</p>
     builder.extend(rows);
     RecordBatch::from(<span class="kw-2">&amp;</span>builder.finish())
 }</code></pre></div>
-</div></details><h2 id="structs" class="section-header"><a href="#structs">Structs</a></h2><ul class="item-table"><li><div class="item-name"><a class="struct" href="struct.BooleanBufferBuilder.html" title="struct arrow::array::builder::BooleanBufferBuilder">BooleanBufferBuilder</a></div><div class="desc docblock-short">Builder for <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer"><code>BooleanBuffer</code></a></div></li><li><div class="item-name [...]
+</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.BooleanBufferBuilder.html" title="struct arrow::array::builder::BooleanBufferBuilder">BooleanBufferBuilder</a></div><div class="desc docblock-short">Builder for <a href="../../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer"><code>BooleanBuffer</code></a></div></li><li><div  [...]
 This function is useful to construct arrays from an arbitrary vectors with known/expected
-schema.</div></li></ul><h2 id="types" class="section-header"><a href="#types">Type Aliases</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.BinaryBuilder.html" title="type arrow::array::builder::BinaryBuilder">BinaryBuilder</a></div><div class="desc docblock-short">Builder for <a href="../type.BinaryArray.html" title="type arrow::array::BinaryArray"><code>BinaryArray</code></a></div></li><li><div class="item-name"><a class="type" href="type.BinaryDicti [...]
\ No newline at end of file
+schema.</div></li></ul><h2 id="types" class="section-header">Type Aliases<a href="#types" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.BinaryBuilder.html" title="type arrow::array::builder::BinaryBuilder">BinaryBuilder</a></div><div class="desc docblock-short">Builder for <a href="../type.BinaryArray.html" title="type arrow::array::BinaryArray"><code>BinaryArray</code></a></div></li><li><div class="item-name"><a class="type" href=" [...]
\ No newline at end of file
diff --git a/arrow/array/builder/struct.BooleanBufferBuilder.html b/arrow/array/builder/struct.BooleanBufferBuilder.html
index f9a2c2053d..44e1712318 100644
--- a/arrow/array/builder/struct.BooleanBufferBuilder.html
+++ b/arrow/array/builder/struct.BooleanBufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -26,7 +26,7 @@ growing it (potentially reallocating it) and writing <code>false</code> in the n
 </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 [...]
 <p><code>to_set</code> is a slice of bits packed LSB-first into <code>[u8]</code></p>
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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> [...]
@@ -36,14 +36,14 @@ growing it (potentially reallocating it) and writing <code>false</code> in the 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-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>< [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 8ff9a4e3c6..f195f9da94 100644
--- a/arrow/array/builder/struct.BooleanBuilder.html
+++ b/arrow/array/builder/struct.BooleanBuilder.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 `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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
 }</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 href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <p>Create a <code>BooleanArray</code> from a <code>BooleanBuilder</code></p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -55,14 +55,14 @@ b.append_value(<span class="bool-val">true</span>);
     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:/ [...]
-    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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 1077f432b0..e165d41443 100644
--- a/arrow/array/builder/struct.BufferBuilder.html
+++ b/arrow/array/builder/struct.BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -8,7 +8,7 @@
 <p>A <a href="../../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a> is the underlying data structure of Arrow’s Arrays.</p>
 <p>For all supported types, there are type definitions for the
 generic version of <code>BufferBuilder&lt;T&gt;</code>, e.g. <code>BufferBuilder</code>.</p>
-<h2 id="example"><a href="#example">Example:</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h2>
 <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">100</span>);
 builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">43</span>, <span class="number">44</span>]);
@@ -26,21 +26,21 @@ Also the
 <a href="struct.BufferBuilder.html#method.append_slice" title="method arrow::array::builder::BufferBuilder::append_slice"><code>append_slice()</code></a> and
 <a href="struct.BufferBuilder.html#method.advance" title="method arrow::array::builder::BufferBuilder::advance"><code>advance()</code></a>
 methods automatically increase the capacity if needed.</p>
-<h5 id="example-1"><a href="#example-1">Example:</a></h5>
+<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">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 [...]
-<h5 id="example-2"><a href="#example-2">Example:</a></h5>
+<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>
-<h5 id="example-3"><a href="#example-3">Example:</a></h5>
+<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>);
@@ -55,14 +55,14 @@ 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
 as they still require physical memory space.</p>
-<h5 id="example-4"><a href="#example-4">Example:</a></h5>
+<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">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 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 [...]
-<h5 id="example-5"><a href="#example-5">Example:</a></h5>
+<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>);
@@ -70,7 +70,7 @@ 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,
 growing the internal buffer as needed.</p>
-<h5 id="example-6"><a href="#example-6">Example:</a></h5>
+<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>
 <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>);
@@ -78,14 +78,14 @@ 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 [...]
 growing the internal buffer as needed.</p>
-<h5 id="example-7"><a href="#example-7">Example:</a></h5>
+<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">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 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 [...]
-<h5 id="example-8"><a href="#example-8">Example:</a></h5>
+<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>);
 builder.append_n_zeroed(<span class="number">3</span>);
@@ -93,7 +93,7 @@ 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 [...]
-<h5 id="example-9"><a href="#example-9">Example:</a></h5>
+<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>]);
@@ -108,7 +108,7 @@ 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 [...]
-<h5 id="example-10"><a href="#example-10">Example:</a></h5>
+<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>);
 
@@ -119,7 +119,7 @@ builder.as_slice_mut()[<span class="number">1</span>] = <span class="number">4.2
 <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 [...]
 <p>If <code>len</code> is greater than the builder’s current length, this has no effect</p>
-<h5 id="example-11"><a href="#example-11">Example:</a></h5>
+<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>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u16&gt;::new(<span class="number">10</span>);
 
@@ -134,11 +134,11 @@ builder.append(<span class="number">12</span>);
 </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>(
     &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 href="#safety">Safety</a></h5>
+)</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 [...]
-<h5 id="example-12"><a href="#example-12">Example:</a></h5>
+<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>);
 builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">44</span>, <span class="number">46</span>]);
@@ -152,8 +152,8 @@ builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</sp
     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-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#164">source</a><a href="#method.from-2" 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-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#376">source</a><a href="#method.from-1" 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 [...]
     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 [...]
@@ -161,14 +161,14 @@ builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</sp
     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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 6f7265d611..18ee7f5f7c 100644
--- a/arrow/array/builder/struct.FixedSizeBinaryBuilder.html
+++ b/arrow/array/builder/struct.FixedSizeBinaryBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -36,14 +36,14 @@ distinct value element.</p>
 </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: '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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 222046573d..21d4726bc0 100644
--- a/arrow/array/builder/struct.FixedSizeListBuilder.html
+++ b/arrow/array/builder/struct.FixedSizeListBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -74,14 +74,14 @@ but you must call <a href="#method.append"><code>append</code></a> to delimit ea
     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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 4c58495d81..5858b66d8c 100644
--- a/arrow/array/builder/struct.GenericByteBuilder.html
+++ b/arrow/array/builder/struct.GenericByteBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -22,11 +22,11 @@ The size of the preallocated buffer of offsets is the number of items plus one.<
     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;
 ) -&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> from buffers.</p>
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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 [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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>(
     &amp;mut self,
@@ -59,14 +59,14 @@ succeeded. <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html#
     &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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 13aec0d1f0..3cdf249a42 100644
--- a/arrow/array/builder/struct.GenericByteDictionaryBuilder.html
+++ b/arrow/array/builder/struct.GenericByteDictionaryBuilder.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="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= [...]
+<!DOCTYPE html><html lang="en"><head><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>{
@@ -27,7 +27,7 @@ result in an ordered dictionary.</p>
 ) -&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 [...]
 which is initialized with the given values.
 The indices of those dictionary values are used as keys.</p>
-<h5 id="example"><a href="#example">Example</a></h5>
+<h5 id="example"><a class="doc-anchor" href="#example">§</a>Example</h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>dictionary_values = StringArray::from(<span class="macro">vec!</span>[<span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="string">"abc"</span>), <span class="prelude-val">Some</span>(<span class="string">"def"</span>)]);
 
@@ -51,14 +51,14 @@ 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 [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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>(
     &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 href="#panics-1">Panics</a></h5>
+<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>< [...]
@@ -87,14 +87,14 @@ value is appended to the values array.</p>
     &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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 61b0abdf83..a24c670df1 100644
--- a/arrow/array/builder/struct.GenericByteRunBuilder.html
+++ b/arrow/array/builder/struct.GenericByteRunBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>{
@@ -9,7 +9,7 @@
     current_run_end_index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     prev_run_end_index: <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.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray</code></a> of <a href="../struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray"><code>GenericByteArray</code></a></p>
-<h2 id="example"><a href="#example">Example:</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 
 <span class="kw">let </span><span class="kw-2">mut </span>builder =
@@ -83,14 +83,14 @@ the eventual runs array.</p>
     &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.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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 4f9e7503e9..41c151a92b 100644
--- a/arrow/array/builder/struct.GenericListBuilder.html
+++ b/arrow/array/builder/struct.GenericListBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>{
@@ -7,7 +7,7 @@
     values_builder: T,
 }</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>
 <p>Use <a href="type.ListBuilder.html" title="type arrow::array::builder::ListBuilder"><code>ListBuilder</code></a> to build <a href="../type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a>s and <a href="type.LargeListBuilder.html" title="type arrow::array::builder::LargeListBuilder"><code>LargeListBuilder</code></a> to build <a href="../type.LargeListArray.html" title="type arrow::array::LargeListArray"><code>LargeListArray</code></a>s.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <p>Here is code that constructs a ListArray with the contents:
 <code>[[A,B,C], [], NULL, [D], [NULL, F]]</code></p>
 
@@ -70,7 +70,7 @@ builder.append(<span class="bool-val">true</span>);
 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#172">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#182">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 [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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#244-247">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
     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;,
@@ -142,14 +142,14 @@ builder.append(<span class="bool-val">true</span>);
     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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 6f62b691e5..83c0452c82 100644
--- a/arrow/array/builder/struct.MapBuilder.html
+++ b/arrow/array/builder/struct.MapBuilder.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="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="../. [...]
+<!DOCTYPE html><html lang="en"><head><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>{
@@ -69,14 +69,14 @@ builder.append(<span class="bool-val">false</span>).unwrap();
     V: <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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 65a7a9dbde..315b9d848d 100644
--- a/arrow/array/builder/struct.MapFieldNames.html
+++ b/arrow/array/builder/struct.MapFieldNames.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
@@ -10,15 +10,15 @@
 </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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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: <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 eb79309962..b2698f0e6c 100644
--- a/arrow/array/builder/struct.NullBuilder.html
+++ b/arrow/array/builder/struct.NullBuilder.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 `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=".. [...]
+<!DOCTYPE html><html lang="en"><head><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 href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <p>Create a <code>NullArray</code> from a <code>NullBuilder</code></p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -34,14 +34,14 @@ b.append_empty_values(<span class="number">3</span>);
 </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: '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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 e71ab1f49e..45060fd170 100644
--- a/arrow/array/builder/struct.PrimitiveBuilder.html
+++ b/arrow/array/builder/struct.PrimitiveBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -16,7 +16,7 @@
 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 href="#panics">Panics</a></h5>
+<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 [...]
@@ -29,13 +29,13 @@ for <a href="../../datatypes/enum.DataType.html#variant.Timestamp" title="varian
     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 href="#panics-1">Panics</a></h5>
+<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>(
     &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 href="#safety">Safety</a></h5>
+<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 [...]
@@ -75,14 +75,14 @@ the iterator implement <code>TrustedLen</code> once that is stabilized.</p>
     &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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 bb847a37f7..d70aa2a95a 100644
--- a/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html
+++ b/arrow/array/builder/struct.PrimitiveDictionaryBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>{
@@ -6,7 +6,7 @@
     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 [...]
 }</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 href="#example">Example:</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 
 <span class="kw">let </span><span class="kw-2">mut </span>builder = PrimitiveDictionaryBuilder::&lt;UInt8Type, UInt32Type&gt;::new();
@@ -37,13 +37,13 @@
     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 href="#panics">Panics</a></h5>
+<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>(
     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 href="#safety">Safety</a></h5>
+<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>(
     keys_capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -60,14 +60,14 @@
 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 [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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>(
     &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 href="#panics-2">Panics</a></h5>
+<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 [...]
@@ -98,14 +98,14 @@ value is appended to the values array.</p>
     &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.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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 bfe6e9a3b9..17da108853 100644
--- a/arrow/array/builder/struct.PrimitiveRunBuilder.html
+++ b/arrow/array/builder/struct.PrimitiveRunBuilder.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="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/ [...]
+<!DOCTYPE html><html lang="en"><head><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>{
@@ -8,7 +8,7 @@
     current_run_end_index: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     prev_run_end_index: <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.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray</code></a> of <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray</code></a></p>
-<h2 id="example"><a href="#example">Example:</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 
 <span class="kw">let </span><span class="kw-2">mut </span>builder =
@@ -76,14 +76,14 @@ the eventual runs array.</p>
     &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.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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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: <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 0ae65a373f..989abe602e 100644
--- a/arrow/array/builder/struct.StructBuilder.html
+++ b/arrow/array/builder/struct.StructBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -39,13 +39,13 @@ type. In this case, one can first cast this into a <code>Any</code>, and then us
 </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: '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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 860d290880..87e47886b8 100644
--- a/arrow/array/builder/struct.UnionBuilder.html
+++ b/arrow/array/builder/struct.UnionBuilder.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="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=" [...]
+<!DOCTYPE html><html lang="en"><head><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;,
@@ -59,12 +59,12 @@ specifying which field (child) to use.</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-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=" [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 fb724c2149..7f1a2f25eb 100644
--- a/arrow/array/builder/trait.ArrayBuilder.html
+++ b/arrow/array/builder/trait.ArrayBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>;
@@ -11,7 +11,7 @@
     // Provided method
     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> { ... }
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Trait for dealing with different array builders at runtime</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>data_builders: Vec&lt;Box&lt;<span class="kw">dyn </span>ArrayBuilder&gt;&gt; = <span class="macro">vec!</span>[
diff --git a/arrow/array/builder/type.BinaryBuilder.html b/arrow/array/builder/type.BinaryBuilder.html
index 7d4dd22fb9..d0a2754e01 100644
--- a/arrow/array/builder/type.BinaryBuilder.html
+++ b/arrow/array/builder/type.BinaryBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.BinaryDictionaryBuilder.html b/arrow/array/builder/type.BinaryDictionaryBuilder.html
index bc7e7746cf..4561b45fdd 100644
--- a/arrow/array/builder/type.BinaryDictionaryBuilder.html
+++ b/arrow/array/builder/type.BinaryDictionaryBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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.
diff --git a/arrow/array/builder/type.BinaryRunBuilder.html b/arrow/array/builder/type.BinaryRunBuilder.html
index 2c7432bd7b..bb4f1a533b 100644
--- a/arrow/array/builder/type.BinaryRunBuilder.html
+++ b/arrow/array/builder/type.BinaryRunBuilder.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="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" [...]
+<!DOCTYPE html><html lang="en"><head><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`.
diff --git a/arrow/array/builder/type.Date32BufferBuilder.html b/arrow/array/builder/type.Date32BufferBuilder.html
index 58e190fd5d..f17f166706 100644
--- a/arrow/array/builder/type.Date32BufferBuilder.html
+++ b/arrow/array/builder/type.Date32BufferBuilder.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="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" [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Date32Builder.html b/arrow/array/builder/type.Date32Builder.html
index b16d270792..6ee404aa68 100644
--- a/arrow/array/builder/type.Date32Builder.html
+++ b/arrow/array/builder/type.Date32Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Date64BufferBuilder.html b/arrow/array/builder/type.Date64BufferBuilder.html
index a59e52516e..83827b4486 100644
--- a/arrow/array/builder/type.Date64BufferBuilder.html
+++ b/arrow/array/builder/type.Date64BufferBuilder.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="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" [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Date64Builder.html b/arrow/array/builder/type.Date64Builder.html
index 27b230a904..61b1f1601b 100644
--- a/arrow/array/builder/type.Date64Builder.html
+++ b/arrow/array/builder/type.Date64Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Decimal128BufferBuilder.html b/arrow/array/builder/type.Decimal128BufferBuilder.html
index 3407c1b604..967254d0f5 100644
--- a/arrow/array/builder/type.Decimal128BufferBuilder.html
+++ b/arrow/array/builder/type.Decimal128BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Decimal128Builder.html b/arrow/array/builder/type.Decimal128Builder.html
index d4e07ca04e..96b48f5078 100644
--- a/arrow/array/builder/type.Decimal128Builder.html
+++ b/arrow/array/builder/type.Decimal128Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Decimal256BufferBuilder.html b/arrow/array/builder/type.Decimal256BufferBuilder.html
index 51d317cad9..eb4ab956a8 100644
--- a/arrow/array/builder/type.Decimal256BufferBuilder.html
+++ b/arrow/array/builder/type.Decimal256BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Decimal256Builder.html b/arrow/array/builder/type.Decimal256Builder.html
index 707a4a4244..8efa23b272 100644
--- a/arrow/array/builder/type.Decimal256Builder.html
+++ b/arrow/array/builder/type.Decimal256Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html b/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html
index 25f2be78da..74f8058bd0 100644
--- a/arrow/array/builder/type.DurationMicrosecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationMicrosecondBufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.DurationMicrosecondBuilder.html b/arrow/array/builder/type.DurationMicrosecondBuilder.html
index 1a745a76d0..e6da938778 100644
--- a/arrow/array/builder/type.DurationMicrosecondBuilder.html
+++ b/arrow/array/builder/type.DurationMicrosecondBuilder.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="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"  [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.DurationMillisecondBufferBuilder.html b/arrow/array/builder/type.DurationMillisecondBufferBuilder.html
index ca9a327eae..5b224da0e5 100644
--- a/arrow/array/builder/type.DurationMillisecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationMillisecondBufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.DurationMillisecondBuilder.html b/arrow/array/builder/type.DurationMillisecondBuilder.html
index 0023beccd6..70256bee75 100644
--- a/arrow/array/builder/type.DurationMillisecondBuilder.html
+++ b/arrow/array/builder/type.DurationMillisecondBuilder.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="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"  [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.DurationNanosecondBufferBuilder.html b/arrow/array/builder/type.DurationNanosecondBufferBuilder.html
index aa7563c535..82868b1122 100644
--- a/arrow/array/builder/type.DurationNanosecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationNanosecondBufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.DurationNanosecondBuilder.html b/arrow/array/builder/type.DurationNanosecondBuilder.html
index 5ac041f300..7b65e1ec96 100644
--- a/arrow/array/builder/type.DurationNanosecondBuilder.html
+++ b/arrow/array/builder/type.DurationNanosecondBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.DurationSecondBufferBuilder.html b/arrow/array/builder/type.DurationSecondBufferBuilder.html
index 3f2657c2a5..0f8884067b 100644
--- a/arrow/array/builder/type.DurationSecondBufferBuilder.html
+++ b/arrow/array/builder/type.DurationSecondBufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.DurationSecondBuilder.html b/arrow/array/builder/type.DurationSecondBuilder.html
index 69a53732b5..eed0567a8a 100644
--- a/arrow/array/builder/type.DurationSecondBuilder.html
+++ b/arrow/array/builder/type.DurationSecondBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Float16BufferBuilder.html b/arrow/array/builder/type.Float16BufferBuilder.html
index 58faae1705..45d58eae00 100644
--- a/arrow/array/builder/type.Float16BufferBuilder.html
+++ b/arrow/array/builder/type.Float16BufferBuilder.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="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=" [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Float16Builder.html b/arrow/array/builder/type.Float16Builder.html
index 4caddd8844..ab98796a6b 100644
--- a/arrow/array/builder/type.Float16Builder.html
+++ b/arrow/array/builder/type.Float16Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Float32BufferBuilder.html b/arrow/array/builder/type.Float32BufferBuilder.html
index 1e45b0cf9e..0babacb32b 100644
--- a/arrow/array/builder/type.Float32BufferBuilder.html
+++ b/arrow/array/builder/type.Float32BufferBuilder.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="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=" [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Float32Builder.html b/arrow/array/builder/type.Float32Builder.html
index 86fb17e941..856fdee061 100644
--- a/arrow/array/builder/type.Float32Builder.html
+++ b/arrow/array/builder/type.Float32Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Float64BufferBuilder.html b/arrow/array/builder/type.Float64BufferBuilder.html
index 20f09d743b..a16fc07414 100644
--- a/arrow/array/builder/type.Float64BufferBuilder.html
+++ b/arrow/array/builder/type.Float64BufferBuilder.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="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=" [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Float64Builder.html b/arrow/array/builder/type.Float64Builder.html
index 8561251058..140d6f4b7b 100644
--- a/arrow/array/builder/type.Float64Builder.html
+++ b/arrow/array/builder/type.Float64Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.GenericBinaryBuilder.html b/arrow/array/builder/type.GenericBinaryBuilder.html
index d7ae1da2ee..db4c7106d5 100644
--- a/arrow/array/builder/type.GenericBinaryBuilder.html
+++ b/arrow/array/builder/type.GenericBinaryBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.GenericStringBuilder.html b/arrow/array/builder/type.GenericStringBuilder.html
index 7723758de0..828f70d2f6 100644
--- a/arrow/array/builder/type.GenericStringBuilder.html
+++ b/arrow/array/builder/type.GenericStringBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>
diff --git a/arrow/array/builder/type.Int16BufferBuilder.html b/arrow/array/builder/type.Int16BufferBuilder.html
index af7706dc1c..986c773565 100644
--- a/arrow/array/builder/type.Int16BufferBuilder.html
+++ b/arrow/array/builder/type.Int16BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Int16Builder.html b/arrow/array/builder/type.Int16Builder.html
index 094a6b4226..038696245d 100644
--- a/arrow/array/builder/type.Int16Builder.html
+++ b/arrow/array/builder/type.Int16Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Int32BufferBuilder.html b/arrow/array/builder/type.Int32BufferBuilder.html
index e1f5b60a25..b64f7fb3df 100644
--- a/arrow/array/builder/type.Int32BufferBuilder.html
+++ b/arrow/array/builder/type.Int32BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Int32Builder.html b/arrow/array/builder/type.Int32Builder.html
index d8d00d3f57..96831746d4 100644
--- a/arrow/array/builder/type.Int32Builder.html
+++ b/arrow/array/builder/type.Int32Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Int64BufferBuilder.html b/arrow/array/builder/type.Int64BufferBuilder.html
index be0c7d85d7..20bd6a1ca5 100644
--- a/arrow/array/builder/type.Int64BufferBuilder.html
+++ b/arrow/array/builder/type.Int64BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Int64Builder.html b/arrow/array/builder/type.Int64Builder.html
index 71248d44fc..91ee10cb97 100644
--- a/arrow/array/builder/type.Int64Builder.html
+++ b/arrow/array/builder/type.Int64Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.Int8BufferBuilder.html b/arrow/array/builder/type.Int8BufferBuilder.html
index 76db9a1426..10f90a36e5 100644
--- a/arrow/array/builder/type.Int8BufferBuilder.html
+++ b/arrow/array/builder/type.Int8BufferBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.Int8Builder.html b/arrow/array/builder/type.Int8Builder.html
index 1189bbd7a8..0f3fa2cee5 100644
--- a/arrow/array/builder/type.Int8Builder.html
+++ b/arrow/array/builder/type.Int8Builder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html b/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html
index f8af5f5549..79d74d29f6 100644
--- a/arrow/array/builder/type.IntervalDayTimeBufferBuilder.html
+++ b/arrow/array/builder/type.IntervalDayTimeBufferBuilder.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="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= [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.IntervalDayTimeBuilder.html b/arrow/array/builder/type.IntervalDayTimeBuilder.html
index 97d43427f4..8b1e5a93a5 100644
--- a/arrow/array/builder/type.IntervalDayTimeBuilder.html
+++ b/arrow/array/builder/type.IntervalDayTimeBuilder.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="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" [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html b/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html
index 1f928d731a..69df6be560 100644
--- a/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.html
+++ b/arrow/array/builder/type.IntervalMonthDayNanoBufferBuilder.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="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">< [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html b/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html
index ac1f8311e0..43c5ba56cd 100644
--- a/arrow/array/builder/type.IntervalMonthDayNanoBuilder.html
+++ b/arrow/array/builder/type.IntervalMonthDayNanoBuilder.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="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  [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html b/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html
index c72bd578da..8abcdb5277 100644
--- a/arrow/array/builder/type.IntervalYearMonthBufferBuilder.html
+++ b/arrow/array/builder/type.IntervalYearMonthBufferBuilder.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="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= [...]
+<!DOCTYPE html><html lang="en"><head><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>,
diff --git a/arrow/array/builder/type.IntervalYearMonthBuilder.html b/arrow/array/builder/type.IntervalYearMonthBuilder.html
index 3f9f64c7a2..313741e5a4 100644
--- a/arrow/array/builder/type.IntervalYearMonthBuilder.html
+++ b/arrow/array/builder/type.IntervalYearMonthBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.LargeBinaryBuilder.html b/arrow/array/builder/type.LargeBinaryBuilder.html
index 2ebdf59657..2207c3ae39 100644
--- a/arrow/array/builder/type.LargeBinaryBuilder.html
+++ b/arrow/array/builder/type.LargeBinaryBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html b/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html
index cd569201fc..ff3b816007 100644
--- a/arrow/array/builder/type.LargeBinaryDictionaryBuilder.html
+++ b/arrow/array/builder/type.LargeBinaryDictionaryBuilder.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="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= [...]
+<!DOCTYPE html><html lang="en"><head><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,
diff --git a/arrow/array/builder/type.LargeBinaryRunBuilder.html b/arrow/array/builder/type.LargeBinaryRunBuilder.html
index 49e7828657..de16e04514 100644
--- a/arrow/array/builder/type.LargeBinaryRunBuilder.html
+++ b/arrow/array/builder/type.LargeBinaryRunBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.LargeListBuilder.html b/arrow/array/builder/type.LargeListBuilder.html
index 51c464a075..1d928c63ef 100644
--- a/arrow/array/builder/type.LargeListBuilder.html
+++ b/arrow/array/builder/type.LargeListBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.LargeStringBuilder.html b/arrow/array/builder/type.LargeStringBuilder.html
index 26d0524567..1aa4d0c2ca 100644
--- a/arrow/array/builder/type.LargeStringBuilder.html
+++ b/arrow/array/builder/type.LargeStringBuilder.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="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 [...]
+<!DOCTYPE html><html lang="en"><head><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;,
diff --git a/arrow/array/builder/type.LargeStringDictionaryBuilder.html b/arrow/array/builder/type.LargeStringDictionaryBuilder.html
index 3b7c395e70..dad4c52c71 100644
--- a/arrow/array/builder/type.LargeStringDictionaryBuilder.html
+++ b/arrow/array/builder/type.LargeStringDictionaryBuilder.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="Builder for `DictionaryArray` of `LargeStringArray`"><title>LargeStringDictionaryBuilder 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= [...]
+<!DOCTYPE html><html lang="en"><head><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 `LargeStringArray`"><title>LargeStringDictionaryBuilder 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 LargeStringDictionaryBuilder&lt;K&gt; {
     state: RandomState,
diff --git a/arrow/array/builder/type.LargeStringRunBuilder.html b/arrow/array/builder/type.LargeStringRunBuilder.html
index 18712efe07..a7b9ccaeae 100644
--- a/arrow/array/builder/type.LargeStringRunBuilder.html
+++ b/arrow/array/builder/type.LargeStringRunBuilder.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="Builder for `RunArray` of `LargeStringArray`"><title>LargeStringRunBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 `LargeStringArray`"><title>LargeStringRunBuilder 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 LargeStringRunBuilder&lt;K&gt; {
     run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
diff --git a/arrow/array/builder/type.ListBuilder.html b/arrow/array/builder/type.ListBuilder.html
index 8788af860d..e4165d671b 100644
--- a/arrow/array/builder/type.ListBuilder.html
+++ b/arrow/array/builder/type.ListBuilder.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="Builder for `ListArray`"><title>ListBuilder 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=".. [...]
+<!DOCTYPE html><html lang="en"><head><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 `ListArray`"><title>ListBuilder 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 ListBuilder&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.i32.html">i32</a>&gt;,
diff --git a/arrow/array/builder/type.StringBuilder.html b/arrow/array/builder/type.StringBuilder.html
index c76a137f1f..a549159b6e 100644
--- a/arrow/array/builder/type.StringBuilder.html
+++ b/arrow/array/builder/type.StringBuilder.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="Builder for `StringArray`"><title>StringBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 `StringArray`"><title>StringBuilder 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 StringBuilder {
     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;,
diff --git a/arrow/array/builder/type.StringDictionaryBuilder.html b/arrow/array/builder/type.StringDictionaryBuilder.html
index 9709e1a85d..2b24d0e70d 100644
--- a/arrow/array/builder/type.StringDictionaryBuilder.html
+++ b/arrow/array/builder/type.StringDictionaryBuilder.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="Builder for `DictionaryArray` of `StringArray`"><title>StringDictionaryBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 `StringArray`"><title>StringDictionaryBuilder 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 Strings.
diff --git a/arrow/array/builder/type.StringRunBuilder.html b/arrow/array/builder/type.StringRunBuilder.html
index 83b1b70f90..bf5f2cf593 100644
--- a/arrow/array/builder/type.StringRunBuilder.html
+++ b/arrow/array/builder/type.StringRunBuilder.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="Builder for `RunArray` of `StringArray`"><title>StringRunBuilder 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" [...]
+<!DOCTYPE html><html lang="en"><head><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 `StringArray`"><title>StringRunBuilder 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`.
diff --git a/arrow/array/builder/type.Time32MillisecondBufferBuilder.html b/arrow/array/builder/type.Time32MillisecondBufferBuilder.html
index e6e60a4077..489c9d079d 100644
--- a/arrow/array/builder/type.Time32MillisecondBufferBuilder.html
+++ b/arrow/array/builder/type.Time32MillisecondBufferBuilder.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="Buffer builder for 32-bit elaspsed time since midnight of millisecond unit."><title>Time32MillisecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time since midnight of millisecond unit."><title>Time32MillisecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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 Time32MillisecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.Time32MillisecondBuilder.html b/arrow/array/builder/type.Time32MillisecondBuilder.html
index 8090c7f975..b3f5b65f65 100644
--- a/arrow/array/builder/type.Time32MillisecondBuilder.html
+++ b/arrow/array/builder/type.Time32MillisecondBuilder.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="A 32-bit elaspsed time in milliseconds array builder."><title>Time32MillisecondBuilder 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="f [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time in milliseconds array builder."><title>Time32MillisecondBuilder 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="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 Time32MillisecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.Time32SecondBufferBuilder.html b/arrow/array/builder/type.Time32SecondBufferBuilder.html
index 053df6df1a..e0e9cd8cd1 100644
--- a/arrow/array/builder/type.Time32SecondBufferBuilder.html
+++ b/arrow/array/builder/type.Time32SecondBufferBuilder.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="Buffer builder for 32-bit elaspsed time since midnight of second unit."><title>Time32SecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link r [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time since midnight of second unit."><title>Time32SecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link r [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 Time32SecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.Time32SecondBuilder.html b/arrow/array/builder/type.Time32SecondBuilder.html
index dc7fe70039..1a03ea6d11 100644
--- a/arrow/array/builder/type.Time32SecondBuilder.html
+++ b/arrow/array/builder/type.Time32SecondBuilder.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="A 32-bit elaspsed time in seconds array builder."><title>Time32SecondBuilder 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= [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time in seconds array builder."><title>Time32SecondBuilder 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 Time32SecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.Time64MicrosecondBufferBuilder.html b/arrow/array/builder/type.Time64MicrosecondBufferBuilder.html
index 1a81a464c5..d1364b79e9 100644
--- a/arrow/array/builder/type.Time64MicrosecondBufferBuilder.html
+++ b/arrow/array/builder/type.Time64MicrosecondBufferBuilder.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="Buffer builder for 64-bit elaspsed time since midnight of microsecond unit."><title>Time64MicrosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time since midnight of microsecond unit."><title>Time64MicrosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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 Time64MicrosecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.Time64MicrosecondBuilder.html b/arrow/array/builder/type.Time64MicrosecondBuilder.html
index 29a882e3db..554f73d0b7 100644
--- a/arrow/array/builder/type.Time64MicrosecondBuilder.html
+++ b/arrow/array/builder/type.Time64MicrosecondBuilder.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="A 64-bit elaspsed time in microseconds array builder."><title>Time64MicrosecondBuilder 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="f [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time in microseconds array builder."><title>Time64MicrosecondBuilder 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="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 Time64MicrosecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.Time64NanosecondBufferBuilder.html b/arrow/array/builder/type.Time64NanosecondBufferBuilder.html
index 5e818af01f..3e3b7f5d16 100644
--- a/arrow/array/builder/type.Time64NanosecondBufferBuilder.html
+++ b/arrow/array/builder/type.Time64NanosecondBufferBuilder.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="Buffer builder for 64-bit elaspsed time since midnight of nanosecond unit."><title>Time64NanosecondBufferBuilder in arrow::array::builder - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2" [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time since midnight of nanosecond unit."><title>Time64NanosecondBufferBuilder 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 Time64NanosecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.Time64NanosecondBuilder.html b/arrow/array/builder/type.Time64NanosecondBuilder.html
index 269d4cabc7..f36c417eb5 100644
--- a/arrow/array/builder/type.Time64NanosecondBuilder.html
+++ b/arrow/array/builder/type.Time64NanosecondBuilder.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="A 64-bit elaspsed time in nanoseconds array builder."><title>Time64NanosecondBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 elaspsed time in nanoseconds array builder."><title>Time64NanosecondBuilder 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 Time64NanosecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.TimestampMicrosecondBufferBuilder.html b/arrow/array/builder/type.TimestampMicrosecondBufferBuilder.html
index 23da3a7a55..e605df313c 100644
--- a/arrow/array/builder/type.TimestampMicrosecondBufferBuilder.html
+++ b/arrow/array/builder/type.TimestampMicrosecondBufferBuilder.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="Buffer builder for timestamp type of microsecond unit."><title>TimestampMicrosecondBufferBuilder 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="prel [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp type of microsecond unit."><title>TimestampMicrosecondBufferBuilder 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="prel [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 TimestampMicrosecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.TimestampMicrosecondBuilder.html b/arrow/array/builder/type.TimestampMicrosecondBuilder.html
index dfa90fcc72..3b7a0ffada 100644
--- a/arrow/array/builder/type.TimestampMicrosecondBuilder.html
+++ b/arrow/array/builder/type.TimestampMicrosecondBuilder.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="A timestamp microsecond array builder."><title>TimestampMicrosecondBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp microsecond array builder."><title>TimestampMicrosecondBuilder 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 TimestampMicrosecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.TimestampMillisecondBufferBuilder.html b/arrow/array/builder/type.TimestampMillisecondBufferBuilder.html
index a2e37f4888..08b63eda39 100644
--- a/arrow/array/builder/type.TimestampMillisecondBufferBuilder.html
+++ b/arrow/array/builder/type.TimestampMillisecondBufferBuilder.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="Buffer builder for timestamp type of millisecond unit."><title>TimestampMillisecondBufferBuilder 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="prel [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp type of millisecond unit."><title>TimestampMillisecondBufferBuilder 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="prel [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 TimestampMillisecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.TimestampMillisecondBuilder.html b/arrow/array/builder/type.TimestampMillisecondBuilder.html
index 06b365bd54..48578c80b0 100644
--- a/arrow/array/builder/type.TimestampMillisecondBuilder.html
+++ b/arrow/array/builder/type.TimestampMillisecondBuilder.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="A timestamp millisecond array builder."><title>TimestampMillisecondBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp millisecond array builder."><title>TimestampMillisecondBuilder 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 TimestampMillisecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.TimestampNanosecondBufferBuilder.html b/arrow/array/builder/type.TimestampNanosecondBufferBuilder.html
index 7c55e509bb..66d905f749 100644
--- a/arrow/array/builder/type.TimestampNanosecondBufferBuilder.html
+++ b/arrow/array/builder/type.TimestampNanosecondBufferBuilder.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="Buffer builder for timestamp type of nanosecond unit."><title>TimestampNanosecondBufferBuilder 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="preloa [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp type of nanosecond unit."><title>TimestampNanosecondBufferBuilder 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="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>< [...]
 </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 TimestampNanosecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.TimestampNanosecondBuilder.html b/arrow/array/builder/type.TimestampNanosecondBuilder.html
index 5ad1a866d3..46dfb40d8c 100644
--- a/arrow/array/builder/type.TimestampNanosecondBuilder.html
+++ b/arrow/array/builder/type.TimestampNanosecondBuilder.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="A timestamp nanosecond array builder."><title>TimestampNanosecondBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp nanosecond array builder."><title>TimestampNanosecondBuilder 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 TimestampNanosecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.TimestampSecondBufferBuilder.html b/arrow/array/builder/type.TimestampSecondBufferBuilder.html
index 7ca35e0186..251af677b8 100644
--- a/arrow/array/builder/type.TimestampSecondBufferBuilder.html
+++ b/arrow/array/builder/type.TimestampSecondBufferBuilder.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="Buffer builder for timestamp type of second unit."><title>TimestampSecondBufferBuilder 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="f [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp type of second unit."><title>TimestampSecondBufferBuilder 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="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 TimestampSecondBufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.TimestampSecondBuilder.html b/arrow/array/builder/type.TimestampSecondBuilder.html
index 481002d35e..c35aefb09e 100644
--- a/arrow/array/builder/type.TimestampSecondBuilder.html
+++ b/arrow/array/builder/type.TimestampSecondBuilder.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="A timestamp second array builder."><title>TimestampSecondBuilder 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" [...]
+<!DOCTYPE html><html lang="en"><head><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 timestamp second array builder."><title>TimestampSecondBuilder 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 TimestampSecondBuilder {
     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;,
diff --git a/arrow/array/builder/type.UInt16BufferBuilder.html b/arrow/array/builder/type.UInt16BufferBuilder.html
index 3380ae991c..5fa8578919 100644
--- a/arrow/array/builder/type.UInt16BufferBuilder.html
+++ b/arrow/array/builder/type.UInt16BufferBuilder.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="Buffer builder for usigned 16-bit integer type."><title>UInt16BufferBuilder 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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 16-bit integer type."><title>UInt16BufferBuilder 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 UInt16BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.UInt16Builder.html b/arrow/array/builder/type.UInt16Builder.html
index 88911792f0..42a7860c62 100644
--- a/arrow/array/builder/type.UInt16Builder.html
+++ b/arrow/array/builder/type.UInt16Builder.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="An usigned 16-bit integer array builder."><title>UInt16Builder 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" c [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 16-bit integer array builder."><title>UInt16Builder 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" 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>< [...]
 </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 UInt16Builder {
     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.u16.html">u16</a>&gt;,
diff --git a/arrow/array/builder/type.UInt32BufferBuilder.html b/arrow/array/builder/type.UInt32BufferBuilder.html
index d21a5935ba..af4bd10862 100644
--- a/arrow/array/builder/type.UInt32BufferBuilder.html
+++ b/arrow/array/builder/type.UInt32BufferBuilder.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="Buffer builder for usigned 32-bit integer type."><title>UInt32BufferBuilder 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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 32-bit integer type."><title>UInt32BufferBuilder 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 UInt32BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.UInt32Builder.html b/arrow/array/builder/type.UInt32Builder.html
index 8e49f78bf3..eb0e4873d5 100644
--- a/arrow/array/builder/type.UInt32Builder.html
+++ b/arrow/array/builder/type.UInt32Builder.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="An usigned 32-bit integer array builder."><title>UInt32Builder 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" c [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 32-bit integer array builder."><title>UInt32Builder 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" 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>< [...]
 </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 UInt32Builder {
     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.u32.html">u32</a>&gt;,
diff --git a/arrow/array/builder/type.UInt64BufferBuilder.html b/arrow/array/builder/type.UInt64BufferBuilder.html
index 70eeeebc5a..0c755262fe 100644
--- a/arrow/array/builder/type.UInt64BufferBuilder.html
+++ b/arrow/array/builder/type.UInt64BufferBuilder.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="Buffer builder for usigned 64-bit integer type."><title>UInt64BufferBuilder 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=" [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 64-bit integer type."><title>UInt64BufferBuilder 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 UInt64BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.UInt64Builder.html b/arrow/array/builder/type.UInt64Builder.html
index 2d821aaeed..42ab0bea6c 100644
--- a/arrow/array/builder/type.UInt64Builder.html
+++ b/arrow/array/builder/type.UInt64Builder.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="An usigned 64-bit integer array builder."><title>UInt64Builder 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" c [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 64-bit integer array builder."><title>UInt64Builder 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" 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>< [...]
 </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 UInt64Builder {
     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.u64.html">u64</a>&gt;,
diff --git a/arrow/array/builder/type.UInt8BufferBuilder.html b/arrow/array/builder/type.UInt8BufferBuilder.html
index e217d007c9..a2bbec02c3 100644
--- a/arrow/array/builder/type.UInt8BufferBuilder.html
+++ b/arrow/array/builder/type.UInt8BufferBuilder.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="Buffer builder for usigned 8-bit integer type."><title>UInt8BufferBuilder 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 8-bit integer type."><title>UInt8BufferBuilder 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 UInt8BufferBuilder {
     buffer: <a class="struct" href="../../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
diff --git a/arrow/array/builder/type.UInt8Builder.html b/arrow/array/builder/type.UInt8Builder.html
index 5784bf82da..a8d0e209bc 100644
--- a/arrow/array/builder/type.UInt8Builder.html
+++ b/arrow/array/builder/type.UInt8Builder.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="An usigned 8-bit integer array builder."><title>UInt8Builder 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" cro [...]
+<!DOCTYPE html><html lang="en"><head><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 usigned 8-bit integer array builder."><title>UInt8Builder 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" cro [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 UInt8Builder {
     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;,
diff --git a/arrow/array/cast/fn.as_boolean_array.html b/arrow/array/cast/fn.as_boolean_array.html
index eb56523b90..fb2a34beeb 100644
--- a/arrow/array/cast/fn.as_boolean_array.html
+++ b/arrow/array/cast/fn.as_boolean_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `BooleanArray`, panicking on failure."><title>as_boolean_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `BooleanArray`, panicking on failure."><title>as_boolean_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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>< [...]
 <a href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray"><code>BooleanArray</code></a>, panicking on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: ArrayRef = Arc::new(BooleanArray::from_iter(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="bool-val">true</span>)]));
 <span class="kw">let </span>boolean_array = as_boolean_array(<span class="kw-2">&amp;</span>arr);</code></pre></div>
diff --git a/arrow/array/cast/fn.as_decimal_array.html b/arrow/array/cast/fn.as_decimal_array.html
index 10a2680273..08e5e2cda3 100644
--- a/arrow/array/cast/fn.as_decimal_array.html
+++ b/arrow/array/cast/fn.as_decimal_array.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="Force downcast of an Array, such as an ArrayRef to Decimal128Array, panic’ing on failure."><title>as_decimal_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"> [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an Array, such as an ArrayRef to Decimal128Array, panic’ing on failure."><title>as_decimal_array in arrow::array::cast - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_dictionary_array.html b/arrow/array/cast/fn.as_dictionary_array.html
index 4540a5b3e3..f0083bc147 100644
--- a/arrow/array/cast/fn.as_dictionary_array.html
+++ b/arrow/array/cast/fn.as_dictionary_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `DictionaryArray&lt;T&gt;`, panic’ing on failure."><title>as_dictionary_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaaf [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `DictionaryArray&lt;T&gt;`, panic’ing on failure."><title>as_dictionary_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaaf [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="../type.ArrayRef.html" title="type arrow::array::Array [...]
 <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: DictionaryArray&lt;Int32Type&gt; = <span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"foo"</span>)].into_iter().collect();
 <span class="kw">let </span>arr: ArrayRef = std::sync::Arc::new(arr);
diff --git a/arrow/array/cast/fn.as_fixed_size_list_array.html b/arrow/array/cast/fn.as_fixed_size_list_array.html
index 9b401d7047..24c14ca418 100644
--- a/arrow/array/cast/fn.as_fixed_size_list_array.html
+++ b/arrow/array/cast/fn.as_fixed_size_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `FixedSizeListArray`, panicking on failure."><title>as_fixed_size_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafa [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `FixedSizeListArray`, panicking on failure."><title>as_fixed_size_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafa [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_generic_binary_array.html b/arrow/array/cast/fn.as_generic_binary_array.html
index c526cce82d..07f9b685d0 100644
--- a/arrow/array/cast/fn.as_generic_binary_array.html
+++ b/arrow/array/cast/fn.as_generic_binary_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="Force downcast of an `Array`, such as an `ArrayRef` to `GenericBinaryArray&lt;S&gt;`, panicking on failure."><title>as_generic_binary_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `GenericBinaryArray&lt;S&gt;`, panicking on failure."><title>as_generic_binary_array in arrow::array::cast - 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>< [...]
     arr: &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<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;S&gt;&gt;<div class="where">where
diff --git a/arrow/array/cast/fn.as_generic_list_array.html b/arrow/array/cast/fn.as_generic_list_array.html
index 02dc0c04a2..d00a7f524f 100644
--- a/arrow/array/cast/fn.as_generic_list_array.html
+++ b/arrow/array/cast/fn.as_generic_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `GenericListArray&lt;T&gt;`, panicking on failure."><title>as_generic_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98ef [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `GenericListArray&lt;T&gt;`, panicking on failure."><title>as_generic_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98ef [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     S: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="../type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef</code></a> to
 <a href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray&lt;T&gt;</code></a>, panicking on failure.</p>
diff --git a/arrow/array/cast/fn.as_large_list_array.html b/arrow/array/cast/fn.as_large_list_array.html
index 4ebb24827a..42c7b4fec7 100644
--- a/arrow/array/cast/fn.as_large_list_array.html
+++ b/arrow/array/cast/fn.as_large_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `LargeListArray`, panicking on failure."><title>as_large_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `LargeListArray`, panicking on failure."><title>as_large_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <a href="../type.LargeListArray.html" title="type arrow::array::LargeListArray"><code>LargeListArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_largestring_array.html b/arrow/array/cast/fn.as_largestring_array.html
index ea91669d5a..d9999496b0 100644
--- a/arrow/array/cast/fn.as_largestring_array.html
+++ b/arrow/array/cast/fn.as_largestring_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="Force downcast of an `Array`, such as an `ArrayRef` to  `LargeStringArray`, panicking on failure."><title>as_largestring_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `LargeStringArray`, panicking on failure."><title>as_largestring_array in arrow::array::cast - 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>< [...]
     arr: &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<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;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span> [...]
diff --git a/arrow/array/cast/fn.as_list_array.html b/arrow/array/cast/fn.as_list_array.html
index c7d2dac43c..a013eb56e7 100644
--- a/arrow/array/cast/fn.as_list_array.html
+++ b/arrow/array/cast/fn.as_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `ListArray`, panicking on failure."><title>as_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><li [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `ListArray`, panicking on failure."><title>as_list_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><li [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
 <a href="../type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_map_array.html b/arrow/array/cast/fn.as_map_array.html
index 5c8a8151e2..47a112d0d4 100644
--- a/arrow/array/cast/fn.as_map_array.html
+++ b/arrow/array/cast/fn.as_map_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="Force downcast of an `Array`, such as an `ArrayRef` to  `MapArray`, panicking on failure."><title>as_map_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><lin [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `MapArray`, panicking on failure."><title>as_map_array in arrow::array::cast - 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>< [...]
 <a href="../struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_null_array.html b/arrow/array/cast/fn.as_null_array.html
index 448d315236..ed1f045e54 100644
--- a/arrow/array/cast/fn.as_null_array.html
+++ b/arrow/array/cast/fn.as_null_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="Force downcast of an `Array`, such as an `ArrayRef` to  `NullArray`, panicking on failure."><title>as_null_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><l [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `NullArray`, panicking on failure."><title>as_null_array in arrow::array::cast - 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>< [...]
 <a href="../struct.NullArray.html" title="struct arrow::array::NullArray"><code>NullArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_primitive_array.html b/arrow/array/cast/fn.as_primitive_array.html
index 1a2e4f9b31..504a60cfb3 100644
--- a/arrow/array/cast/fn.as_primitive_array.html
+++ b/arrow/array/cast/fn.as_primitive_array.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="Force downcast of an `Array`, such as an `ArrayRef`, to `PrimitiveArray&lt;T&gt;`, panic’ing on failure."><title>as_primitive_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafa [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef`, to `PrimitiveArray&lt;T&gt;`, panic’ing on failure."><title>as_primitive_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafa [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="../type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>A [...]
 <a href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: ArrayRef = Arc::new(Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">1</span>)]));
 
diff --git a/arrow/array/cast/fn.as_run_array.html b/arrow/array/cast/fn.as_run_array.html
index 8c38f3d50a..fadf961a38 100644
--- a/arrow/array/cast/fn.as_run_array.html
+++ b/arrow/array/cast/fn.as_run_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `RunArray&lt;T&gt;`, panic’ing on failure."><title>as_run_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.wof [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `RunArray&lt;T&gt;`, panic’ing on failure."><title>as_run_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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>< [...]
     T: <a class="trait" href="../../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="../type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef</ [...]
 <a href="../struct.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: RunArray&lt;Int32Type&gt; = <span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"foo"</span>)].into_iter().collect();
 <span class="kw">let </span>arr: ArrayRef = std::sync::Arc::new(arr);
diff --git a/arrow/array/cast/fn.as_string_array.html b/arrow/array/cast/fn.as_string_array.html
index 129a486317..07b1ef6661 100644
--- a/arrow/array/cast/fn.as_string_array.html
+++ b/arrow/array/cast/fn.as_string_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `StringArray`, panicking on failure."><title>as_string_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2" [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `StringArray`, panicking on failure."><title>as_string_array in arrow::array::cast - 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>< [...]
     arr: &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<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;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span> [...]
 <a href="../type.StringArray.html" title="type arrow::array::StringArray"><code>StringArray</code></a>, panicking on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: ArrayRef = Arc::new(StringArray::from_iter(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"foo"</span>)]));
 <span class="kw">let </span>string_array = as_string_array(<span class="kw-2">&amp;</span>arr);</code></pre></div>
diff --git a/arrow/array/cast/fn.as_struct_array.html b/arrow/array/cast/fn.as_struct_array.html
index db4aec9148..441f2a284f 100644
--- a/arrow/array/cast/fn.as_struct_array.html
+++ b/arrow/array/cast/fn.as_struct_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="Force downcast of an `Array`, such as an `ArrayRef` to  `StructArray`, panicking on failure."><title>as_struct_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `StructArray`, panicking on failure."><title>as_struct_array in arrow::array::cast - 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>< [...]
 <a href="../struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.as_union_array.html b/arrow/array/cast/fn.as_union_array.html
index 91d2b6d8a8..f2d59d9329 100644
--- a/arrow/array/cast/fn.as_union_array.html
+++ b/arrow/array/cast/fn.as_union_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="Force downcast of an `Array`, such as an `ArrayRef` to  `UnionArray`, panicking on failure."><title>as_union_array in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"> [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `UnionArray`, panicking on failure."><title>as_union_array in arrow::array::cast - 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>< [...]
 <a href="../struct.UnionArray.html" title="struct arrow::array::UnionArray"><code>UnionArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/fn.downcast_array.html b/arrow/array/cast/fn.downcast_array.html
index f9ed9cc6df..4c919a8026 100644
--- a/arrow/array/cast/fn.downcast_array.html
+++ b/arrow/array/cast/fn.downcast_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="Downcasts a `dyn Array` to a concrete type"><title>downcast_array in arrow::array::cast - 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 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Downcasts a `dyn Array` to a concrete type"><title>downcast_array in arrow::array::cast - 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="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;<a class="struct" href="../struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Downcasts a <code>dyn Array</code> to a concrete type</p>
 
@@ -17,6 +17,6 @@
         }
     }
 }</code></pre></div>
-<h2 id="panics"><a href="#panics">Panics</a></h2>
+<h2 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h2>
 <p>Panics if array is not of the correct data type</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/cast/index.html b/arrow/array/cast/index.html
index 31e8a65bbb..9063efd542 100644
--- a/arrow/array/cast/index.html
+++ b/arrow/array/cast/index.html
@@ -1,6 +1,6 @@
-<!DOCTYPE html><html lang="en"><head><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 helper functions for downcasting `dyn Array` to concrete types"><title>arrow::array::cast - 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 helper functions for downcasting `dyn Array` to concrete types"><title>arrow::array::cast - 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="traits" class="section-header"><a href="#traits">Traits</a></h2><ul class="item-table"><li><div class="item-name"><a class="trait" href="trait.AsArray.html" title="trait arrow::array::cast::AsArray">AsArray</a></div><div class="desc docblock-short">An extension trait for <code>dyn Array</code> that provides ergonomic downcasting</div></li></ul><h2 id="functions" class="section-header"><a href="#functions">Functions</a></h2><ul class="item-table"><li><div class="it [...]
+</div></details><h2 id="traits" class="section-header">Traits<a href="#traits" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="trait" href="trait.AsArray.html" title="trait arrow::array::cast::AsArray">AsArray</a></div><div class="desc docblock-short">An extension trait for <code>dyn Array</code> that provides ergonomic downcasting</div></li></ul><h2 id="functions" class="section-header">Functions<a href="#functions" class="anchor">§</a></h2><ul class [...]
 <a href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray"><code>BooleanArray</code></a>, panicking on failure.</div></li><li><div class="item-name"><a class="fn" href="fn.as_decimal_array.html" title="fn arrow::array::cast::as_decimal_array">as_decimal_array</a><span class="stab deprecated" title="">Deprecated</span></div><div class="desc docblock-short">Force downcast of an Array, such as an ArrayRef to Decimal128Array, panic’ing on failure.</div></li><li><div clas [...]
 <a href="../struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray&lt;T&gt;</code></a>, panic’ing on failure.</div></li><li><div class="item-name"><a class="fn" href="fn.as_fixed_size_list_array.html" title="fn arrow::array::cast::as_fixed_size_list_array">as_fixed_size_list_array</a></div><div class="desc docblock-short">Force downcast of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href [...]
 <a href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a>, panicking on failure.</div></li><li><div class="item-name"><a class="fn" href="fn.as_generic_binary_array.html" title="fn arrow::array::cast::as_generic_binary_array">as_generic_binary_array</a></div><div class="desc docblock-short">Force downcast of an <a href="../trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href=". [...]
diff --git a/arrow/array/cast/trait.AsArray.html b/arrow/array/cast/trait.AsArray.html
index 2f9ceb8991..6d660d0d50 100644
--- a/arrow/array/cast/trait.AsArray.html
+++ b/arrow/array/cast/trait.AsArray.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="An extension trait for `dyn Array` that provides ergonomic downcasting"><title>AsArray in arrow::array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font [...]
+<!DOCTYPE html><html lang="en"><head><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 extension trait for `dyn Array` that provides ergonomic downcasting"><title>AsArray in arrow::array::cast - 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>< [...]
 <details class="toggle type-contents-toggle"><summary class="hideme"><span>Show 24 methods</span></summary>    // Required methods
     fn <a href="#tymethod.as_boolean_opt" class="fn">as_boolean_opt</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="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>&gt;;
diff --git a/arrow/array/enum.BufferSpec.html b/arrow/array/enum.BufferSpec.html
index 55ec47d391..125c5d2074 100644
--- a/arrow/array/enum.BufferSpec.html
+++ b/arrow/array/enum.BufferSpec.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="Layout specification for a single data type buffer"><title>BufferSpec in arrow::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" crosso [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Layout specification for a single data type buffer"><title>BufferSpec in arrow::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" 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 [...]
     FixedWidth {
         byte_width: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -31,14 +31,14 @@ sufficient, and should not be overridden without very good reason.</div></detail
     Q: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.Eq.html" title="trait core::cmp::Eq">Eq</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/borrow/trait.Borrow.html" title="trait core::borrow::Borrow">Borrow</a>&lt;Q&gt; + ?<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.equivalent" class="method trait-impl"><a href="#method.equivalent" class="anchor" [...]
     Q: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.Eq.html" title="trait core::cmp::Eq">Eq</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,
-    K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/borrow/trait.Borrow.html" title="trait core::borrow::Borrow">Borrow</a>&lt;Q&gt; + ?<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.equivalent-1" class="method trait-impl"><a href="#method.equivalent-1" class="anc [...]
+    K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/borrow/trait.Borrow.html" title="trait core::borrow::Borrow">Borrow</a>&lt;Q&gt; + ?<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.equivalent-1" class="method trait-impl"><a href="#method.equivalent-1" class="anc [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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& [...]
     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/enum.Capacities.html b/arrow/array/enum.Capacities.html
index bb6e32b7fa..d714907bcb 100644
--- a/arrow/array/enum.Capacities.html
+++ b/arrow/array/enum.Capacities.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="Define capacities of child data or data buffers."><title>Capacities in arrow::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" crossori [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Define capacities of child data or data buffers."><title>Capacities in arrow::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" crossori [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     Binary(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</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="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;),
     List(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</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" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;<a class="enum" href="enum.Capacities.html" title="enum arrow::array::Capacities">Capacities</a>&gt;&gt;),
@@ -32,15 +32,15 @@ Define</p>
 </div></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-Capacities" class="impl"><a class="src rightside" href="../../src/arrow_data/transform/mod.rs.html#310">source</a><a href="#impl-Clone-for-Capacities" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="h [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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& [...]
     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/ffi/fn.export_array_into_raw.html b/arrow/array/ffi/fn.export_array_into_raw.html
index 0f801f9238..779557cf57 100644
--- a/arrow/array/ffi/fn.export_array_into_raw.html
+++ b/arrow/array/ffi/fn.export_array_into_raw.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="Exports an array to raw pointers of the C Data Interface provided by the consumer."><title>export_array_into_raw in arrow::array::ffi - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><li [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Exports an array to raw pointers of the C Data Interface provided by the consumer."><title>export_array_into_raw in arrow::array::ffi - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><li [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click or press ‘S’ to search, ‘?’ for more options…" type="search"><div id="help-button" tabindex="-1"><a href="../../../help.html" title="help">?</a></div>< [...]
     src: <a class="type" href="../type.ArrayRef.html" title="type arrow::array::ArrayRef">ArrayRef</a>,
     out_array: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../../ffi/struct.FFI_ArrowArray.html" title="struct arrow::ffi::FFI_ArrowArray">FFI_ArrowArray</a>,
     out_schema: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../../ffi/struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a>
 ) -&gt; <a class="type" href="../../error/type.Result.html" title="type arrow::error::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</code></pre><span class="item-info"><div class="stab deprecated"><span class="emoji">👎</span><span>Deprecated: Use FFI_ArrowArray::new and FFI_ArrowSchema::try_from</span></div></span><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary>< [...]
-<h2 id="safety"><a href="#safety">Safety</a></h2>
+<h2 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h2>
 <p>Assumes that these pointers represent valid C Data Interfaces, both in memory
 representation and lifetime via the <code>release</code> mechanism.</p>
 <p>This function copies the content of two FFI structs <a href="../../ffi/struct.FFI_ArrowArray.html" title="struct arrow::ffi::FFI_ArrowArray">ffi::FFI_ArrowArray</a> and
diff --git a/arrow/array/ffi/index.html b/arrow/array/ffi/index.html
index f66c1f32c0..51013bc63e 100644
--- a/arrow/array/ffi/index.html
+++ b/arrow/array/ffi/index.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="Contains functionality to load an ArrayData from the C Data Interface"><title>arrow::array::ffi - 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/ [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Contains functionality to load an ArrayData from the C Data Interface"><title>arrow::array::ffi - 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="functions" class="section-header"><a href="#functions">Functions</a></h2><ul class="item-table"><li><div class="item-name"><a class="fn" href="fn.export_array_into_raw.html" title="fn arrow::array::ffi::export_array_into_raw">export_array_into_raw</a><sup title="unsafe function">⚠</sup><span class="stab deprecated" title="">Deprecated</span></div><div class="desc docblock-short">Exports an array to raw pointers of the C Data Interface provided by the consumer.</di [...]
\ No newline at end of file
+</div></details><h2 id="functions" class="section-header">Functions<a href="#functions" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="fn" href="fn.export_array_into_raw.html" title="fn arrow::array::ffi::export_array_into_raw">export_array_into_raw</a><sup title="unsafe function">⚠</sup><span class="stab deprecated" title="">Deprecated</span></div><div class="desc docblock-short">Exports an array to raw pointers of the C Data Interface provided by t [...]
\ No newline at end of file
diff --git a/arrow/array/fn.as_boolean_array.html b/arrow/array/fn.as_boolean_array.html
index f382415894..aa4601503d 100644
--- a/arrow/array/fn.as_boolean_array.html
+++ b/arrow/array/fn.as_boolean_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `BooleanArray`, panicking on failure."><title>as_boolean_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link  [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `BooleanArray`, panicking on failure."><title>as_boolean_array in arrow::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><div id [...]
 <a href="struct.BooleanArray.html" title="struct arrow::array::BooleanArray"><code>BooleanArray</code></a>, panicking on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: ArrayRef = Arc::new(BooleanArray::from_iter(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="bool-val">true</span>)]));
 <span class="kw">let </span>boolean_array = as_boolean_array(<span class="kw-2">&amp;</span>arr);</code></pre></div>
diff --git a/arrow/array/fn.as_decimal_array.html b/arrow/array/fn.as_decimal_array.html
index 56ea0e1d4d..2e4ebc1341 100644
--- a/arrow/array/fn.as_decimal_array.html
+++ b/arrow/array/fn.as_decimal_array.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="Force downcast of an Array, such as an ArrayRef to Decimal128Array, panic’ing on failure."><title>as_decimal_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an Array, such as an ArrayRef to Decimal128Array, panic’ing on failure."><title>as_decimal_array in arrow::array - 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 id [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_dictionary_array.html b/arrow/array/fn.as_dictionary_array.html
index 0460b522fb..205535c50d 100644
--- a/arrow/array/fn.as_dictionary_array.html
+++ b/arrow/array/fn.as_dictionary_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `DictionaryArray&lt;T&gt;`, panic’ing on failure."><title>as_dictionary_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.tt [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `DictionaryArray&lt;T&gt;`, panic’ing on failure."><title>as_dictionary_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.tt [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef.html" title="type arrow::array::ArrayRef"><cod [...]
 <a href="struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: DictionaryArray&lt;Int32Type&gt; = <span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"foo"</span>)].into_iter().collect();
 <span class="kw">let </span>arr: ArrayRef = std::sync::Arc::new(arr);
diff --git a/arrow/array/fn.as_fixed_size_list_array.html b/arrow/array/fn.as_fixed_size_list_array.html
index 02c23ba265..283add2fc3 100644
--- a/arrow/array/fn.as_fixed_size_list_array.html
+++ b/arrow/array/fn.as_fixed_size_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `FixedSizeListArray`, panicking on failure."><title>as_fixed_size_list_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `FixedSizeListArray`, panicking on failure."><title>as_fixed_size_list_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <a href="struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_generic_binary_array.html b/arrow/array/fn.as_generic_binary_array.html
index 8b261b17a3..e97f781f5f 100644
--- a/arrow/array/fn.as_generic_binary_array.html
+++ b/arrow/array/fn.as_generic_binary_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="Force downcast of an `Array`, such as an `ArrayRef` to `GenericBinaryArray&lt;S&gt;`, panicking on failure."><title>as_generic_binary_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `GenericBinaryArray&lt;S&gt;`, panicking on failure."><title>as_generic_binary_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     arr: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<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;S&gt;&gt;<div class="where">where
diff --git a/arrow/array/fn.as_generic_list_array.html b/arrow/array/fn.as_generic_list_array.html
index dc0440fd48..26c4936f9f 100644
--- a/arrow/array/fn.as_generic_list_array.html
+++ b/arrow/array/fn.as_generic_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `GenericListArray&lt;T&gt;`, panicking on failure."><title>as_generic_list_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `GenericListArray&lt;T&gt;`, panicking on failure."><title>as_generic_list_array in arrow::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><div id [...]
     S: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef</code></a> to
 <a href="struct.GenericListArray.html" title="struct arrow::array::GenericListArray"><code>GenericListArray&lt;T&gt;</code></a>, panicking on failure.</p>
diff --git a/arrow/array/fn.as_large_list_array.html b/arrow/array/fn.as_large_list_array.html
index aef0c4efb0..f6d879958f 100644
--- a/arrow/array/fn.as_large_list_array.html
+++ b/arrow/array/fn.as_large_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `LargeListArray`, panicking on failure."><title>as_large_list_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2">< [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `LargeListArray`, panicking on failure."><title>as_large_list_array in arrow::array - 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 id [...]
 <a href="type.LargeListArray.html" title="type arrow::array::LargeListArray"><code>LargeListArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_largestring_array.html b/arrow/array/fn.as_largestring_array.html
index 0a77a75141..ff148f7a4e 100644
--- a/arrow/array/fn.as_largestring_array.html
+++ b/arrow/array/fn.as_largestring_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="Force downcast of an `Array`, such as an `ArrayRef` to  `LargeStringArray`, panicking on failure."><title>as_largestring_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `LargeStringArray`, panicking on failure."><title>as_largestring_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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 id [...]
     arr: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<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;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>&gt;&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summ [...]
diff --git a/arrow/array/fn.as_list_array.html b/arrow/array/fn.as_list_array.html
index c39a92fbf9..a9d983ed2f 100644
--- a/arrow/array/fn.as_list_array.html
+++ b/arrow/array/fn.as_list_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="Force downcast of an `Array`, such as an `ArrayRef` to `ListArray`, panicking on failure."><title>as_list_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `ListArray`, panicking on failure."><title>as_list_array in arrow::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><div id [...]
 <a href="type.ListArray.html" title="type arrow::array::ListArray"><code>ListArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_map_array.html b/arrow/array/fn.as_map_array.html
index 98aeef78cc..2cc984687e 100644
--- a/arrow/array/fn.as_map_array.html
+++ b/arrow/array/fn.as_map_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="Force downcast of an `Array`, such as an `ArrayRef` to  `MapArray`, panicking on failure."><title>as_map_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pr [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `MapArray`, panicking on failure."><title>as_map_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pr [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <a href="struct.MapArray.html" title="struct arrow::array::MapArray"><code>MapArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_null_array.html b/arrow/array/fn.as_null_array.html
index 690b5d0387..0391664237 100644
--- a/arrow/array/fn.as_null_array.html
+++ b/arrow/array/fn.as_null_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="Force downcast of an `Array`, such as an `ArrayRef` to  `NullArray`, panicking on failure."><title>as_null_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel=" [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `NullArray`, panicking on failure."><title>as_null_array in arrow::array - 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 id [...]
 <a href="struct.NullArray.html" title="struct arrow::array::NullArray"><code>NullArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_primitive_array.html b/arrow/array/fn.as_primitive_array.html
index 9cc6d0e0f7..c2c56a6a56 100644
--- a/arrow/array/fn.as_primitive_array.html
+++ b/arrow/array/fn.as_primitive_array.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="Force downcast of an `Array`, such as an `ArrayRef`, to `PrimitiveArray&lt;T&gt;`, panic’ing on failure."><title>as_primitive_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef`, to `PrimitiveArray&lt;T&gt;`, panic’ing on failure."><title>as_primitive_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef</ [...]
 <a href="struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: ArrayRef = Arc::new(Int32Array::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="number">1</span>)]));
 
diff --git a/arrow/array/fn.as_run_array.html b/arrow/array/fn.as_run_array.html
index 5eb23a3d66..07820af264 100644
--- a/arrow/array/fn.as_run_array.html
+++ b/arrow/array/fn.as_run_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `RunArray&lt;T&gt;`, panic’ing on failure."><title>as_run_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `RunArray&lt;T&gt;`, panic’ing on failure."><title>as_run_array in arrow::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><div id [...]
     T: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef</code></a> to
 <a href="struct.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: RunArray&lt;Int32Type&gt; = <span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"foo"</span>)].into_iter().collect();
 <span class="kw">let </span>arr: ArrayRef = std::sync::Arc::new(arr);
diff --git a/arrow/array/fn.as_string_array.html b/arrow/array/fn.as_string_array.html
index a6bb18e6d1..24d5fd7508 100644
--- a/arrow/array/fn.as_string_array.html
+++ b/arrow/array/fn.as_string_array.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="Force downcast of an `Array`, such as an `ArrayRef` to `StringArray`, panicking on failure."><title>as_string_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link re [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to `StringArray`, panicking on failure."><title>as_string_array in arrow::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><div id [...]
     arr: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<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;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summ [...]
 <a href="type.StringArray.html" title="type arrow::array::StringArray"><code>StringArray</code></a>, panicking on failure.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>arr: ArrayRef = Arc::new(StringArray::from_iter(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="string">"foo"</span>)]));
 <span class="kw">let </span>string_array = as_string_array(<span class="kw-2">&amp;</span>arr);</code></pre></div>
diff --git a/arrow/array/fn.as_struct_array.html b/arrow/array/fn.as_struct_array.html
index 3236d1429c..de2c2fd2dc 100644
--- a/arrow/array/fn.as_struct_array.html
+++ b/arrow/array/fn.as_struct_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="Force downcast of an `Array`, such as an `ArrayRef` to  `StructArray`, panicking on failure."><title>as_struct_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link r [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `StructArray`, panicking on failure."><title>as_struct_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link r [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <a href="struct.StructArray.html" title="struct arrow::array::StructArray"><code>StructArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_union_array.html b/arrow/array/fn.as_union_array.html
index e141a9c641..d234d9a633 100644
--- a/arrow/array/fn.as_union_array.html
+++ b/arrow/array/fn.as_union_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="Force downcast of an `Array`, such as an `ArrayRef` to  `UnionArray`, panicking on failure."><title>as_union_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Force downcast of an `Array`, such as an `ArrayRef` to  `UnionArray`, panicking on failure."><title>as_union_array in arrow::array - 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 id [...]
 <a href="struct.UnionArray.html" title="struct arrow::array::UnionArray"><code>UnionArray</code></a>, panicking on failure.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.build_compare.html b/arrow/array/fn.build_compare.html
index 1d09c126bd..7838e3f000 100644
--- a/arrow/array/fn.build_compare.html
+++ b/arrow/array/fn.build_compare.html
@@ -1,11 +1,11 @@
-<!DOCTYPE html><html lang="en"><head><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 comparison function that compares two values at two different positions between the two arrays. The arrays’ types must be equal."><title>build_compare in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4 [...]
+<!DOCTYPE html><html lang="en"><head><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 comparison function that compares two values at two different positions between the two arrays. The arrays’ types must be equal."><title>build_compare in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     left: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>,
     right: &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="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize [...]
 between the two arrays.
 The arrays’ types must be equal.</p>
-<h2 id="example"><a href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::Int32Array;
 <span class="kw">use </span>arrow_ord::ord::build_compare;
 
diff --git a/arrow/array/fn.downcast_array.html b/arrow/array/fn.downcast_array.html
index c68bd7f6ea..66fb70b789 100644
--- a/arrow/array/fn.downcast_array.html
+++ b/arrow/array/fn.downcast_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="Downcasts a `dyn Array` to a concrete type"><title>downcast_array in arrow::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" crossorigi [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Downcasts a `dyn Array` to a concrete type"><title>downcast_array in arrow::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" 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 id [...]
     T: <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="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;,</div></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Downcasts a <code>dyn Array</code> to a concrete type</p>
 
@@ -17,6 +17,6 @@
         }
     }
 }</code></pre></div>
-<h2 id="panics"><a href="#panics">Panics</a></h2>
+<h2 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h2>
 <p>Panics if array is not of the correct data type</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.export_array_into_raw.html b/arrow/array/fn.export_array_into_raw.html
index cc4561e019..26ba9b8585 100644
--- a/arrow/array/fn.export_array_into_raw.html
+++ b/arrow/array/fn.export_array_into_raw.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="Exports an array to raw pointers of the C Data Interface provided by the consumer."><title>export_array_into_raw in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel=" [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Exports an array to raw pointers of the C Data Interface provided by the consumer."><title>export_array_into_raw in arrow::array - 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 id [...]
     src: <a class="type" href="type.ArrayRef.html" title="type arrow::array::ArrayRef">ArrayRef</a>,
     out_array: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../ffi/struct.FFI_ArrowArray.html" title="struct arrow::ffi::FFI_ArrowArray">FFI_ArrowArray</a>,
     out_schema: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../ffi/struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a>
 ) -&gt; <a class="type" href="../error/type.Result.html" title="type arrow::error::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</code></pre><span class="item-info"><div class="stab deprecated"><span class="emoji">👎</span><span>Deprecated: Use FFI_ArrowArray::new and FFI_ArrowSchema::try_from</span></div></span><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div [...]
-<h2 id="safety"><a href="#safety">Safety</a></h2>
+<h2 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h2>
 <p>Assumes that these pointers represent valid C Data Interfaces, both in memory
 representation and lifetime via the <code>release</code> mechanism.</p>
 <p>This function copies the content of two FFI structs <a href="../ffi/struct.FFI_ArrowArray.html" title="struct arrow::ffi::FFI_ArrowArray">ffi::FFI_ArrowArray</a> and
diff --git a/arrow/array/fn.layout.html b/arrow/array/fn.layout.html
index 046650b128..1f9e3e066c 100644
--- a/arrow/array/fn.layout.html
+++ b/arrow/array/fn.layout.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="Return the expected `DataTypeLayout` Arrays of this data type are expected to have"><title>layout in arrow::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 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Return the expected `DataTypeLayout` Arrays of this data type are expected to have"><title>layout in arrow::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><div id [...]
 type are expected to have</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.make_array.html b/arrow/array/fn.make_array.html
index 195baf5aec..e53d8d39fe 100644
--- a/arrow/array/fn.make_array.html
+++ b/arrow/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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prel [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prel [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 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/fn.make_builder.html b/arrow/array/fn.make_builder.html
index 9f32b38dfa..31384c1f7c 100644
--- a/arrow/array/fn.make_builder.html
+++ b/arrow/array/fn.make_builder.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="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 - Rust</title><link rel="preload" as="font" type="font/woff2" cros [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><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 id [...]
     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>
diff --git a/arrow/array/fn.new_empty_array.html b/arrow/array/fn.new_empty_array.html
index 8d64110fd0..02e7ff1c6f 100644
--- a/arrow/array/fn.new_empty_array.html
+++ b/arrow/array/fn.new_empty_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="Creates a new empty array"><title>new_empty_array in arrow::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="../../st [...]
+<!DOCTYPE html><html lang="en"><head><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 - 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="../../st [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>std::sync::Arc;
diff --git a/arrow/array/fn.new_null_array.html b/arrow/array/fn.new_null_array.html
index b1a824aee8..f411d3e191 100644
--- a/arrow/array/fn.new_null_array.html
+++ b/arrow/array/fn.new_null_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="Creates a new array of `data_type` of length `length` filled entirely of `NULL` values"><title>new_null_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pre [...]
+<!DOCTYPE html><html lang="en"><head><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 - 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><div id [...]
 entirely of <code>NULL</code> values</p>
 
diff --git a/arrow/array/index.html b/arrow/array/index.html
index 98c383a005..d5f3170f07 100644
--- a/arrow/array/index.html
+++ b/arrow/array/index.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="Statically typed implementations of Arrow Arrays"><title>arrow::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="../. [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Statically typed implementations of Arrow Arrays"><title>arrow::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 id [...]
 <p><strong>See <a href="../../arrow_array/index.html" title="mod arrow_array">arrow_array</a> for examples and usage instructions</strong></p>
-</div></details><h2 id="modules" class="section-header"><a href="#modules">Modules</a></h2><ul class="item-table"><li><div class="item-name"><a class="mod" href="array/index.html" title="mod arrow::array::array">array</a></div><div class="desc docblock-short">The concrete array definitions</div></li><li><div class="item-name"><a class="mod" href="builder/index.html" title="mod arrow::array::builder">builder</a></div><div class="desc docblock-short">Defines push-based APIs for constructin [...]
+</div></details><h2 id="modules" class="section-header">Modules<a href="#modules" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="mod" href="array/index.html" title="mod arrow::array::array">array</a></div><div class="desc docblock-short">The concrete array definitions</div></li><li><div class="item-name"><a class="mod" href="builder/index.html" title="mod arrow::array::builder">builder</a></div><div class="desc docblock-short">Defines push-based APIs [...]
 a number of subsequent patterns to match the data type</div></li><li><div class="item-name"><a class="macro" href="macro.downcast_integer.html" title="macro arrow::array::downcast_integer">downcast_integer</a></div><div class="desc docblock-short">Given one or more expressions evaluating to an integer <a href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a> invokes the provided macro
 <code>m</code> with the corresponding integer <a href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a>, followed by any additional arguments</div></li><li><div class="item-name"><a class="macro" href="macro.downcast_primitive.html" title="macro arrow::array::downcast_primitive">downcast_primitive</a></div><div class="desc docblock-short">Given one or more expressions evaluating to primitive <a href="../dat [...]
 <code>m</code> with the corresponding <a href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a>, followed by any additional arguments</div></li><li><div class="item-name"><a class="macro" href="macro.downcast_primitive_array.html" title="macro arrow::array::downcast_primitive_array">downcast_primitive_array</a></div><div class="desc docblock-short">Downcast an <a href="trait.Array.html" title="trait arrow:: [...]
@@ -9,7 +9,7 @@ accepts a number of subsequent patterns to match the data type</div></li><li><di
 a number of subsequent patterns to match the data type</div></li><li><div class="item-name"><a class="macro" href="macro.downcast_run_end_index.html" title="macro arrow::array::downcast_run_end_index">downcast_run_end_index</a></div><div class="desc docblock-short">Given one or more expressions evaluating to an integer <a href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a> invokes the provided macro
 <code>m</code> with the corresponding integer <a href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType"><code>RunEndIndexType</code></a>, followed by any additional arguments</div></li><li><div class="item-name"><a class="macro" href="macro.downcast_temporal.html" title="macro arrow::array::downcast_temporal">downcast_temporal</a></div><div class="desc docblock-short">Given one or more expressions evaluating to primitive <a href="../datatypes/enum. [...]
 <code>m</code> with the corresponding <a href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a>, followed by any additional arguments</div></li><li><div class="item-name"><a class="macro" href="macro.downcast_temporal_array.html" title="macro arrow::array::downcast_temporal_array">downcast_temporal_array</a></div><div class="desc docblock-short">Downcast an <a href="trait.Array.html" title="trait arrow::arr [...]
-accepts a number of subsequent patterns to match the data type</div></li></ul><h2 id="structs" class="section-header"><a href="#structs">Structs</a></h2><ul class="item-table"><li><div class="item-name"><a class="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></div><div class="desc docblock-short">A generic representation of Arrow array data which encapsulates common attributes and
+accepts a number of subsequent patterns to match the data type</div></li></ul><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.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a></div><div class="desc docblock-short">A generic representation of Arrow array data which encapsulates common attributes and
 operations for Arrow array. Specific operations for different arrays types (e.g.,
 primitive, list, struct) are implemented in <code>Array</code>.</div></li><li><div class="item-name"><a class="struct" href="struct.ArrayDataBuilder.html" title="struct arrow::array::ArrayDataBuilder">ArrayDataBuilder</a></div><div class="desc docblock-short">Builder for <code>ArrayData</code> type</div></li><li><div class="item-name"><a class="struct" href="struct.ArrayIter.html" title="struct arrow::array::ArrayIter">ArrayIter</a></div><div class="desc docblock-short">An iterator that  [...]
 (e.g. <code>[&quot;A&quot;, &quot;B&quot;]</code>).</div></li><li><div class="item-name"><a class="struct" href="struct.FixedSizeListBuilder.html" title="struct arrow::array::FixedSizeListBuilder">FixedSizeListBuilder</a></div><div class="desc docblock-short">Builder for <a href="struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a></div></li><li><div class="item-name"><a class="struct" href="struct.GenericByteArray.html" titl [...]
@@ -17,9 +17,9 @@ primitive, list, struct) are implemented in <code>Array</code>.</div></li><li><d
 copying chunks.</div></li><li><div class="item-name"><a class="struct" href="struct.NativeAdapter.html" title="struct arrow::array::NativeAdapter">NativeAdapter</a></div><div class="desc docblock-short">An optional primitive value</div></li><li><div class="item-name"><a class="struct" href="struct.NullArray.html" title="struct arrow::array::NullArray">NullArray</a></div><div class="desc docblock-short">An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#null-layout">n [...]
 <a href="../datatypes/struct.Schema.html" title="struct arrow::datatypes::Schema">schema</a>.</div></li><li><div class="item-name"><a class="struct" href="struct.RecordBatchIterator.html" title="struct arrow::array::RecordBatchIterator">RecordBatchIterator</a></div><div class="desc docblock-short">Generic implementation of <a href="../record_batch/trait.RecordBatchReader.html" title="trait arrow::record_batch::RecordBatchReader">RecordBatchReader</a> that wraps an iterator.</div></li><li [...]
 <a href="trait.Datum.html" title="trait arrow::array::Datum"><code>Datum</code></a> and indicates <a href="https://docs.rs/arrow/latest/arrow/compute/index.html">compute</a> kernels should treat this array
-as a scalar value (a single value).</div></li><li><div class="item-name"><a class="struct" href="struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></div><div class="desc docblock-short">An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#struct-layout">structs</a></div></li><li><div class="item-name"><a class="struct" href="struct.StructBuilder.html" title="struct arrow::array::StructBuilder">StructBuilder</a></div><div class="desc docbl [...]
+as a scalar value (a single value).</div></li><li><div class="item-name"><a class="struct" href="struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></div><div class="desc docblock-short">An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#struct-layout">structs</a></div></li><li><div class="item-name"><a class="struct" href="struct.StructBuilder.html" title="struct arrow::array::StructBuilder">StructBuilder</a></div><div class="desc docbl [...]
 and totally ordered comparison operations</div></li><li><div class="item-name"><a class="trait" href="trait.ArrowNumericType.html" title="trait arrow::array::ArrowNumericType">ArrowNumericType</a></div><div class="desc docblock-short">A subtype of primitive type that represents numeric values.</div></li><li><div class="item-name"><a class="trait" href="trait.ArrowPrimitiveType.html" title="trait arrow::array::ArrowPrimitiveType">ArrowPrimitiveType</a></div><div class="desc docblock-short [...]
-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>.</div></li><li><div class="item-name"><a class="trait" href="trait.AsArray.html" title="trait arrow::array::AsArray">AsArray</a></div><div class="desc docblock-short [...]
+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>.</div></li><li><div class="item-name"><a class="trait" href="trait.AsArray.html" title="trait arrow::array::AsArray">AsArray</a></div><div class="desc docblock-short [...]
 <a href="struct.BooleanArray.html" title="struct arrow::array::BooleanArray"><code>BooleanArray</code></a>, panicking on failure.</div></li><li><div class="item-name"><a class="fn" href="fn.as_decimal_array.html" title="fn arrow::array::as_decimal_array">as_decimal_array</a><span class="stab deprecated" title="">Deprecated</span></div><div class="desc docblock-short">Force downcast of an Array, such as an ArrayRef to Decimal128Array, panic’ing on failure.</div></li><li><div class="item-n [...]
 <a href="struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray&lt;T&gt;</code></a>, panic’ing on failure.</div></li><li><div class="item-name"><a class="fn" href="fn.as_fixed_size_list_array.html" title="fn arrow::array::as_fixed_size_list_array">as_fixed_size_list_array</a></div><div class="desc docblock-short">Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.Array [...]
 <a href="struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray"><code>FixedSizeListArray</code></a>, panicking on failure.</div></li><li><div class="item-name"><a class="fn" href="fn.as_generic_binary_array.html" title="fn arrow::array::as_generic_binary_array">as_generic_binary_array</a></div><div class="desc docblock-short">Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef [...]
@@ -41,4 +41,4 @@ type are expected to have</div></li><li><div class="item-name"><a class="fn" hre
 Returns a reference-counted <code>Array</code> instance.</div></li><li><div class="item-name"><a class="fn" href="fn.make_builder.html" title="fn arrow::array::make_builder">make_builder</a></div><div class="desc docblock-short">Returns a builder with capacity <code>capacity</code> that corresponds to the datatype <code>DataType</code>
 This function is useful to construct arrays from an arbitrary vectors with known/expected
 schema.</div></li><li><div class="item-name"><a class="fn" href="fn.new_empty_array.html" title="fn arrow::array::new_empty_array">new_empty_array</a></div><div class="desc docblock-short">Creates a new empty array</div></li><li><div class="item-name"><a class="fn" href="fn.new_null_array.html" title="fn arrow::array::new_null_array">new_null_array</a></div><div class="desc docblock-short">Creates a new array of <code>data_type</code> of length <code>length</code> filled
-entirely of <code>NULL</code> values</div></li></ul><h2 id="types" class="section-header"><a href="#types">Type Aliases</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.ArrayDataRef.html" title="type arrow::array::ArrayDataRef">ArrayDataRef</a></div></li><li><div class="item-name"><a class="type" href="type.ArrayRef.html" title="type arrow::array::ArrayRef">ArrayRef</a></div><div class="desc docblock-short">A reference-counted reference to a generic <c [...]
\ No newline at end of file
+entirely of <code>NULL</code> values</div></li></ul><h2 id="types" class="section-header">Type Aliases<a href="#types" class="anchor">§</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.ArrayDataRef.html" title="type arrow::array::ArrayDataRef">ArrayDataRef</a></div></li><li><div class="item-name"><a class="type" href="type.ArrayRef.html" title="type arrow::array::ArrayRef">ArrayRef</a></div><div class="desc docblock-short">A reference-counted reference [...]
\ No newline at end of file
diff --git a/arrow/array/iterator/index.html b/arrow/array/iterator/index.html
index e4bc4ab12b..945a229df5 100644
--- a/arrow/array/iterator/index.html
+++ b/arrow/array/iterator/index.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="Idiomatic iterators for `Array`"><title>arrow::array::iterator - 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="../../.. [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Idiomatic iterators for `Array`"><title>arrow::array::iterator - 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="structs" class="section-header"><a href="#structs">Structs</a></h2><ul class="item-table"><li><div class="item-name"><a class="struct" href="struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a></div><div class="desc docblock-short">An iterator that returns Some(T) or None, that can be used on any <a href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor"><code>ArrayAccessor</code></a></div></li></ul><h2 id="typ [...]
\ No newline at end of file
+</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.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter">ArrayIter</a></div><div class="desc docblock-short">An iterator that returns Some(T) or None, that can be used on any <a href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor"><code>ArrayAccessor</code></a></div></li> [...]
\ No newline at end of file
diff --git a/arrow/array/iterator/struct.ArrayIter.html b/arrow/array/iterator/struct.ArrayIter.html
index 26254b0ca2..72ad8bd3c5 100644
--- a/arrow/array/iterator/struct.ArrayIter.html
+++ b/arrow/array/iterator/struct.ArrayIter.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="An iterator that returns Some(T) or None, that can be used on any `ArrayAccessor`"><title>ArrayIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel=" [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any `ArrayAccessor`"><title>ArrayIter in arrow::array::iterator - 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>< [...]
     T: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,</div>{
     array: T,
@@ -6,7 +6,7 @@
     current: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     current_end: <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 iterator that returns Some(T) or None, that can be used on any <a href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor"><code>ArrayAccessor</code></a></p>
-<h2 id="performance"><a href="#performance">Performance</a></h2>
+<h2 id="performance"><a class="doc-anchor" href="#performance">§</a>Performance</h2>
 <p><a href="struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter"><code>ArrayIter</code></a> provides an idiomatic way to iterate over an array, however, this
 comes at the cost of performance. In particular the interleaved handling of
 the null mask is often sub-optimal.</p>
@@ -215,7 +215,7 @@ greater than those of another. <a href="https://doc.rust-lang.org/nightly/core/i
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Determines if the elements of this <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator"><code>Iterator</code></a> are <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#lexicographical-compari [...]
 greater than or equal to those of another. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#method.ge">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.is_sorted_by" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/iter/traits/iterator.rs.html#4060-4063">source</a><a href="#method.is_sorted_by" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</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>(&amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>, &amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associ [...]
+    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>(&amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>, &amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</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>(Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>) -&gt; K,
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">PartialOrd</a>,</div></h4></section></summary><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>is_sorted</code>)</span></div></span><div class='docblock'>Checks if the elements of this iterator are sorted using the given key extraction
@@ -225,9 +225,9 @@ function. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/t
     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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-IntoIterator-for-I" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/iter/traits/collect.rs.html#273">source</a><a href="#impl-IntoIterator-for-I" class="anchor">§</a><h3 class="code-header">impl&lt;I&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collec [...]
@@ -237,9 +237,9 @@ function. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/t
     R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Choose one element at random from the iterator. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_stable">Read more</a></div></details> [...]
     R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects values at random from the iterator into a supplied buffer
 until that buffer is filled. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multiple_fill">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.choose_multiple" class="method trait-impl"><a class="src rightside" href="https://rust-random.github.io/rand/src/rand/seq/mod.rs.html#466-467">source</a><a href="#method.choose_multiple" class="anchor">§</a><h4 class="code-header">fn <a href="https://rus [...]
-    R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects <code>amount</code> values at random from the iterator into a vector. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multip [...]
-    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. [...]
+    R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects <code>amount</code> values at random from the iterator into a vector. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multip [...]
+    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 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: <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<T>":"<h3>Notable traits for <code><a class=\"struct\" href=\"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://doc.rust-lang.org/ [...]
\ No newline at end of file
diff --git a/arrow/array/iterator/type.BooleanIter.html b/arrow/array/iterator/type.BooleanIter.html
index 0a657f24dd..1d63937360 100644
--- a/arrow/array/iterator/type.BooleanIter.html
+++ b/arrow/array/iterator/type.BooleanIter.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="an iterator that returns Some(T) or None, that can be used on any BooleanArray"><title>BooleanIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any BooleanArray"><title>BooleanIter in arrow::array::iterator - 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>< [...]
 </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 BooleanIter&lt;'a&gt; {
     array: &amp;'a <a class="struct" href="../struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>,
diff --git a/arrow/array/iterator/type.FixedSizeBinaryIter.html b/arrow/array/iterator/type.FixedSizeBinaryIter.html
index bb3a9ddb76..c3e967b96c 100644
--- a/arrow/array/iterator/type.FixedSizeBinaryIter.html
+++ b/arrow/array/iterator/type.FixedSizeBinaryIter.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="an iterator that returns Some(T) or None, that can be used on any FixedSizeBinaryArray"><title>FixedSizeBinaryIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.wof [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any FixedSizeBinaryArray"><title>FixedSizeBinaryIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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 FixedSizeBinaryIter&lt;'a&gt; {
     array: &amp;'a <a class="struct" href="../struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a>,
diff --git a/arrow/array/iterator/type.FixedSizeListIter.html b/arrow/array/iterator/type.FixedSizeListIter.html
index d80e4baf75..a440d8070e 100644
--- a/arrow/array/iterator/type.FixedSizeListIter.html
+++ b/arrow/array/iterator/type.FixedSizeListIter.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="an iterator that returns Some(T) or None, that can be used on any FixedSizeListArray"><title>FixedSizeListIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"> [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any FixedSizeListArray"><title>FixedSizeListIter in arrow::array::iterator - 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 FixedSizeListIter&lt;'a&gt; {
     array: &amp;'a <a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a>,
diff --git a/arrow/array/iterator/type.GenericBinaryIter.html b/arrow/array/iterator/type.GenericBinaryIter.html
index 1a32d6afeb..c1948d8bc8 100644
--- a/arrow/array/iterator/type.GenericBinaryIter.html
+++ b/arrow/array/iterator/type.GenericBinaryIter.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="an iterator that returns Some(T) or None, that can be used on any BinaryArray"><title>GenericBinaryIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link r [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any BinaryArray"><title>GenericBinaryIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link r [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 GenericBinaryIter&lt;'a, T&gt; {
     array: &amp;'a <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;T&gt;&gt;,
diff --git a/arrow/array/iterator/type.GenericListArrayIter.html b/arrow/array/iterator/type.GenericListArrayIter.html
index ca741fded4..00c1f26131 100644
--- a/arrow/array/iterator/type.GenericListArrayIter.html
+++ b/arrow/array/iterator/type.GenericListArrayIter.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="an iterator that returns Some(T) or None, that can be used on any ListArray"><title>GenericListArrayIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link  [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any ListArray"><title>GenericListArrayIter in arrow::array::iterator - 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 GenericListArrayIter&lt;'a, O&gt; {
     array: &amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;O&gt;,
diff --git a/arrow/array/iterator/type.GenericStringIter.html b/arrow/array/iterator/type.GenericStringIter.html
index 5fd56c863f..058d08dc0c 100644
--- a/arrow/array/iterator/type.GenericStringIter.html
+++ b/arrow/array/iterator/type.GenericStringIter.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="an iterator that returns Some(T) or None, that can be used on any Utf8Array"><title>GenericStringIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any Utf8Array"><title>GenericStringIter in arrow::array::iterator - 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 GenericStringIter&lt;'a, T&gt; {
     array: &amp;'a <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;T&gt;&gt;,
diff --git a/arrow/array/iterator/type.MapArrayIter.html b/arrow/array/iterator/type.MapArrayIter.html
index 7c91f6e35c..b4be7dfcea 100644
--- a/arrow/array/iterator/type.MapArrayIter.html
+++ b/arrow/array/iterator/type.MapArrayIter.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="an iterator that returns Some(T) or None, that can be used on any MapArray"><title>MapArrayIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prel [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any MapArray"><title>MapArrayIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prel [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 MapArrayIter&lt;'a&gt; {
     array: &amp;'a <a class="struct" href="../struct.MapArray.html" title="struct arrow::array::MapArray">MapArray</a>,
diff --git a/arrow/array/iterator/type.PrimitiveIter.html b/arrow/array/iterator/type.PrimitiveIter.html
index 33fa81281a..98667d470a 100644
--- a/arrow/array/iterator/type.PrimitiveIter.html
+++ b/arrow/array/iterator/type.PrimitiveIter.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="an iterator that returns Some(T) or None, that can be used on any PrimitiveArray"><title>PrimitiveIter in arrow::array::iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link re [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any PrimitiveArray"><title>PrimitiveIter in arrow::array::iterator - 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>< [...]
 </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 PrimitiveIter&lt;'a, T&gt; {
     array: &amp;'a <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;,
diff --git a/arrow/array/macro.downcast_dictionary_array.html b/arrow/array/macro.downcast_dictionary_array.html
index 03131aa7a3..e7ef2a1174 100644
--- a/arrow/array/macro.downcast_dictionary_array.html
+++ b/arrow/array/macro.downcast_dictionary_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="Downcast an `Array` to a `DictionaryArray` based on its `DataType`, accepts a number of subsequent patterns to match the data type"><title>downcast_dictionary_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSe [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Downcast an `Array` to a `DictionaryArray` based on its `DataType`, accepts a number of subsequent patterns to match the data type"><title>downcast_dictionary_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSe [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     (<span class="macro-nonterminal">$values</span>:ident =&gt; <span class="macro-nonterminal">$e</span>:expr, $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
     (<span class="macro-nonterminal">$values</span>:ident =&gt; <span class="macro-nonterminal">$e</span>:block $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
diff --git a/arrow/array/macro.downcast_integer.html b/arrow/array/macro.downcast_integer.html
index c522b33ae8..4f94fd9ab0 100644
--- a/arrow/array/macro.downcast_integer.html
+++ b/arrow/array/macro.downcast_integer.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="Given one or more expressions evaluating to an integer `DataType` invokes the provided macro `m` with the corresponding integer `ArrowPrimitiveType`, followed by any additional arguments"><title>downcast_integer in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Given one or more expressions evaluating to an integer `DataType` invokes the provided macro `m` with the corresponding integer `ArrowPrimitiveType`, followed by any additional arguments"><title>downcast_integer in arrow::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><div id [...]
     ($(<span class="macro-nonterminal">$data_type</span>:expr),+ =&gt; (<span class="macro-nonterminal">$m</span>:path $(, <span class="macro-nonterminal">$args</span>:tt)<span class="kw-2">*</span>), $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
 }</pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Given one or more expressions evaluating to an integer <a href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a> invokes the provided macro
diff --git a/arrow/array/macro.downcast_primitive.html b/arrow/array/macro.downcast_primitive.html
index 6f68698193..2dc570ece7 100644
--- a/arrow/array/macro.downcast_primitive.html
+++ b/arrow/array/macro.downcast_primitive.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="Given one or more expressions evaluating to primitive `DataType` invokes the provided macro `m` with the corresponding `ArrowPrimitiveType`, followed by any additional arguments"><title>downcast_primitive in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" cross [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Given one or more expressions evaluating to primitive `DataType` invokes the provided macro `m` with the corresponding `ArrowPrimitiveType`, followed by any additional arguments"><title>downcast_primitive in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" cross [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     ($(<span class="macro-nonterminal">$data_type</span>:expr),+ =&gt; (<span class="macro-nonterminal">$m</span>:path $(, <span class="macro-nonterminal">$args</span>:tt)<span class="kw-2">*</span>), $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
 }</pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Given one or more expressions evaluating to primitive <a href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a> invokes the provided macro
diff --git a/arrow/array/macro.downcast_primitive_array.html b/arrow/array/macro.downcast_primitive_array.html
index 8bbf99cbc4..c1a46a8b71 100644
--- a/arrow/array/macro.downcast_primitive_array.html
+++ b/arrow/array/macro.downcast_primitive_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="Downcast an `Array` to a `PrimitiveArray` based on its `DataType` accepts a number of subsequent patterns to match the data type"><title>downcast_primitive_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Downcast an `Array` to a `PrimitiveArray` based on its `DataType` accepts a number of subsequent patterns to match the data type"><title>downcast_primitive_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     (<span class="macro-nonterminal">$values</span>:ident =&gt; <span class="macro-nonterminal">$e</span>:expr, $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
     (($(<span class="macro-nonterminal">$values</span>:ident),+) =&gt; <span class="macro-nonterminal">$e</span>:expr, $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
diff --git a/arrow/array/macro.downcast_run_array.html b/arrow/array/macro.downcast_run_array.html
index 71685f37e6..ef559c70d4 100644
--- a/arrow/array/macro.downcast_run_array.html
+++ b/arrow/array/macro.downcast_run_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="Downcast an `Array` to a `RunArray` based on its `DataType`, accepts a number of subsequent patterns to match the data type"><title>downcast_run_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-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="Downcast an `Array` to a `RunArray` based on its `DataType`, accepts a number of subsequent patterns to match the data type"><title>downcast_run_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-4 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     (<span class="macro-nonterminal">$values</span>:ident =&gt; <span class="macro-nonterminal">$e</span>:expr, $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
     (<span class="macro-nonterminal">$values</span>:ident =&gt; <span class="macro-nonterminal">$e</span>:block $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
diff --git a/arrow/array/macro.downcast_run_end_index.html b/arrow/array/macro.downcast_run_end_index.html
index df165e5494..8671066ed3 100644
--- a/arrow/array/macro.downcast_run_end_index.html
+++ b/arrow/array/macro.downcast_run_end_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="Given one or more expressions evaluating to an integer `DataType` invokes the provided macro `m` with the corresponding integer `RunEndIndexType`, followed by any additional arguments"><title>downcast_run_end_index in arrow::array - Rust</title><link rel="preload" as="font" type="font/wo [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Given one or more expressions evaluating to an integer `DataType` invokes the provided macro `m` with the corresponding integer `RunEndIndexType`, followed by any additional arguments"><title>downcast_run_end_index in arrow::array - 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><div id [...]
     ($(<span class="macro-nonterminal">$data_type</span>:expr),+ =&gt; (<span class="macro-nonterminal">$m</span>:path $(, <span class="macro-nonterminal">$args</span>:tt)<span class="kw-2">*</span>), $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
 }</pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Given one or more expressions evaluating to an integer <a href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a> invokes the provided macro
diff --git a/arrow/array/macro.downcast_temporal.html b/arrow/array/macro.downcast_temporal.html
index c94df541f8..69bb43e089 100644
--- a/arrow/array/macro.downcast_temporal.html
+++ b/arrow/array/macro.downcast_temporal.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="Given one or more expressions evaluating to primitive `DataType` invokes the provided macro `m` with the corresponding `ArrowPrimitiveType`, followed by any additional arguments"><title>downcast_temporal in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crosso [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Given one or more expressions evaluating to primitive `DataType` invokes the provided macro `m` with the corresponding `ArrowPrimitiveType`, followed by any additional arguments"><title>downcast_temporal in arrow::array - Rust</title><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 [...]
     ($(<span class="macro-nonterminal">$data_type</span>:expr),+ =&gt; (<span class="macro-nonterminal">$m</span>:path $(, <span class="macro-nonterminal">$args</span>:tt)<span class="kw-2">*</span>), $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
 }</pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Given one or more expressions evaluating to primitive <a href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType"><code>DataType</code></a> invokes the provided macro
diff --git a/arrow/array/macro.downcast_temporal_array.html b/arrow/array/macro.downcast_temporal_array.html
index c62c5963f0..03c416a2d7 100644
--- a/arrow/array/macro.downcast_temporal_array.html
+++ b/arrow/array/macro.downcast_temporal_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="Downcast an `Array` to a temporal `PrimitiveArray` based on its `DataType` accepts a number of subsequent patterns to match the data type"><title>downcast_temporal_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/Sou [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Downcast an `Array` to a temporal `PrimitiveArray` based on its `DataType` accepts a number of subsequent patterns to match the data type"><title>downcast_temporal_array in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/Sou [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     (<span class="macro-nonterminal">$values</span>:ident =&gt; <span class="macro-nonterminal">$e</span>:expr, $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
     (($(<span class="macro-nonterminal">$values</span>:ident),+) =&gt; <span class="macro-nonterminal">$e</span>:expr, $(<span class="macro-nonterminal">$p</span>:pat =&gt; <span class="macro-nonterminal">$fallback</span>:expr $(,)<span class="kw-2">*</span>)<span class="kw-2">*</span>) =&gt; { ... };
diff --git a/arrow/array/run_iterator/index.html b/arrow/array/run_iterator/index.html
index 22578c1378..ef2e7367b4 100644
--- a/arrow/array/run_iterator/index.html
+++ b/arrow/array/run_iterator/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="Idiomatic iterator for `RunArray`"><title>arrow::array::run_iterator - 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=".. [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Idiomatic iterator for `RunArray`"><title>arrow::array::run_iterator - 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="structs" class="section-header"><a href="#structs">Structs</a></h2><ul class="item-table"><li><div class="item-name"><a class="struct" href="struct.RunArrayIter.html" title="struct arrow::array::run_iterator::RunArrayIter">RunArrayIter</a></div><div class="desc docblock-short">The <a href="struct.RunArrayIter.html" title="struct arrow::array::run_iterator::RunArrayIter"><code>RunArrayIter</code></a> provides an idiomatic way to iterate over the run array.
+</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.RunArrayIter.html" title="struct arrow::array::run_iterator::RunArrayIter">RunArrayIter</a></div><div class="desc docblock-short">The <a href="struct.RunArrayIter.html" title="struct arrow::array::run_iterator::RunArrayIter"><code>RunArrayIter</code></a> provides an idiomatic way to iterate over the run array.
 It returns Some(T) if there is a value or None if the value is null.</div></li></ul></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/run_iterator/struct.RunArrayIter.html b/arrow/array/run_iterator/struct.RunArrayIter.html
index b53f9cb071..e0d929b116 100644
--- a/arrow/array/run_iterator/struct.RunArrayIter.html
+++ b/arrow/array/run_iterator/struct.RunArrayIter.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="The `RunArrayIter` provides an idiomatic way to iterate over the run array. It returns Some(T) if there is a value or None if the value is null."><title>RunArrayIter in arrow::array::run_iterator - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../sta [...]
+<!DOCTYPE html><html lang="en"><head><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 `RunArrayIter` provides an idiomatic way to iterate over the run array. It returns Some(T) if there is a value or None if the value is null."><title>RunArrayIter in arrow::array::run_iterator - Rust</title><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>< [...]
     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>,
@@ -231,16 +231,16 @@ greater than those of another. <a href="https://doc.rust-lang.org/nightly/core/i
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Determines if the elements of this <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator"><code>Iterator</code></a> are <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#lexicographical-compari [...]
 greater than or equal to those of another. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#method.ge">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.is_sorted_by" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/iter/traits/iterator.rs.html#4060-4063">source</a><a href="#method.is_sorted_by" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</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>(&amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>, &amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associ [...]
+    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>(&amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>, &amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</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>(Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>) -&gt; K,
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">PartialOrd</a>,</div></h4></section></summary><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>is_sorted</code>)</span></div></span><div class='docblock'>Checks if the elements of this iterator are sorted using the given key extraction
 function. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#method.is_sorted_by_key">Read more</a></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-RunArrayIter%3C'a,+R,+V%3E" class="impl"><a href="#impl-RefUnwindSafe-for-RunArrayIter%3C'a,+R [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-IntoIterator-for-I" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/iter/traits/collect.rs.html#273">source</a><a href="#impl-IntoIterator-for-I" class="anchor">§</a><h3 class="code-header">impl&lt;I&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collec [...]
@@ -250,8 +250,8 @@ function. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/t
     R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Choose one element at random from the iterator. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_stable">Read more</a></div></details> [...]
     R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects values at random from the iterator into a supplied buffer
 until that buffer is filled. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multiple_fill">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.choose_multiple" class="method trait-impl"><a class="src rightside" href="https://rust-random.github.io/rand/src/rand/seq/mod.rs.html#466-467">source</a><a href="#method.choose_multiple" class="anchor">§</a><h4 class="code-header">fn <a href="https://rus [...]
-    R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects <code>amount</code> values at random from the iterator into a vector. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multip [...]
-    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. [...]
+    R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects <code>amount</code> values at random from the iterator into a vector. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multip [...]
+    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">{"Chain<Self, <U as IntoIterator>::IntoIter>":"<h3>Notable traits for <code><a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/core/iter/adapters/chain/struct.Chain.html\" title=\"struct core::iter::adapters::chain::Chain\">Chain</a>&lt;A, B&gt;</code></h3><pre><code><d [...]
\ No newline at end of file
diff --git a/arrow/array/struct.ArrayData.html b/arrow/array/struct.ArrayData.html
index 83a9cf7cfa..c758c38ecb 100644
--- a/arrow/array/struct.ArrayData.html
+++ b/arrow/array/struct.ArrayData.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="A generic representation of Arrow array data which encapsulates common attributes and operations for Arrow array. Specific operations for different arrays types (e.g., primitive, list, struct) are implemented in `Array`."><title>ArrayData in arrow::array - Rust</title><link rel="preload" [...]
+<!DOCTYPE html><html lang="en"><head><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 representation of Arrow array data which encapsulates common attributes and operations for Arrow array. Specific operations for different arrays types (e.g., primitive, list, struct) are implemented in `Array`."><title>ArrayData in arrow::array - Rust</title><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 id [...]
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -9,7 +9,7 @@
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A generic representation of Arrow array data which encapsulates common attributes and
 operations for Arrow array. Specific operations for different arrays types (e.g.,
 primitive, list, struct) are implemented in <code>Array</code>.</p>
-<h2 id="memory-layout"><a href="#memory-layout">Memory Layout</a></h2>
+<h2 id="memory-layout"><a class="doc-anchor" href="#memory-layout">§</a>Memory Layout</h2>
 <p><code>ArrayData</code> has references to one or more underlying data buffers
 and optional child ArrayData, depending on type as illustrated
 below. Bitmaps are not shown for simplicity but they are stored
@@ -56,7 +56,7 @@ Child ArrayData may also have its own buffers and children
 null_bit_buffer is calculated.</p>
 <p>If the number of nulls is 0 then the null_bit_buffer
 is set to <code>None</code>.</p>
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>The input values <em>must</em> form a valid Arrow array for
 <code>data_type</code>, or undefined behavior can result.</p>
 <p>Note: This is a low level API and most users of the arrow
@@ -118,11 +118,11 @@ children. (See also diagram on <a href="struct.ArrayData.html" title="struct arr
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../src/arrow_data/data.rs.html#532">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">usize</a>) -&g [...]
 <a href="struct.ArrayData.html" title="struct arrow::array::ArrayData"><code>ArrayData</code></a> pointing at the same underlying <a href="../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer"><code>Buffer</code></a>s with a
 different offset and len</p>
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<h5 id="panics"><a class="doc-anchor" href="#panics">§</a>Panics</h5>
 <p>Panics if <code>offset + length &gt; self.len()</code>.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.buffer" class="method"><a class="src rightside" href="../../src/arrow_data/data.rs.html#569">source</a><h4 class="code-header">pub fn <a href="#method.buffer" class="fn">buffer</a>&lt;T&gt;(&amp;self, buffer: <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.slice.html" [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h4></section></summary><div class="docblock"><p>Returns the <code>buffer</code> as a slice of type <code>T</code> starting at self.offset</p>
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<h5 id="panics-1"><a class="doc-anchor" href="#panics-1">§</a>Panics</h5>
 <p>This function panics if:</p>
 <ul>
 <li>the buffer is not byte-aligned with type T, or</li>
@@ -178,33 +178,33 @@ without recursing into child <a href="struct.ArrayData.html" title="struct arrow
 to determine buffer equality. This is cheaper than <code>PartialEq::eq</code> but may
 return false when the arrays are logically equal</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.into_builder" class="method"><a class="src rightside" href="../../src/arrow_data/data.rs.html#1487">source</a><h4 class="code-header">pub fn <a href="#method.into_builder" class="fn">into_builder</a>(self) -&gt; <a class="struct" href="struct.ArrayDataBuilder.html" title="struct arrow::array::ArrayDataBuilder">ArrayDataBuilder</a></h4></section></summary><div class="docblock"><p>Converts this <a href= [...]
-</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-Clone-for-ArrayData" class="impl"><a class="src rightside" href="../../src/arrow_data/data.rs.html#217">source</a><a href="#impl-Clone-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl <a class= [...]
+</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-Clone-for-ArrayData" class="impl"><a class="src rightside" href="../../src/arrow_data/data.rs.html#217">source</a><a href="#impl-Clone-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl <a class= [...]
     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-23" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#571">source</a><a href="#method.from-23" 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.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-15" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-15" 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.from-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#374">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ [...]
+</div><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/dictionary_array.rs.html#571">source</a><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>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::arra [...]
+    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-16" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-16" 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.from-15" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#374">source</a><a href="#method.from-15" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
     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-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1376">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>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::arra [...]
-    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-14" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#259">source</a><a href="#method.from-14" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
-    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-10" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#619">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">f [...]
-    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#521">source</a><a href="#method.from-8" 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-3" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#381">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ [...]
-    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#977">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="http [...]
-    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-9" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#286">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+</div><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#1376">source</a><a href="#method.from-22" 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 [...]
+    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-lang.o [...]
+    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-6" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#619">source</a><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn  [...]
+    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-23" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-23" 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.from-17" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#381">source</a><a href="#method.from-17" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
+    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-3" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#977">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="http [...]
+    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-20" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#286">source</a><a href="#method.from-20" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
 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#242">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-ToPyArrow-for-ArrayData" class="impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#294-310">source</a><a href="#impl-ToPyArrow-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../pyarrow/trait.ToPyArrow.html" title="trait arrow::pyarrow::ToPyArrow">ToPyArrow</a> [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-IntoPyArrow-for-T" class="impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#98-102">source</a><a href="#impl-IntoPyArrow-for-T" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../pyarrow/trait.IntoPyArrow.html" title="trait arrow::pyarrow::IntoPyArrow">IntoPyArrow</a> for T<div class="where">where
     T: <a class="trait" href="../pyarrow/trait.ToPyArrow.html" title="trait arrow::pyarrow::ToPyArrow">ToPyArrow</a>,</div></h3></section></summary><div class="impl-items"><section id="method.into_pyarrow" class="method trait-impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#99-101">source</a><a href="#method.into_pyarrow" class="anchor">§</a><h4 class="code-header">fn <a href="../pyarrow/trait.IntoPyArrow.html#tymethod.into_pyarrow" class="fn">into_pyarrow</a>(self, p [...]
-    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. [...]
+    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" 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 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& [...]
     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/struct.ArrayDataBuilder.html b/arrow/array/struct.ArrayDataBuilder.html
index 845ec77796..dc5349a51d 100644
--- a/arrow/array/struct.ArrayDataBuilder.html
+++ b/arrow/array/struct.ArrayDataBuilder.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="Builder for `ArrayData` type"><title>ArrayDataBuilder in arrow::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="../. [...]
+<!DOCTYPE html><html lang="en"><head><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 `ArrayData` type"><title>ArrayDataBuilder in arrow::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 id [...]
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -10,7 +10,7 @@
     child_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="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <code>ArrayData</code> type</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.len" class="structfield section-header"><a href="#structfield.len" class="anchor field">§</a>< [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<h5 id="safety"><a class="doc-anchor" href="#safety">§</a>Safety</h5>
 <p>The same caveats as <a href="struct.ArrayData.html#method.new_unchecked" title="associated function arrow::array::ArrayData::new_unchecked"><code>ArrayData::new_unchecked</code></a>
 apply.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.build" class="method"><a class="src rightside" href="../../src/arrow_data/data.rs.html#1784">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.ArrayData.html" title="struct arrow::array::Arra [...]
@@ -28,14 +28,14 @@ insufficiently aligned buffers.</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-Debug-for-ArrayDataBuilder" class="impl"><a class="src rightside" href="../../src/arrow_data/data.rs.html#1665">source</a><a href="#impl-Debug-for-ArrayDataBuilder" class="anchor">§</a><h3 class="code-header" [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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& [...]
     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/struct.ArrayIter.html b/arrow/array/struct.ArrayIter.html
index df77da6d9b..f879737ac8 100644
--- a/arrow/array/struct.ArrayIter.html
+++ b/arrow/array/struct.ArrayIter.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="An iterator that returns Some(T) or None, that can be used on any `ArrayAccessor`"><title>ArrayIter in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as=" [...]
+<!DOCTYPE html><html lang="en"><head><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 iterator that returns Some(T) or None, that can be used on any `ArrayAccessor`"><title>ArrayIter in arrow::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><div id [...]
     T: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,</div>{
     array: T,
@@ -6,7 +6,7 @@
     current: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     current_end: <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 iterator that returns Some(T) or None, that can be used on any <a href="trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor"><code>ArrayAccessor</code></a></p>
-<h2 id="performance"><a href="#performance">Performance</a></h2>
+<h2 id="performance"><a class="doc-anchor" href="#performance">§</a>Performance</h2>
 <p><a href="iterator/struct.ArrayIter.html" title="struct arrow::array::iterator::ArrayIter"><code>ArrayIter</code></a> provides an idiomatic way to iterate over an array, however, this
 comes at the cost of performance. In particular the interleaved handling of
 the null mask is often sub-optimal.</p>
@@ -215,7 +215,7 @@ greater than those of another. <a href="https://doc.rust-lang.org/nightly/core/i
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Determines if the elements of this <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator"><code>Iterator</code></a> are <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#lexicographical-compari [...]
 greater than or equal to those of another. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#method.ge">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.is_sorted_by" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/iter/traits/iterator.rs.html#4060-4063">source</a><a href="#method.is_sorted_by" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</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>(&amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>, &amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associ [...]
+    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>(&amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>, &amp;Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</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>(Self::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html#associatedtype.Item" title="type core::iter::traits::iterator::Iterator::Item">Item</a>) -&gt; K,
     K: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">PartialOrd</a>,</div></h4></section></summary><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>is_sorted</code>)</span></div></span><div class='docblock'>Checks if the elements of this iterator are sorted using the given key extraction
@@ -225,9 +225,9 @@ function. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/t
     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 [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-IntoIterator-for-I" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/iter/traits/collect.rs.html#273">source</a><a href="#impl-IntoIterator-for-I" class="anchor">§</a><h3 class="code-header">impl&lt;I&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collec [...]
@@ -237,9 +237,9 @@ function. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/t
     R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Choose one element at random from the iterator. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_stable">Read more</a></div></details> [...]
     R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects values at random from the iterator into a supplied buffer
 until that buffer is filled. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multiple_fill">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.choose_multiple" class="method trait-impl"><a class="src rightside" href="https://rust-random.github.io/rand/src/rand/seq/mod.rs.html#466-467">source</a><a href="#method.choose_multiple" class="anchor">§</a><h4 class="code-header">fn <a href="https://rus [...]
-    R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects <code>amount</code> values at random from the iterator into a vector. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multip [...]
-    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. [...]
+    R: <a class="trait" href="https://rust-random.github.io/rand/rand/rng/trait.Rng.html" title="trait rand::rng::Rng">Rng</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h4></section></summary><div class='docblock'>Collects <code>amount</code> values at random from the iterator into a vector. <a href="https://rust-random.github.io/rand/rand/seq/trait.IteratorRandom.html#method.choose_multip [...]
+    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 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& [...]
     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<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\" href=\"https://doc.rust- [...]
\ No newline at end of file
diff --git a/arrow/array/struct.BooleanArray.html b/arrow/array/struct.BooleanArray.html
index 177ea33ca4..e4d21f6b1f 100644
--- a/arrow/array/struct.BooleanArray.html
+++ b/arrow/array/struct.BooleanArray.html
@@ -1,17 +1,17 @@
-<!DOCTYPE html><html lang="en"><head><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 - 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="../../stat [...]
+<!DOCTYPE html><html lang="en"><head><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 - 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="../../stat [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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>
-<h2 id="example-from-a-vec"><a href="#example-from-a-vec">Example: From a Vec</a></h2>
+<h2 id="example-from-a-vec"><a class="doc-anchor" href="#example-from-a-vec">§</a>Example: From a Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: BooleanArray = <span class="macro">vec!</span>[<span class="bool-val">true</span>, <span class="bool-val">true</span>, <span class="bool-val">false</span>].into();</code></pre></div>
-<h2 id="example-from-an-optional-vec"><a href="#example-from-an-optional-vec">Example: From an optional Vec</a></h2>
+<h2 id="example-from-an-optional-vec"><a class="doc-anchor" href="#example-from-an-optional-vec">§</a>Example: From an optional Vec</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: BooleanArray = <span class="macro">vec!</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>)].into();</code></pre></div>
-<h2 id="example-from-an-iterator"><a href="#example-from-an-iterator">Example: From an iterator</a></h2>
+<h2 id="example-from-an-iterator"><a class="doc-anchor" href="#example-from-an-iterator">§</a>Example: From an iterator</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>arr: BooleanArray = (<span class="number">0</span>..<span class="number">5</span>).map(|x| (x % <span class="number">2 </span>== <span class="number">0</span>).then(|| x % <span class="number">3 </span>== <span class="number">0</span>)).collect();
 <span class="kw">let </span>values: Vec&lt;<span class="kw">_</span>&gt; = arr.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>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="bool-val">false</span>)])</code></pre></div>
-<h2 id="example-using-builder"><a href="#example-using-builder">Example: Using Builder</a></h2>
+<h2 id="example-using-builder"><a class="doc-anchor" href="#example-using-builder">§</a>Example: Using Builder</h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>builder = BooleanBuilder::new();
 builder.append_value(<span class="bool-val">true</span>);
 builder.append_null();
@@ -20,7 +20,7 @@ builder.append_value(<span class="bool-val">false</span>);
 <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 fie [...]
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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::BooleanArray">B [...]
 </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">Scalar [...]
@@ -32,10 +32,10 @@ builder.append_value(<span class="bool-val">false</span>);
 </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 null,  [...]
 </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 nul [...]
 </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/ni [...]
-<h5 id="safety"><a href="#safety">Safety</a></h5>
+<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">bool</ [...]
-<h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
+<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;(
     &amp;'a self,
@@ -45,7 +45,7 @@ builder.append_value(<span class="bool-val">false</span>);
     &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 href="#safety-1">Safety</a></h5>
+<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
     T: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,
@@ -67,7 +67,7 @@ each element of the provided arrays</p>
 <span class="kw">let </span>b = Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">0</span>, <span class="number">2</span>, <span class="number">5</span>]);
 <span class="kw">let </span>r = BooleanArray::from_binary(<span class="kw-2">&amp;</span>a, <span class="kw-2">&amp;</span>b, |a, b| a == b);
 <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 href="#panics-2">Panics</a></h5>
+<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/nightly/co [...]
 </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"><details cla [...]
@@ -81,7 +81,7 @@ includes the overhead of the data structures that contain the pointers to the va
 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-header">fn <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.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="trait.ArrayAc [...]
+) -&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="trait.ArrayAc [...]
     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#242">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= [...]
@@ -89,15 +89,15 @@ sufficient, and should not be overridden without very good reason.</div></detail
     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;dyn <a cl [...]
+    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;dyn <a cl [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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. [...]
+    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" 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 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& [...]
     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=\"ht [...]
\ No newline at end of file
diff --git a/arrow/array/struct.BooleanBufferBuilder.html b/arrow/array/struct.BooleanBufferBuilder.html
index 26aa7ec665..cb879654bf 100644
--- a/arrow/array/struct.BooleanBufferBuilder.html
+++ b/arrow/array/struct.BooleanBufferBuilder.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="Builder for `BooleanBuffer`"><title>BooleanBufferBuilder in arrow::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=". [...]
+<!DOCTYPE html><html lang="en"><head><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 - 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 id [...]
     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>,
@@ -26,7 +26,7 @@ growing it (potentially reallocating it) and writing <code>false</code> in the n
 </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 of [...]
 </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 cl [...]
 <p><code>to_set</code> is a slice of bits packed LSB-first into <code>[u8]</code></p>
-<h5 id="panics"><a href="#panics">Panics</a></h5>
+<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 class="d [...]
 </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><di [...]
@@ -36,14 +36,14 @@ growing it (potentially reallocating it) and writing <code>false</code> in the 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-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><h3  [...]
     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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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& [...]
     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/struct.BooleanBuilder.html b/arrow/array/struct.BooleanBuilder.html
index 89129b1ecc..ee90f4bc62 100644
--- a/arrow/array/struct.BooleanBuilder.html
+++ b/arrow/array/struct.BooleanBuilder.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 `BooleanArray`"><title>BooleanBuilder in arrow::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="../../st [...]
+<!DOCTYPE html><html lang="en"><head><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 - 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="../../st [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     values_builder: <a class="struct" href="builder/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>,
 }</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 href="#example">Example</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example</h2>
 <p>Create a <code>BooleanArray</code> from a <code>BooleanBuilder</code></p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
@@ -55,14 +55,14 @@ b.append_value(<span class="bool-val">true</span>);
     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:/ [...]
-    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="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= [...]
 </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#756">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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-TryFrom%3CU%3E-for-T" class="impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#803-805">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. [...]
+</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-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 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& [...]
     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/struct.BufferBuilder.html b/arrow/array/struct.BufferBuilder.html
index ab5608ea2e..8e983b06cc 100644
--- a/arrow/array/struct.BufferBuilder.html
+++ b/arrow/array/struct.BufferBuilder.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="Builder for creating a Buffer object."><title>BufferBuilder in arrow::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 [...]
+<!DOCTYPE html><html lang="en"><head><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 - 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 id [...]
     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>,
@@ -8,7 +8,7 @@
 <p>A <a href="../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a> is the underlying data structure of Arrow’s Arrays.</p>
 <p>For all supported types, there are type definitions for the
 generic version of <code>BufferBuilder&lt;T&gt;</code>, e.g. <code>BufferBuilder</code>.</p>
-<h2 id="example"><a href="#example">Example:</a></h2>
+<h2 id="example"><a class="doc-anchor" href="#example">§</a>Example:</h2>
 <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">100</span>);
 builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">43</span>, <span class="number">44</span>]);
@@ -26,21 +26,21 @@ Also the
 <a href="builder/struct.BufferBuilder.html#method.append_slice" title="method arrow::array::builder::BufferBuilder::append_slice"><code>append_slice()</code></a> and
 <a href="builder/struct.BufferBuilder.html#method.advance" title="method arrow::array::builder::BufferBuilder::advance"><code>advance()</code></a>
 methods automatically increase the capacity if needed.</p>
-<h5 id="example-1"><a href="#example-1">Example:</a></h5>
+<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">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="builder/struct.BufferBuild [...]
 </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 internal [...]
-<h5 id="example-2"><a href="#example-2">Example:</a></h5>
+<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>
-<h5 id="example-3"><a href="#example-3">Example:</a></h5>
+<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>);
@@ -55,14 +55,14 @@ 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
 as they still require physical memory space.</p>
-<h5 id="example-4"><a href="#example-4">Example:</a></h5>
+<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">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 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>n< [...]
-<h5 id="example-5"><a href="#example-5">Example:</a></h5>
+<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>);
@@ -70,7 +70,7 @@ 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,
 growing the internal buffer as needed.</p>
-<h5 id="example-6"><a href="#example-6">Example:</a></h5>
+<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>
 <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>);
@@ -78,14 +78,14 @@ 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</code [...]
 growing the internal buffer as needed.</p>
-<h5 id="example-7"><a href="#example-7">Example:</a></h5>
+<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">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u8&gt;::new(<span class="number">10</span>);
 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</code> [...]
-<h5 id="example-8"><a href="#example-8">Example:</a></h5>
+<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>);
 builder.append_n_zeroed(<span class="number">3</span>);
@@ -93,7 +93,7 @@ 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 type  [...]
-<h5 id="example-9"><a href="#example-9">Example:</a></h5>
+<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>]);
@@ -108,7 +108,7 @@ 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 of t [...]
-<h5 id="example-10"><a href="#example-10">Example:</a></h5>
+<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>);
 
@@ -119,7 +119,7 @@ builder.as_slice_mut()[<span class="number">1</span>] = <span class="number">4.2
 <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>len</ [...]
 <p>If <code>len</code> is greater than the builder’s current length, this has no effect</p>
-<h5 id="example-11"><a href="#example-11">Example:</a></h5>
+<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>
 <span class="kw">let </span><span class="kw-2">mut </span>builder = BufferBuilder::&lt;u16&gt;::new(<span class="number">10</span>);
 
@@ -134,11 +134,11 @@ builder.append(<span class="number">12</span>);
 </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>(
     &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 href="#safety">Safety</a></h5>
+)</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 immutab [...]
-<h5 id="example-12"><a href="#example-12">Example:</a></h5>
+<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>);
 builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</span>, <span class="number">44</span>, <span class="number">46</span>]);
@@ -152,8 +152,8 @@ builder.append_slice(<span class="kw-2">&amp;</span>[<span class="number">42</sp
     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-lang. [...]
     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.rust-lang [...]
-    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.rust-lan [...]
-    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-lang. [...]
+    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/buffer/scalar.rs.html#164">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lan [...]
+    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/builder/mod.rs.html#376">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
... 100588 lines suppressed ...