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 2023/12/25 15:15:26 UTC

(arrow-rs) branch asf-site updated: deploy: 0eb8a08f8893870a6d7aafa63aef0e92593a7585

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 03be555322 deploy: 0eb8a08f8893870a6d7aafa63aef0e92593a7585
03be555322 is described below

commit 03be55532274d593e40a832c097989b27bf48a83
Author: tustvold <tu...@users.noreply.github.com>
AuthorDate: Mon Dec 25 15:15:15 2023 +0000

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

diff --git a/arrow/all.html b/arrow/all.html
index e850904aeb..7279d39e92 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 94afe5ca67..d0e1b7fa78 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 333bfdfb67..37ae8e7104 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 [...]
 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 0ffebb8daf..3f6f1f5a0b 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 0ffdee5f83..e19293a587 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 ba81524124..d244f1310c 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 840d04dfbd..bd82ac7bdc 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 082d478ed2..bce46c6081 100644
--- a/arrow/array/array/index.html
+++ b/arrow/array/array/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="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 [...]
 (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 [...]
diff --git a/arrow/array/array/struct.BooleanArray.html b/arrow/array/array/struct.BooleanArray.html
index 0294ca7aeb..367219f2c7 100644
--- a/arrow/array/array/struct.BooleanArray.html
+++ b/arrow/array/array/struct.BooleanArray.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 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;,
@@ -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= [...]
diff --git a/arrow/array/array/struct.DictionaryArray.html b/arrow/array/array/struct.DictionaryArray.html
index 300978a304..84258a8a03 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>,
@@ -182,7 +182,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-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 [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of strings.</p>
-<h4 id="example-1"><a href="#example-1">Example:</a></h4>
+<h4 id="example-2"><a href="#example-2">Example:</a></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>];
@@ -191,10 +191,10 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  1,\n  2,\n] values: StringArray\n[\n  \"a\",\n  \"b\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#672">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struc [...]
+</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-2"><a href="#example-2">Example:</a></h4>
+<h4 id="example-1"><a href="#example-1">Example:</a></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>];
@@ -206,7 +206,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  null,\n  1,\n] values: StringArray\n[\n  \"a\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#648">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="s [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#648">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struc [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
     K: <a class="trait" href="../../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#468">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https: [...]
 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= [...]
diff --git a/arrow/array/array/struct.FixedSizeBinaryArray.html b/arrow/array/array/struct.FixedSizeBinaryArray.html
index 65b6b706b3..f88c9340c1 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>,
@@ -133,8 +133,8 @@ 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-3" 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-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="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 [...]
diff --git a/arrow/array/array/struct.FixedSizeListArray.html b/arrow/array/array/struct.FixedSizeListArray.html
index 0657610c2f..493a6d47f6 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;,
@@ -131,15 +131,15 @@ 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= [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
+) -&gt; &lt;<a class="struct" href="../struct.FixedSizeListArray.html" title="struct arrow::array::FixedSizeListArray">FixedSizeListArray</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code> <a  [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a 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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lan [...]
 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 [...]
diff --git a/arrow/array/array/struct.GenericByteArray.html b/arrow/array/array/struct.GenericByteArray.html
index 21fca25f2a..cc014c1d0a 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>,
@@ -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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#79">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.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from" 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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#79">source</a><a href="#method.from-4" 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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-9" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-9" 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-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-5" 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/string_array.rs.html#71">source</a><a href="#method.from-2" 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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#71">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.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-7" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#110">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#91">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-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#104">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+    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-11" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-11" 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-6" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#110">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-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#91">source</a><a href="#method.from-5" 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-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#104">source</a><a href="#method.from-2" 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-11" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#85">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-6" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#97">source</a><a href="#method.from-6" 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-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 [...]
     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-9" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#103">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-10" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#103">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>,
     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 [...]
diff --git a/arrow/array/array/struct.GenericListArray.html b/arrow/array/array/struct.GenericListArray.html
index 73988a769b..62abdff655 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>,
@@ -139,13 +139,13 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
 ) -&gt; &lt;&amp;'a <a class="struct" href="../struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt; as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at inde [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.clone" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#135">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#528">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ [...]
-    OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#374">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" 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-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#381">source</a><a href="#method.from-5" 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-3" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-3" 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/list_array.rs.html#374">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-5" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from-5" 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-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-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/string_array.rs.html#71">source</a><a href="#method.from-2" 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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-4" 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-4" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
     OffsetSize: <a class="trait" href="../trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/mod.rs.html#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 [...]
diff --git a/arrow/array/array/struct.MapArray.html b/arrow/array/array/struct.MapArray.html
index 3024d256d5..1a2ef8e08d 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;,
@@ -74,7 +74,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.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 [...]
diff --git a/arrow/array/array/struct.NativeAdapter.html b/arrow/array/array/struct.NativeAdapter.html
index 060426782a..abd3208287 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,8 +11,8 @@ 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#1167">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-12" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1206">source</a><a href="#method.from-12" class="anchor">§</a><h4 class="code-header">fn <a h [...]
-    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#1200">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-13" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1206">source</a><a href="#method.from-13" class="anchor">§</a><h4 class="code-header">fn <a h [...]
+    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#1200">source</a><a href="#method.from-8" 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 [...]
diff --git a/arrow/array/array/struct.NullArray.html b/arrow/array/array/struct.NullArray.html
index 4b2a4c736e..431697cd07 100644
--- a/arrow/array/array/struct.NullArray.html
+++ b/arrow/array/array/struct.NullArray.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 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>
diff --git a/arrow/array/array/struct.PrimitiveArray.html b/arrow/array/array/struct.PrimitiveArray.html
index e2493a77b2..936e1e7446 100644
--- a/arrow/array/array/struct.PrimitiveArray.html
+++ b/arrow/array/array/struct.PrimitiveArray.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 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>,
@@ -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#1094">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-30" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-30" 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-8" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#978">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-55" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-55" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="../struct.ArrayData.html" title="struct arr [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-22" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#978">source</a><a href="#method.from-22" class="anchor">§</a><h4 class="code-header">fn <a hr [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDate64Type+as+ArrowPrimi [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date32Type.html" title="struct arrow::datatypes::Date32Type">Date32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDate64Type+as+ArrowPrimi [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.htm [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal128Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Date64Type.html" title="struct arrow::datatypes::Date64Type">Date64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal128Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimi [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal256Ty [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal128Type.html" title="struct arrow::datatypes::Decimal128Type">Decimal128Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDecimal256Ty [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimi [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDurationMicr [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Decimal256Type.html" title="struct arrow::datatypes::Decimal256Type">Decimal256Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CDurationMicr [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../.. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMicrosecondType.html" title="struct arrow::datatypes::DurationMicrosecondType">DurationMicrosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../.. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../da [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trai [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat32Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat32Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat64Type+as+ArrowP [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float32Type.html" title="struct arrow::datatypes::Float32Type">Float32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CFloat64Type+as+ArrowP [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt16Type+as+ArrowPri [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Float64Type.html" title="struct arrow::datatypes::Float64Type">Float64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt16Type+as+ArrowPri [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt32Type+as+ArrowPrimitive [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt32Type+as+ArrowPrimitive [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt64Type+as+ArrowPrimitive [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int32Type.html" title="struct arrow::datatypes::Int32Type">Int32Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt64Type+as+ArrowPrimitive [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#a [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt8Type+as+ArrowPrimitiveT [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int64Type.html" title="struct arrow::datatypes::Int64Type">Int64Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CInt8Type+as+ArrowPrimitiveT [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#asso [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CIntervalDayTimeType+as+ArrowPr [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Int8Type.html" title="struct arrow::datatypes::Int8Type">Int8Type</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CIntervalDayTimeType+as+ArrowPr [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/t [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href=".. [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalMonthDayNanoType.html" title="struct arrow::datatypes::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="imp [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datat [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datat [...]
-) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
+) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3C [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a> as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.Arro [...]
 ) -&gt; <a class="struct" href="../struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../../datatypes/struct.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%3C%3CTime64 [...]
     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>,
diff --git a/arrow/array/array/struct.RunArray.html b/arrow/array/array/struct.RunArray.html
index 52a4422ecc..9650c00756 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>,
@@ -84,7 +84,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     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"><a href="#example">Example:</a></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>];
@@ -93,10 +93,10 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"RunArray {run_ends: [2, 3, 4], values: StringArray\n[\n  \"a\",\n  \"b\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#445">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct"  [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#445">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href [...]
     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-1"><a href="#example-1">Example:</a></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>];
@@ -108,7 +108,7 @@ opposite of <a href="../trait.Array.html#method.is_null" title="method arrow_arr
     <span class="string">"RunArray {run_ends: [2, 3, 5], values: StringArray\n[\n  \"a\",\n  null,\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#418">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_array/array/run_array.rs.html#418">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 = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
     &lt;R as <a class="trait" href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><sectio [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.type_id" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#141">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a href [...]
diff --git a/arrow/array/array/struct.StructArray.html b/arrow/array/array/struct.StructArray.html
index f34749514e..e610f9774a 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>,
@@ -96,7 +96,7 @@ 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>
diff --git a/arrow/array/array/struct.TypedDictionaryArray.html b/arrow/array/array/struct.TypedDictionaryArray.html
index adde86a0c2..83ee687963 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;,
diff --git a/arrow/array/array/struct.TypedRunArray.html b/arrow/array/array/struct.TypedRunArray.html
index 91257f47f2..b594d45a2d 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;,
diff --git a/arrow/array/array/struct.UnionArray.html b/arrow/array/array/struct.UnionArray.html
index 1790cea094..5882f73c79 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;,
diff --git a/arrow/array/array/trait.AnyDictionaryArray.html b/arrow/array/array/trait.AnyDictionaryArray.html
index 7395a792cb..22d9cc069d 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>;
diff --git a/arrow/array/array/trait.Array.html b/arrow/array/array/trait.Array.html
index 6b084dc36d..7eb50350a6 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);
@@ -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" 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 [...]
+    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 [...]
+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="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 0cb3a3e40f..0dd15f486e 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>;
 
diff --git a/arrow/array/array/trait.ArrowPrimitiveType.html b/arrow/array/array/trait.ArrowPrimitiveType.html
index 20ef83d3ea..ce5d78489b 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 35dec8fa3c..e2dab04188 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 2bcf241525..4d91fa4f19 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 b2ec8a9553..f037fb90b6 100644
--- a/arrow/array/array/type.BinaryArray.html
+++ b/arrow/array/array/type.BinaryArray.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` 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>
diff --git a/arrow/array/array/type.Date32Array.html b/arrow/array/array/type.Date32Array.html
index 4f296a68f6..d7f9b2976c 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 145f5a98a2..a440c54c38 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 abda4e07d9..e9c80d4c27 100644
--- a/arrow/array/array/type.Decimal128Array.html
+++ b/arrow/array/array/type.Decimal128Array.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 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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Decimal256Array.html b/arrow/array/array/type.Decimal256Array.html
index 1ddba08023..84e4e77f94 100644
--- a/arrow/array/array/type.Decimal256Array.html
+++ b/arrow/array/array/type.Decimal256Array.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 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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.DurationMicrosecondArray.html b/arrow/array/array/type.DurationMicrosecondArray.html
index 80f3fe433e..e50738fe44 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 2c051fe7d8..1ee3c6bcd5 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 9380c7013e..470c5d2230 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 35949fe21d..3bd9af05f0 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 31d430075d..65be604492 100644
--- a/arrow/array/array/type.Float16Array.html
+++ b/arrow/array/array/type.Float16Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Float32Array.html b/arrow/array/array/type.Float32Array.html
index 03fc608b53..8a0adb8069 100644
--- a/arrow/array/array/type.Float32Array.html
+++ b/arrow/array/array/type.Float32Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Float64Array.html b/arrow/array/array/type.Float64Array.html
index e01f2a314c..10b1a5f1fe 100644
--- a/arrow/array/array/type.Float64Array.html
+++ b/arrow/array/array/type.Float64Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.GenericBinaryArray.html b/arrow/array/array/type.GenericBinaryArray.html
index 3cfbf24d0c..5dcf4206e4 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 349e3d3b4f..df1fb866d2 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 f9ae046c2c..aa4666af67 100644
--- a/arrow/array/array/type.Int16Array.html
+++ b/arrow/array/array/type.Int16Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Int16DictionaryArray.html b/arrow/array/array/type.Int16DictionaryArray.html
index 229bd4d19b..d484ead3b5 100644
--- a/arrow/array/array/type.Int16DictionaryArray.html
+++ b/arrow/array/array/type.Int16DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.Int16RunArray.html b/arrow/array/array/type.Int16RunArray.html
index 97b67bdfd2..e46daafff7 100644
--- a/arrow/array/array/type.Int16RunArray.html
+++ b/arrow/array/array/type.Int16RunArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.Int32Array.html b/arrow/array/array/type.Int32Array.html
index f0ca1ccc85..d2a66495de 100644
--- a/arrow/array/array/type.Int32Array.html
+++ b/arrow/array/array/type.Int32Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Int32DictionaryArray.html b/arrow/array/array/type.Int32DictionaryArray.html
index fa5cf09538..38cadc71f5 100644
--- a/arrow/array/array/type.Int32DictionaryArray.html
+++ b/arrow/array/array/type.Int32DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.Int32RunArray.html b/arrow/array/array/type.Int32RunArray.html
index 594810c1e2..534abdd579 100644
--- a/arrow/array/array/type.Int32RunArray.html
+++ b/arrow/array/array/type.Int32RunArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.Int64Array.html b/arrow/array/array/type.Int64Array.html
index 14d30c16f2..8edf67fe2f 100644
--- a/arrow/array/array/type.Int64Array.html
+++ b/arrow/array/array/type.Int64Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Int64DictionaryArray.html b/arrow/array/array/type.Int64DictionaryArray.html
index a79006810e..370c983da6 100644
--- a/arrow/array/array/type.Int64DictionaryArray.html
+++ b/arrow/array/array/type.Int64DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.Int64RunArray.html b/arrow/array/array/type.Int64RunArray.html
index e1405dac2d..327332c3f3 100644
--- a/arrow/array/array/type.Int64RunArray.html
+++ b/arrow/array/array/type.Int64RunArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.Int8Array.html b/arrow/array/array/type.Int8Array.html
index 8ce2973006..1b624d0c5f 100644
--- a/arrow/array/array/type.Int8Array.html
+++ b/arrow/array/array/type.Int8Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Int8DictionaryArray.html b/arrow/array/array/type.Int8DictionaryArray.html
index 615344f6c6..506673afc8 100644
--- a/arrow/array/array/type.Int8DictionaryArray.html
+++ b/arrow/array/array/type.Int8DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.IntervalDayTimeArray.html b/arrow/array/array/type.IntervalDayTimeArray.html
index fc7703a8f4..c08b6e16d3 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 f88c00963c..5a8f5a0eb0 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 a21cc77885..f063cba864 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 435771d5d6..575f905cb9 100644
--- a/arrow/array/array/type.LargeBinaryArray.html
+++ b/arrow/array/array/type.LargeBinaryArray.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` 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>
 <p>Create a LargeBinaryArray from a vector of byte slices.</p>
diff --git a/arrow/array/array/type.LargeListArray.html b/arrow/array/array/type.LargeListArray.html
index 75530eee4c..0304a283db 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 127bbec008..ff82a7ba39 100644
--- a/arrow/array/array/type.LargeStringArray.html
+++ b/arrow/array/array/type.LargeStringArray.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.ListArray.html b/arrow/array/array/type.ListArray.html
index f427f6ba1f..4f00f38af0 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 d17bc79983..a65a3b7d0d 100644
--- a/arrow/array/array/type.StringArray.html
+++ b/arrow/array/array/type.StringArray.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.Time32MillisecondArray.html b/arrow/array/array/type.Time32MillisecondArray.html
index 4dcf0e3fc0..c503fea7c3 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 badfe2e1de..9046bdbc2f 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 411bec631d..8bbb539fa6 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 7f0884d40f..bb70147e8f 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 39b9236b70..5be70a93c5 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 ecf53c930d..16d41ba280 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 f100c4de33..0ee968ac80 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 dc34e2ea3e..6881cb3e13 100644
--- a/arrow/array/array/type.TimestampSecondArray.html
+++ b/arrow/array/array/type.TimestampSecondArray.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 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>
diff --git a/arrow/array/array/type.UInt16Array.html b/arrow/array/array/type.UInt16Array.html
index 0cc5814961..772fbce591 100644
--- a/arrow/array/array/type.UInt16Array.html
+++ b/arrow/array/array/type.UInt16Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.UInt16DictionaryArray.html b/arrow/array/array/type.UInt16DictionaryArray.html
index 1b24140eca..1e0ea718ef 100644
--- a/arrow/array/array/type.UInt16DictionaryArray.html
+++ b/arrow/array/array/type.UInt16DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.UInt32Array.html b/arrow/array/array/type.UInt32Array.html
index edb6dc59bf..c223b0deaa 100644
--- a/arrow/array/array/type.UInt32Array.html
+++ b/arrow/array/array/type.UInt32Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.UInt32DictionaryArray.html b/arrow/array/array/type.UInt32DictionaryArray.html
index 53aa28d57d..ec1f094fd0 100644
--- a/arrow/array/array/type.UInt32DictionaryArray.html
+++ b/arrow/array/array/type.UInt32DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.UInt64Array.html b/arrow/array/array/type.UInt64Array.html
index a49c4d7197..f55f9a92be 100644
--- a/arrow/array/array/type.UInt64Array.html
+++ b/arrow/array/array/type.UInt64Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.UInt64DictionaryArray.html b/arrow/array/array/type.UInt64DictionaryArray.html
index 04d8665403..2be2913d59 100644
--- a/arrow/array/array/type.UInt64DictionaryArray.html
+++ b/arrow/array/array/type.UInt64DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/array/type.UInt8Array.html b/arrow/array/array/type.UInt8Array.html
index 8088c53b99..142365bac4 100644
--- a/arrow/array/array/type.UInt8Array.html
+++ b/arrow/array/array/type.UInt8Array.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 `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>
 <p>Construction</p>
diff --git a/arrow/array/array/type.UInt8DictionaryArray.html b/arrow/array/array/type.UInt8DictionaryArray.html
index 54be5ab708..ccda42ca8d 100644
--- a/arrow/array/array/type.UInt8DictionaryArray.html
+++ b/arrow/array/array/type.UInt8DictionaryArray.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` 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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/builder/fn.make_builder.html b/arrow/array/builder/fn.make_builder.html
index a443c2181a..73073bc523 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 0166f38647..6ef34e9dc5 100644
--- a/arrow/array/builder/index.html
+++ b/arrow/array/builder/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 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>
 <p>Builders can be used to build simple, non-nested arrays</p>
diff --git a/arrow/array/builder/struct.BooleanBufferBuilder.html b/arrow/array/builder/struct.BooleanBufferBuilder.html
index c7d0377c64..4c864eb9ee 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>,
diff --git a/arrow/array/builder/struct.BooleanBuilder.html b/arrow/array/builder/struct.BooleanBuilder.html
index 1f0aef2ad1..18a8bd39ad 100644
--- a/arrow/array/builder/struct.BooleanBuilder.html
+++ b/arrow/array/builder/struct.BooleanBuilder.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 `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>,
diff --git a/arrow/array/builder/struct.BufferBuilder.html b/arrow/array/builder/struct.BufferBuilder.html
index 3cc8e17c0f..7041a495da 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>,
@@ -151,9 +151,9 @@ 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.default" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#362">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.extend" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#368">source</a><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = T&gt;,</div></h4></section></summary><div class='docblock'>Extends a collection with the contents of an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html#tymethod.extend">Read more</a></div></details><details class="toggle method-toggle" open><summa [...]
-    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/buffer/immutable.rs.html#376">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc [...]
-    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" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#376">source</a><a href="#method.from" 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/buffer/immutable.rs.html#376">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc [...]
+    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/scalar.rs.html#164">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
+    T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#376">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust [...]
     T: <a class="trait" href="../../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../../src/arrow_buffer/builder/mod.rs.html#382">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://do [...]
     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 [...]
diff --git a/arrow/array/builder/struct.FixedSizeBinaryBuilder.html b/arrow/array/builder/struct.FixedSizeBinaryBuilder.html
index c9f5413480..2d71fd358d 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>,
diff --git a/arrow/array/builder/struct.FixedSizeListBuilder.html b/arrow/array/builder/struct.FixedSizeListBuilder.html
index bda7943883..fc0c3223b7 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>,
diff --git a/arrow/array/builder/struct.GenericByteBuilder.html b/arrow/array/builder/struct.GenericByteBuilder.html
index 9220c93e67..c0096a26fd 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;,
diff --git a/arrow/array/builder/struct.GenericByteDictionaryBuilder.html b/arrow/array/builder/struct.GenericByteDictionaryBuilder.html
index 2b94bf84d0..aa0fca2317 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>{
diff --git a/arrow/array/builder/struct.GenericByteRunBuilder.html b/arrow/array/builder/struct.GenericByteRunBuilder.html
index e3fdd149bf..3e22a4cd55 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>{
diff --git a/arrow/array/builder/struct.GenericListBuilder.html b/arrow/array/builder/struct.GenericListBuilder.html
index 83c1302cb2..46aa69c2dd 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>{
diff --git a/arrow/array/builder/struct.MapBuilder.html b/arrow/array/builder/struct.MapBuilder.html
index 842837abc6..bc2421c30a 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>{
diff --git a/arrow/array/builder/struct.MapFieldNames.html b/arrow/array/builder/struct.MapFieldNames.html
index 2701c2d412..fa120d9bc0 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>,
diff --git a/arrow/array/builder/struct.NullBuilder.html b/arrow/array/builder/struct.NullBuilder.html
index a818c42b9e..fad07922b8 100644
--- a/arrow/array/builder/struct.NullBuilder.html
+++ b/arrow/array/builder/struct.NullBuilder.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 `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>
diff --git a/arrow/array/builder/struct.PrimitiveBuilder.html b/arrow/array/builder/struct.PrimitiveBuilder.html
index f1e2847342..ecc658a73e 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;,
diff --git a/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html b/arrow/array/builder/struct.PrimitiveDictionaryBuilder.html
index 087c58ee50..22048c2948 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>{
diff --git a/arrow/array/builder/struct.PrimitiveRunBuilder.html b/arrow/array/builder/struct.PrimitiveRunBuilder.html
index ee2ef13105..196eb56ef8 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>{
diff --git a/arrow/array/builder/struct.StructBuilder.html b/arrow/array/builder/struct.StructBuilder.html
index d08f51aa4d..1d7adf83b9 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;,
diff --git a/arrow/array/builder/struct.UnionBuilder.html b/arrow/array/builder/struct.UnionBuilder.html
index 88b778cda4..f752488b17 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;,
diff --git a/arrow/array/builder/trait.ArrayBuilder.html b/arrow/array/builder/trait.ArrayBuilder.html
index 8b17ad4641..a8e624d7fd 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>;
diff --git a/arrow/array/builder/type.BinaryBuilder.html b/arrow/array/builder/type.BinaryBuilder.html
index 3bd264af50..47b6ceb180 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 904b456bb7..29e653f8c1 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 56d2e4c406..72ec0a4f6d 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 744e84901a..9ad4479295 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 7124b157a1..eb82e0ac33 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 67ff1d0b95..4126658cc4 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 1274390e58..c0cbcadc50 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 8f07452979..db01c7f2a9 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 c9ceae3163..f4e74d3f92 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 008d5f65bf..cf006bef3f 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 0729df140b..8da810c5e5 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 a5ae3985a4..c3a466e079 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 4dc034e01c..65fad86fc0 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 91ba7a2afb..c9593d9dd1 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 09de93392e..54482cc5c1 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 b4dea254d5..77c25f4141 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 458646ff2b..84b6da4a49 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 546cc5cf93..23928dfbed 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 45e4b6a158..03d4696547 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 eb891daba2..3f786d7ef5 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 038840af36..5045270d98 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 6cdfbc95fa..0b4c86106a 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 ac597544bf..5f3f719d49 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 bce79426bb..3b83dd668b 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 282f9b0a76..4cd2cc68cb 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 57d1698d10..d639fdfc70 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 af24ae8ae0..64eddec3f9 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 237d02d4dc..4d83657516 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 cd63405566..031aa989c2 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 1bee411c16..86a42c05f2 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 0272f1f8fe..0e91e5a08b 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 bca6f0f2fd..bb4036006a 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 0035ddc777..6fd9f25ae1 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 73061d76e6..cc6ea1129a 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 c40820a141..c3ac30a072 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 cfa44cb5f7..8622677b40 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 8712075822..0c69658021 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 349f405301..e795a6b804 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 6d474686ed..d6e4737ba3 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 0b91784c59..5b1778c50e 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 cf45efcf85..04b421deb4 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 fd483df794..1155da0fd3 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 5a15f9933f..2e73a6ba9c 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 553c2987e8..ff6ab6da77 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 b88a03380f..4e4672098a 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 6b7021bb51..b68e6f8469 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 4fd9bb627a..6b207722b9 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 3cb5a2f116..bc9bfd7d1e 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 8c6caf0f8b..df708c116f 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 b97f7cde22..c39bf58037 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 eef4bf395d..a706d73df7 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 ded267c541..5fe510ea58 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 6710ebed3e..a5c21372af 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 ba9c689174..5f8135916f 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 04bb925c90..0c5400d25b 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 747b70aea0..9e0783eb51 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 6d7d7a14b2..2e60fe1039 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 9d0cde7282..84231bcc78 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 19e611b257..5339a19d19 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 ed4c4eae6d..f7d6e57c57 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 2f12a9331f..cbae9d05e9 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 90961eff6c..4df6af0e19 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 e6d49f8749..c438a99d7b 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 4ad09391e5..431edbef87 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 724c5f2498..ad4c5188a6 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 57ef323318..71423a85c5 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 b0a6398e23..fa29117b84 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 0ce70f1322..8811f3e475 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 b37032eeed..038edbeae6 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 d268a9a745..0f6a5302f2 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 f31d5e4130..d1f9758d17 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 433d01e0fc..662ea89b17 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 d66edb7491..696951718b 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 f48fdd3f38..2ce57ff1c9 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 491a7c0555..8a2a3a2cdb 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 7383e77e13..760e6a7744 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 826b618ec5..fb01e5fe96 100644
--- a/arrow/array/cast/fn.as_boolean_array.html
+++ b/arrow/array/cast/fn.as_boolean_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 `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>
diff --git a/arrow/array/cast/fn.as_decimal_array.html b/arrow/array/cast/fn.as_decimal_array.html
index 2fdbe3ebf9..3adeba3be7 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 e29a4afd01..25759fed39 100644
--- a/arrow/array/cast/fn.as_dictionary_array.html
+++ b/arrow/array/cast/fn.as_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="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>
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 7ba72f98e2..c1c1f960fd 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 2ae1cd749d..fa81a76831 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 8a56b3fca5..447c99f00c 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 8d9d040c0d..b6c9ce823d 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 89db55b50c..7711aed714 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 f331d740af..bfa651cff2 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 a41da0e326..6862892a39 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 ace5945ee2..867fb4d797 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 94fae14456..fe7e270f20 100644
--- a/arrow/array/cast/fn.as_primitive_array.html
+++ b/arrow/array/cast/fn.as_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="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>
diff --git a/arrow/array/cast/fn.as_run_array.html b/arrow/array/cast/fn.as_run_array.html
index 1369f866d7..165ccc20e9 100644
--- a/arrow/array/cast/fn.as_run_array.html
+++ b/arrow/array/cast/fn.as_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="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>
diff --git a/arrow/array/cast/fn.as_string_array.html b/arrow/array/cast/fn.as_string_array.html
index f828722d3d..edb3133891 100644
--- a/arrow/array/cast/fn.as_string_array.html
+++ b/arrow/array/cast/fn.as_string_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 `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> [...]
diff --git a/arrow/array/cast/fn.as_struct_array.html b/arrow/array/cast/fn.as_struct_array.html
index 6ef1105267..84dabf8339 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 b6cdd5b734..835897b7af 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 d5a864b5b8..3538874221 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>
 
diff --git a/arrow/array/cast/index.html b/arrow/array/cast/index.html
index 558ad8cba7..c4c305b03f 100644
--- a/arrow/array/cast/index.html
+++ b/arrow/array/cast/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 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 [...]
 <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 [...]
diff --git a/arrow/array/cast/trait.AsArray.html b/arrow/array/cast/trait.AsArray.html
index 6d2c20dd54..9cc58b0d1b 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 757a4f04c0..9b2dd1390b 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>,
diff --git a/arrow/array/enum.Capacities.html b/arrow/array/enum.Capacities.html
index b2d16b8604..f4a708ddac 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;),
diff --git a/arrow/array/ffi/fn.export_array_into_raw.html b/arrow/array/ffi/fn.export_array_into_raw.html
index ab9f3f1689..3cc7228138 100644
--- a/arrow/array/ffi/fn.export_array_into_raw.html
+++ b/arrow/array/ffi/fn.export_array_into_raw.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="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>,
diff --git a/arrow/array/ffi/index.html b/arrow/array/ffi/index.html
index dd94df7946..9af2279e43 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
diff --git a/arrow/array/fn.as_boolean_array.html b/arrow/array/fn.as_boolean_array.html
index 1d6cea6cbc..eae5e2af85 100644
--- a/arrow/array/fn.as_boolean_array.html
+++ b/arrow/array/fn.as_boolean_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 `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>
diff --git a/arrow/array/fn.as_decimal_array.html b/arrow/array/fn.as_decimal_array.html
index 7ae771a8c7..55f6c3973a 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 8c2392c712..a5bbd003da 100644
--- a/arrow/array/fn.as_dictionary_array.html
+++ b/arrow/array/fn.as_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="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>
diff --git a/arrow/array/fn.as_fixed_size_list_array.html b/arrow/array/fn.as_fixed_size_list_array.html
index c4dc6fbb61..a4eb52b324 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 8bd216c8f0..2269b9f283 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 58ae72b882..86c812405b 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 0c125d6581..bdfb23bcbc 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 ee9b205630..fda30cc6d0 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 eeafc38ff3..1cbbafadd9 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 44bd9646ba..2528d28a14 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 32a18ee8b4..0438d6b9c5 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 28518c3d6e..3a3c0386ba 100644
--- a/arrow/array/fn.as_primitive_array.html
+++ b/arrow/array/fn.as_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="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>
diff --git a/arrow/array/fn.as_run_array.html b/arrow/array/fn.as_run_array.html
index bf559a71b1..82b6fbfbbd 100644
--- a/arrow/array/fn.as_run_array.html
+++ b/arrow/array/fn.as_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="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>
diff --git a/arrow/array/fn.as_string_array.html b/arrow/array/fn.as_string_array.html
index f21692a2aa..93f3d48938 100644
--- a/arrow/array/fn.as_string_array.html
+++ b/arrow/array/fn.as_string_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 `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 [...]
diff --git a/arrow/array/fn.as_struct_array.html b/arrow/array/fn.as_struct_array.html
index 4633d44d00..2872505062 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 c36e975518..566c0f41d0 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 73127154c7..46193377c9 100644
--- a/arrow/array/fn.build_compare.html
+++ b/arrow/array/fn.build_compare.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 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>
diff --git a/arrow/array/fn.downcast_array.html b/arrow/array/fn.downcast_array.html
index d9354a4473..878d4593d9 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>
 
diff --git a/arrow/array/fn.export_array_into_raw.html b/arrow/array/fn.export_array_into_raw.html
index 8830ad3bf3..add22716db 100644
--- a/arrow/array/fn.export_array_into_raw.html
+++ b/arrow/array/fn.export_array_into_raw.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="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>,
diff --git a/arrow/array/fn.layout.html b/arrow/array/fn.layout.html
index 772f0a0021..9028ba360d 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 d1033ed024..2ad8877258 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 3b6bbf5f3d..3b60886b39 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 247e89a7bb..00c7aaa62a 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 b97c283e66..f9740be748 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 911e871cb8..acc8de758f 100644
--- a/arrow/array/index.html
+++ b/arrow/array/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="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 [...]
diff --git a/arrow/array/iterator/index.html b/arrow/array/iterator/index.html
index 85f5fca9ac..014708cf11 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
diff --git a/arrow/array/iterator/struct.ArrayIter.html b/arrow/array/iterator/struct.ArrayIter.html
index d941a5253d..5c3c3704da 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,
diff --git a/arrow/array/iterator/type.BooleanIter.html b/arrow/array/iterator/type.BooleanIter.html
index 24840d2be2..6c588cf5b6 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 754d459769..fbff002824 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 91dce1d312..79b8272f3b 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 fbe1d16196..808e2d5cdd 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 7158bbc627..d11be52296 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 8436ef2b79..c496dfbe72 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 e7161cb965..12651b36e3 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 78ac569dd2..cc6639e7f0 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 51d6060b21..a724dd6fd2 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 633410e9c6..d310c6d43a 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 3d39307456..5d9be60b91 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 93fd0cd6cb..69c90a63e5 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 ea6014df1d..7b9731ed8d 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 43bb94521b..a58561de61 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 59a030e892..809947eb81 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 c690e8388e..abbb7e2772 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 4319ee90bc..b142427b3e 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.
 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 a6eec20601..9fbdf408fc 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>,
diff --git a/arrow/array/struct.ArrayData.html b/arrow/array/struct.ArrayData.html
index b7dbe7c6dd..60c764117f 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>,
@@ -178,19 +178,19 @@ 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-3" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-3" 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#374">source</a><a href="#method.from-1" 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-20" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#571">source</a><a href="#method.from-20" 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-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-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#374">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="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-12" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-12" 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-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#259">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
-    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-4" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#619">source</a><a href="#method.from-4" 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-7" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-7" 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-15" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#381">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="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#978">source</a><a href="#method.from-2" 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-21" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#286">source</a><a href="#method.from-21" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-18" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-18" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="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-12" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#259">source</a><a href="#method.from-12" 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-11" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#619">source</a><a href="#method.from-11" 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-10" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-10" 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-6" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#978">source</a><a href="#method.from-6" 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-16" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#286">source</a><a href="#method.from-16" 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 [...]
diff --git a/arrow/array/struct.ArrayDataBuilder.html b/arrow/array/struct.ArrayDataBuilder.html
index e51afbb4d8..5daf852dbe 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>,
diff --git a/arrow/array/struct.ArrayIter.html b/arrow/array/struct.ArrayIter.html
index b2b221e3fe..fac6211930 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,
diff --git a/arrow/array/struct.BooleanArray.html b/arrow/array/struct.BooleanArray.html
index c29a0d59c0..fad931bd9c 100644
--- a/arrow/array/struct.BooleanArray.html
+++ b/arrow/array/struct.BooleanArray.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 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;,
@@ -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= [...]
diff --git a/arrow/array/struct.BooleanBufferBuilder.html b/arrow/array/struct.BooleanBufferBuilder.html
index 6da38ec163..e9be104454 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>,
diff --git a/arrow/array/struct.BooleanBuilder.html b/arrow/array/struct.BooleanBuilder.html
index 0b8d0f23ae..84df5fba4d 100644
--- a/arrow/array/struct.BooleanBuilder.html
+++ b/arrow/array/struct.BooleanBuilder.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 `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>,
diff --git a/arrow/array/struct.BufferBuilder.html b/arrow/array/struct.BufferBuilder.html
index 49458a74a5..a105903fa3 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>,
@@ -151,9 +151,9 @@ 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.default" class="method trait-impl"><a class="src rightside" href="../../src/arrow_buffer/builder/mod.rs.html#362">source</a><a href="#method.default" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.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.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-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/immutable.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-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" class="method trait-impl"><a class="src rightside" href="../../src/arrow_buffer/builder/mod.rs.html#376">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ [...]
+    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/immutable.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" class="method trait-impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#164">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
+    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_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://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'>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 [...]
diff --git a/arrow/array/struct.DataTypeLayout.html b/arrow/array/struct.DataTypeLayout.html
index 82b2f0602f..64109435a6 100644
--- a/arrow/array/struct.DataTypeLayout.html
+++ b/arrow/array/struct.DataTypeLayout.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 data type"><title>DataTypeLayout 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="Layout specification for a data type"><title>DataTypeLayout 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 [...]
     pub buffers: <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="enum.BufferSpec.html" title="enum arrow::array::BufferSpec">BufferSpec</a>&gt;,
     pub can_contain_null_mask: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,
diff --git a/arrow/array/struct.DictionaryArray.html b/arrow/array/struct.DictionaryArray.html
index a005585c6e..cad98f7cc1 100644
--- a/arrow/array/struct.DictionaryArray.html
+++ b/arrow/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 - Rust</title><link 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 dictionary encoded values"><title>DictionaryArray 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 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><div id [...]
     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>,
@@ -182,7 +182,7 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
 </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::arra [...]
     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">fn <a h [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of strings.</p>
-<h4 id="example-1"><a href="#example-1">Example:</a></h4>
+<h4 id="example-2"><a href="#example-2">Example:</a></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>];
@@ -191,10 +191,10 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
     <span class="string">"DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  1,\n  2,\n] values: StringArray\n[\n  \"a\",\n  \"b\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#672">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct"  [...]
+</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="stru [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,</div></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.fr [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of optional strings.</p>
-<h4 id="example-2"><a href="#example-2">Example:</a></h4>
+<h4 id="example-1"><a href="#example-1">Example:</a></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>];
@@ -206,7 +206,7 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
     <span class="string">"DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  null,\n  1,\n] values: StringArray\n[\n  \"a\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#648">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="stru [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#648">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct"  [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
     K: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#468">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc. [...]
 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= [...]
diff --git a/arrow/array/struct.FixedSizeBinaryArray.html b/arrow/array/struct.FixedSizeBinaryArray.html
index 17251753b8..d5f2c0b7c4 100644
--- a/arrow/array/struct.FixedSizeBinaryArray.html
+++ b/arrow/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 - Rust</title><link 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="An array of fixed size binary arrays"><title>FixedSizeBinaryArray 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 [...]
     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>,
@@ -133,8 +133,8 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
 ) -&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 <code>i</code [...]
     &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 <code>i</code [...]
-</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="struc [...]
+) -&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 <code>i</code [...]
+</div><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/fixed_size_binary_array.rs.html#502">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(v: <a class="struct" href="struct.FixedSizeListArray.html" title="struc [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#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 [...]
diff --git a/arrow/array/struct.FixedSizeBinaryBuilder.html b/arrow/array/struct.FixedSizeBinaryBuilder.html
index b59c73174c..3a380cf29a 100644
--- a/arrow/array/struct.FixedSizeBinaryBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `FixedSizeBinaryArray`"><title>FixedSizeBinaryBuilder 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 [...]
     values_builder: <a class="struct" href="builder/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>,
diff --git a/arrow/array/struct.FixedSizeListArray.html b/arrow/array/struct.FixedSizeListArray.html
index 19015b4c73..0bf6aed36c 100644
--- a/arrow/array/struct.FixedSizeListArray.html
+++ b/arrow/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 - 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 array of [fixed length lists], similar to JSON arrays (e.g. `[&quot;A&quot;, &quot;B&quot;]`)."><title>FixedSizeListArray 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 [...]
     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;,
@@ -131,15 +131,15 @@ This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read
 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" class [...]
 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 class=" [...]
-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  [...]
+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.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 h [...]
+) -&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</code> <a h [...]
     &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 href="tra [...]
-</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="struc [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" 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.org/nigh [...]
+) -&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 href="tra [...]
+</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="struc [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ [...]
 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 [...]
diff --git a/arrow/array/struct.FixedSizeListBuilder.html b/arrow/array/struct.FixedSizeListBuilder.html
index 48dec1917d..5606414019 100644
--- a/arrow/array/struct.FixedSizeListBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `FixedSizeListArray`"><title>FixedSizeListBuilder 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 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><div id [...]
     T: <a class="trait" href="builder/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>,
diff --git a/arrow/array/struct.GenericByteArray.html b/arrow/array/struct.GenericByteArray.html
index fd739ece0c..0bba64913c 100644
--- a/arrow/array/struct.GenericByteArray.html
+++ b/arrow/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 - Rust</title><link 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 variable length byte arrays"><title>GenericByteArray 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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.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>,
@@ -148,28 +148,28 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
 ) -&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</code> < [...]
     T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.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.org/n [...]
     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.org/nigh [...]
-    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from-3" 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" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#79">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nig [...]
+    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#491">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ni [...]
+    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#79">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org [...]
     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="impl-F [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-4" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-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-9" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#124">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
     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="impl-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-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org [...]
+    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#521">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-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-7" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org [...]
     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="impl-F [...]
-    T: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-7" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly [...]
-    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/binary_array.rs.html#110">source</a><a href="#method.from-1" 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-10" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#91">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
-    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/binary_array.rs.html#104">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
+    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-11" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-11" 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-6" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#110">source</a><a href="#method.from-6" 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-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#91">source</a><a href="#method.from-5" 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-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#104">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
     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="impl-F [...]
-    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#85">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
-    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#97">source</a><a href="#method.from-6" 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-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-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-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-lang.org [...]
     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="impl-F [...]
-    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#103">source</a><a href="#method.from-9" 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-10" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#103">source</a><a href="#method.from-10" 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>,
     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 class [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &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 [...]
diff --git a/arrow/array/struct.GenericByteBuilder.html b/arrow/array/struct.GenericByteBuilder.html
index cd71afe7fd..33ab3e9e80 100644
--- a/arrow/array/struct.GenericByteBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `GenericByteArray`"><title>GenericByteBuilder 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.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</div>{
     value_builder: <a class="struct" href="builder/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/struct.GenericByteDictionaryBuilder.html b/arrow/array/struct.GenericByteDictionaryBuilder.html
index f440553117..475cc745a4 100644
--- a/arrow/array/struct.GenericByteDictionaryBuilder.html
+++ b/arrow/array/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 - Rust</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="Builder for `DictionaryArray` of `GenericByteArray`"><title>GenericByteDictionaryBuilder 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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>{
diff --git a/arrow/array/struct.GenericByteRunBuilder.html b/arrow/array/struct.GenericByteRunBuilder.html
index b72532f8ff..d653079049 100644
--- a/arrow/array/struct.GenericByteRunBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `RunArray` of `GenericByteArray`"><title>GenericByteRunBuilder 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" 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 id [...]
     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>{
diff --git a/arrow/array/struct.GenericListArray.html b/arrow/array/struct.GenericListArray.html
index 701fee4592..5e838980af 100644
--- a/arrow/array/struct.GenericListArray.html
+++ b/arrow/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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5 [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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>,
@@ -139,13 +139,13 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
 ) -&gt; &lt;&amp;'a <a class="struct" href="struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt; as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i [...]
     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.org/ni [...]
     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/nightl [...]
-    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#374">source</a><a href="#method.from-2" 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" 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.org/nigh [...]
-    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#381">source</a><a href="#method.from-5" 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/string_array.rs.html#71">source</a><a href="#method.from-3" 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-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#374">source</a><a href="#method.from-1" 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-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#394">source</a><a href="#method.from-5" 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#381">source</a><a href="#method.from-3" 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-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#71">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org [...]
     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="impl-F [...]
-    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-4" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly [...]
+    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-4" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#116">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly [...]
     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/core/cm [...]
 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 [...]
diff --git a/arrow/array/struct.GenericListBuilder.html b/arrow/array/struct.GenericListBuilder.html
index 4e5e7ec170..c326d822c7 100644
--- a/arrow/array/struct.GenericListBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `GenericListArray`"><title>GenericListBuilder 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 [...]
     OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,
     T: <a class="trait" href="builder/trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div>{
diff --git a/arrow/array/struct.MapArray.html b/arrow/array/struct.MapArray.html
index 3c2eb0338e..6abcfbfa66 100644
--- a/arrow/array/struct.MapArray.html
+++ b/arrow/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 - Rust</title><link 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.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="An array of key-value maps"><title>MapArray 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="../../static.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 id [...]
     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;,
@@ -74,7 +74,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.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.ArrayAccessor.html# [...]
+) -&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.ArrayAccessor.html# [...]
 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 [...]
diff --git a/arrow/array/struct.MapBuilder.html b/arrow/array/struct.MapBuilder.html
index f22b15f3d5..f38b1ae994 100644
--- a/arrow/array/struct.MapBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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.fil [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link 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.fil [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     K: <a class="trait" href="builder/trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,
     V: <a class="trait" href="builder/trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>,</div>{
diff --git a/arrow/array/struct.MapFieldNames.html b/arrow/array/struct.MapFieldNames.html
index 3c7abf7a08..5c9d295684 100644
--- a/arrow/array/struct.MapFieldNames.html
+++ b/arrow/array/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 - Rust</title><link 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="The `Field` names for a `MapArray`"><title>MapFieldNames 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 [...]
     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>,
diff --git a/arrow/array/struct.MutableArrayData.html b/arrow/array/struct.MutableArrayData.html
index 9d13941761..25c4482ba6 100644
--- a/arrow/array/struct.MutableArrayData.html
+++ b/arrow/array/struct.MutableArrayData.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="Struct to efficiently and interactively create an ArrayData from an existing ArrayData by copying chunks."><title>MutableArrayData 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="Struct to efficiently and interactively create an ArrayData from an existing ArrayData by copying chunks."><title>MutableArrayData 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 [...]
     arrays: <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 <a class="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;,
     data: <a class="struct" href="../../arrow_data/transform/struct._MutableArrayData.html" title="struct arrow_data::transform::_MutableArrayData">_MutableArrayData</a>&lt;'a&gt;,
diff --git a/arrow/array/struct.NativeAdapter.html b/arrow/array/struct.NativeAdapter.html
index c53b063521..9b5797b60a 100644
--- a/arrow/array/struct.NativeAdapter.html
+++ b/arrow/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 - Rust</title><link 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="An optional primitive value"><title>NativeAdapter 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 [...]
     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,8 +11,8 @@ 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#1167">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-header">impl& [...]
     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><div clas [...]
-    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-12" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1206">source</a><a href="#method.from-12" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
-    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#1200">source</a><a href="#method.from-3" 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="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-13" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1206">source</a><a href="#method.from-13" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
+    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#1200">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="htt [...]
     &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">RefUn [...]
     &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><section id=" [...]
     &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">UnwindSafe< [...]
diff --git a/arrow/array/struct.NullArray.html b/arrow/array/struct.NullArray.html
index 2f9e26838a..1c0f138953 100644
--- a/arrow/array/struct.NullArray.html
+++ b/arrow/array/struct.NullArray.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 null values"><title>NullArray 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="../../static.fil [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link 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.fil [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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>
diff --git a/arrow/array/struct.NullBuilder.html b/arrow/array/struct.NullBuilder.html
index a166878a4a..54da93f6f4 100644
--- a/arrow/array/struct.NullBuilder.html
+++ b/arrow/array/struct.NullBuilder.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 `NullArray`"><title>NullBuilder 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="../../static.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 `NullArray`"><title>NullBuilder 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="../../static.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 id [...]
     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>
diff --git a/arrow/array/struct.PrimitiveArray.html b/arrow/array/struct.PrimitiveArray.html
index 6404bd5303..40ce2860df 100644
--- a/arrow/array/struct.PrimitiveArray.html
+++ b/arrow/array/struct.PrimitiveArray.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 primitive values"><title>PrimitiveArray 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="An array of primitive values"><title>PrimitiveArray 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.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>,
@@ -250,126 +250,126 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
     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="https: [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1094">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://d [...]
     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-30" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-30" 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.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#978">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="http [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-55" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1377">source</a><a href="#method.from-55" 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.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-22" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#978">source</a><a href="#method.from-22" class="anchor">§</a><h4 class="code-header">fn <a href="ht [...]
     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.html#associa [...]
-) -&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+ArrowPrimitiveTy [...]
+) -&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+ArrowPrimitiveTy [...]
     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.html#associa [...]
-) -&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+ArrowPrimiti [...]
+) -&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+ArrowPrimiti [...]
     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.ArrowPrimitiveType. [...]
-) -&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%3CDecimal256Type+as+ [...]
+) -&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%3CDecimal256Type+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;&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.ArrowPrimitiveType. [...]
-) -&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%3CDurationMicrosecon [...]
+) -&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%3CDurationMicrosecon [...]
     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="../datatype [...]
-) -&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-From%3C [...]
+) -&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-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.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="../datatype [...]
-) -&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-From%3C [...]
+) -&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-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.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="../datatypes/t [...]
-) -&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%3CVec [...]
+) -&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%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.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/trait.ArrowPr [...]
-) -&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%3CFloat1 [...]
+) -&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%3CFloat1 [...]
     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.html#asso [...]
-) -&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+ArrowPrimiti [...]
+) -&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+ArrowPrimiti [...]
     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.html#asso [...]
-) -&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+ArrowPrimiti [...]
+) -&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+ArrowPrimiti [...]
     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.html#asso [...]
-) -&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+ArrowPrimitive [...]
+) -&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+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.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#associated [...]
-) -&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+ArrowPrimitiveType%3 [...]
+) -&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+ArrowPrimitiveType%3 [...]
     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#associated [...]
-) -&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+ArrowPrimitiveType%3 [...]
+) -&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+ArrowPrimitiveType%3 [...]
     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#associated [...]
-) -&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+ArrowPrimitiveType%3E [...]
+) -&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+ArrowPrimitiveType%3E [...]
     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#associatedtyp [...]
-) -&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+ArrowPrimitiv [...]
+) -&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+ArrowPrimitiv [...]
     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/trait.Arro [...]
-) -&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%3CInt [...]
+) -&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%3CInt [...]
     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="../datat [...]
-) -&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="impl-From [...]
+) -&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="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.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="../datatypes/trai [...]
-) -&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%3CVec%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%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.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="../datatypes/trai [...]
-) -&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%3CVec%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%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.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.ArrowPrimitiv [...]
 ) -&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%3CTime64Micros [...]
     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="../datatypes/trai [...]
-) -&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%3CVec%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%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.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="../datatypes/trait.A [...]
-) -&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%3C%3C [...]
+) -&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%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.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="../datat [...]
-) -&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="impl-From [...]
+) -&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="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.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="../datat [...]
-) -&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="impl-From [...]
+) -&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="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.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="../datatype [...]
-) -&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-From%3C [...]
+) -&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-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.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/trait.Arro [...]
-) -&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%3CUIn [...]
+) -&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%3CUIn [...]
     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.html#associa [...]
-) -&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+ArrowPrimitiveTy [...]
+) -&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+ArrowPrimitiveTy [...]
     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.html#associa [...]
-) -&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+ArrowPrimitiveTy [...]
+) -&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+ArrowPrimitiveTy [...]
     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.html#associa [...]
-) -&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+ArrowPrimitiveTyp [...]
+) -&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+ArrowPrimitiveTyp [...]
     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#associated [...]
-) -&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+ArrowPrimi [...]
+) -&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+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;<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::datatyp [...]
-) -&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+ArrowPr [...]
+) -&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+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;<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::datatyp [...]
-) -&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+as+Arr [...]
+) -&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+as+Arr [...]
     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="trait ar [...]
-) -&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%3CDecimal25 [...]
+) -&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%3CDecimal25 [...]
     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="trait ar [...]
-) -&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%3CDurationM [...]
+) -&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%3CDurationM [...]
     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.ArrowPrimitiv [...]
-) -&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-From%3C [...]
+) -&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-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.DurationMillisecondType.html" title="struct arrow::datatypes::DurationMillisecondType">DurationMillisecondType</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.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-From%3C [...]
+) -&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-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.DurationNanosecondType.html" title="struct arrow::datatypes::DurationNanosecondType">DurationNanosecondType</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.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%3CVec [...]
+) -&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%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.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</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.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%3COption%3C [...]
+) -&gt; <a class="struct" href="struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;<a class="struct" href="../datatypes/struct.DurationSecondType.html" title="struct arrow::datatypes::DurationSecondType">DurationSecondType</a>&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CVec%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.Float16Type.html" title="struct arrow::datatypes::Float16Type">Float16Type</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.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+as+Arr [...]
+) -&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+as+Arr [...]
     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::data [...]
-) -&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+as+Arr [...]
+) -&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+as+Arr [...]
     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::data [...]
-) -&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+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+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.Int16Type.html" title="struct arrow::datatypes::Int16Type">Int16Type</a> as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes: [...]
-) -&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+ArrowPrimit [...]
+) -&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+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;<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::datatypes: [...]
-) -&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+ArrowPrimit [...]
+) -&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+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;<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::datatypes: [...]
-) -&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+ArrowPrimiti [...]
+) -&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+ArrowPrimiti [...]
     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::datatypes::Ar [...]
-) -&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+as+Arro [...]
+) -&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+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.IntervalDayTimeType.html" title="struct arrow::datatypes::IntervalDayTimeType">IntervalDayTimeType</a> as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html"  [...]
-) -&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%3COption [...]
+) -&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%3COption [...]
     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.ArrowPrimi [...]
-) -&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="impl-From [...]
+) -&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="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.IntervalYearMonthType.html" title="struct arrow::datatypes::IntervalYearMonthType">IntervalYearMonthType</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.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%3CVec%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%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.Time32MillisecondType.html" title="struct arrow::datatypes::Time32MillisecondType">Time32MillisecondType</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.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%3CVec%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%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.Time32SecondType.html" title="struct arrow::datatypes::Time32SecondType">Time32SecondType</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.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%3CTim [...]
+) -&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%3CTim [...]
     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.ArrowPrimitiveType. [...]
-) -&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%3CVec%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%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.Time64NanosecondType.html" title="struct arrow::datatypes::Time64NanosecondType">Time64NanosecondType</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.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%3COpt [...]
+) -&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%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.TimestampMicrosecondType.html" title="struct arrow::datatypes::TimestampMicrosecondType">TimestampMicrosecondType</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.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="impl-From [...]
+) -&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="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.TimestampMillisecondType.html" title="struct arrow::datatypes::TimestampMillisecondType">TimestampMillisecondType</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.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="impl-From [...]
+) -&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="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.TimestampNanosecondType.html" title="struct arrow::datatypes::TimestampNanosecondType">TimestampNanosecondType</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.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-From%3C [...]
+) -&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-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.TimestampSecondType.html" title="struct arrow::datatypes::TimestampSecondType">TimestampSecondType</a> as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html"  [...]
-) -&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%3COption [...]
+) -&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%3COption [...]
     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::datatyp [...]
-) -&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+ArrowPr [...]
+) -&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+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;<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::datatyp [...]
-) -&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+ArrowPr [...]
+) -&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+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;<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::datatyp [...]
-) -&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+ArrowPri [...]
+) -&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+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;<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::datatypes: [...]
 ) -&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%3CT%3E"  [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,
diff --git a/arrow/array/struct.PrimitiveBuilder.html b/arrow/array/struct.PrimitiveBuilder.html
index 5619e0038e..427998c6a1 100644
--- a/arrow/array/struct.PrimitiveBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `PrimitiveArray`"><title>PrimitiveBuilder 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.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div>{
     values_builder: <a class="struct" href="builder/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;,
diff --git a/arrow/array/struct.PrimitiveDictionaryBuilder.html b/arrow/array/struct.PrimitiveDictionaryBuilder.html
index e83c67c1bf..703c82318a 100644
--- a/arrow/array/struct.PrimitiveDictionaryBuilder.html
+++ b/arrow/array/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 - Rust</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="Builder for `DictionaryArray` of `PrimitiveArray`"><title>PrimitiveDictionaryBuilder 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="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 id [...]
     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>{
diff --git a/arrow/array/struct.PrimitiveRunBuilder.html b/arrow/array/struct.PrimitiveRunBuilder.html
index 6cd2b38783..7c341ef720 100644
--- a/arrow/array/struct.PrimitiveRunBuilder.html
+++ b/arrow/array/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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><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="Builder for `RunArray` of `PrimitiveArray`"><title>PrimitiveRunBuilder 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" 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 [...]
     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>{
diff --git a/arrow/array/struct.RecordBatch.html b/arrow/array/struct.RecordBatch.html
index f3e97662de..708d84500f 100644
--- a/arrow/array/struct.RecordBatch.html
+++ b/arrow/array/struct.RecordBatch.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 two-dimensional batch of column-oriented data with a defined schema."><title>RecordBatch 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" 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 two-dimensional batch of column-oriented data with a defined schema."><title>RecordBatch 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" 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 id [...]
     schema: <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.Schema.html" title="struct arrow::datatypes::Schema">Schema</a>&gt;,
     columns: <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;,
diff --git a/arrow/array/struct.RecordBatchIterator.html b/arrow/array/struct.RecordBatchIterator.html
index d06ec59639..9591fb3308 100644
--- a/arrow/array/struct.RecordBatchIterator.html
+++ b/arrow/array/struct.RecordBatchIterator.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="Generic implementation of RecordBatchReader that wraps an iterator."><title>RecordBatchIterator 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 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Generic implementation of RecordBatchReader that wraps an iterator."><title>RecordBatchIterator 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a>, <a class="enum" href="../error/ [...]
     inner: &lt;I as <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>&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associatedtype.IntoIter" title="type core::iter::traits::collect::IntoIterator::IntoIter">IntoIter</a>,
diff --git a/arrow/array/struct.RecordBatchOptions.html b/arrow/array/struct.RecordBatchOptions.html
index 9b0709ceaa..b859cb3f29 100644
--- a/arrow/array/struct.RecordBatchOptions.html
+++ b/arrow/array/struct.RecordBatchOptions.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="Options that control the behaviour used when creating a `RecordBatch`."><title>RecordBatchOptions 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="Options that control the behaviour used when creating a `RecordBatch`."><title>RecordBatchOptions 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 [...]
     pub match_field_names: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,
     pub row_count: <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;,
diff --git a/arrow/array/struct.RunArray.html b/arrow/array/struct.RunArray.html
index 3eb66cdef5..6eb972c118 100644
--- a/arrow/array/struct.RunArray.html
+++ b/arrow/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 - Rust</title><link 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 run-end encoded values"><title>RunArray 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 [...]
     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>,
@@ -84,7 +84,7 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
     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 [...]
     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.rust-la [...]
     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"><a href="#example">Example:</a></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>];
@@ -93,10 +93,10 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
     <span class="string">"RunArray {run_ends: [2, 3, 4], values: StringArray\n[\n  \"a\",\n  \"b\",\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#445">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" hre [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#445">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="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.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-1"><a href="#example-1">Example:</a></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>];
@@ -108,7 +108,7 @@ opposite of <a href="trait.Array.html#method.is_null" title="method arrow_array:
     <span class="string">"RunArray {run_ends: [2, 3, 5], values: StringArray\n[\n  \"a\",\n  null,\n  \"c\",\n]}\n"</span>,
     <span class="macro">format!</span>(<span class="string">"{:?}"</span>, array)
 );</code></pre></div>
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#418">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" href="s [...]
+</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#418">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" hre [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;&gt;,</div></h4></section></summary><div class='docblock' [...]
     &lt;R as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</div></h3></section><section id=" [...]
     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 [...]
diff --git a/arrow/array/struct.Scalar.html b/arrow/array/struct.Scalar.html
index 28a0e2b93b..0831baaa86 100644
--- a/arrow/array/struct.Scalar.html
+++ b/arrow/array/struct.Scalar.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 wrapper around a single value `Array` that implements `Datum` and indicates compute kernels should treat this array as a scalar value (a single value)."><title>Scalar in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/Sour [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A wrapper around a single value `Array` that implements `Datum` and indicates compute kernels should treat this array as a scalar value (a single value)."><title>Scalar in arrow::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/Sour [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="where">where
     T: <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a></span>;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A wrapper around a single value <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a> that implements
diff --git a/arrow/array/struct.StructArray.html b/arrow/array/struct.StructArray.html
index 8c95071f46..dfe9a7376c 100644
--- a/arrow/array/struct.StructArray.html
+++ b/arrow/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 - Rust</title><link 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.files [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link 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.files [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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>,
@@ -96,7 +96,7 @@ This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read
 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="fn">get [...]
 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 class=" [...]
-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  [...]
+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  [...]
 <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>
diff --git a/arrow/array/struct.StructBuilder.html b/arrow/array/struct.StructBuilder.html
index f5c96d6c42..47f100a9c7 100644
--- a/arrow/array/struct.StructBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `StructArray`"><title>StructBuilder 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 [...]
     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="builder/trait.ArrayBuilder.html" title="trait arrow::array::builder::ArrayBuilder">ArrayBuilder</a>&gt;&gt;,
diff --git a/arrow/array/struct.TypedDictionaryArray.html b/arrow/array/struct.TypedDictionaryArray.html
index aa776a1af0..c786d78262 100644
--- a/arrow/array/struct.TypedDictionaryArray.html
+++ b/arrow/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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><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="A `DictionaryArray` typed on its child values array"><title>TypedDictionaryArray 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/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 [...]
     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;,
diff --git a/arrow/array/struct.TypedRunArray.html b/arrow/array/struct.TypedRunArray.html
index 60c1a0f540..c7c3fd19e5 100644
--- a/arrow/array/struct.TypedRunArray.html
+++ b/arrow/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 - Rust</title><link 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="A `RunArray` typed typed on its child values array"><title>TypedRunArray 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" 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 id [...]
     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;,
diff --git a/arrow/array/struct.UnionArray.html b/arrow/array/struct.UnionArray.html
index 865213ad8e..7dd64a778f 100644
--- a/arrow/array/struct.UnionArray.html
+++ b/arrow/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 - Rust</title><link 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 values of varying types"><title>UnionArray 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>,
     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;,
diff --git a/arrow/array/struct.UnionBuilder.html b/arrow/array/struct.UnionBuilder.html
index 99e7041b48..e1a15efd27 100644
--- a/arrow/array/struct.UnionBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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;,
diff --git a/arrow/array/temporal_conversions/constant.EPOCH_DAYS_FROM_CE.html b/arrow/array/temporal_conversions/constant.EPOCH_DAYS_FROM_CE.html
index b88916408f..041feefedd 100644
--- a/arrow/array/temporal_conversions/constant.EPOCH_DAYS_FROM_CE.html
+++ b/arrow/array/temporal_conversions/constant.EPOCH_DAYS_FROM_CE.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="Number of days between 0001-01-01 and 1970-01-01"><title>EPOCH_DAYS_FROM_CE in arrow::array::temporal_conversions - 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="Number of days between 0001-01-01 and 1970-01-01"><title>EPOCH_DAYS_FROM_CE in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.MICROSECONDS.html b/arrow/array/temporal_conversions/constant.MICROSECONDS.html
index 14279799f9..2b782bc438 100644
--- a/arrow/array/temporal_conversions/constant.MICROSECONDS.html
+++ b/arrow/array/temporal_conversions/constant.MICROSECONDS.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="Number of microseconds in a second"><title>MICROSECONDS in arrow::array::temporal_conversions - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><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="Number of microseconds in a second"><title>MICROSECONDS in arrow::array::temporal_conversions - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><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></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.MICROSECONDS_IN_DAY.html b/arrow/array/temporal_conversions/constant.MICROSECONDS_IN_DAY.html
index aaa2b43645..baf67a4515 100644
--- a/arrow/array/temporal_conversions/constant.MICROSECONDS_IN_DAY.html
+++ b/arrow/array/temporal_conversions/constant.MICROSECONDS_IN_DAY.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="Number of microseconds in a day"><title>MICROSECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</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="Number of microseconds in a day"><title>MICROSECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.MILLISECONDS.html b/arrow/array/temporal_conversions/constant.MILLISECONDS.html
index 44d8a85b09..11ec9a4ee6 100644
--- a/arrow/array/temporal_conversions/constant.MILLISECONDS.html
+++ b/arrow/array/temporal_conversions/constant.MILLISECONDS.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="Number of milliseconds in a second"><title>MILLISECONDS in arrow::array::temporal_conversions - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><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="Number of milliseconds in a second"><title>MILLISECONDS in arrow::array::temporal_conversions - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><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></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.MILLISECONDS_IN_DAY.html b/arrow/array/temporal_conversions/constant.MILLISECONDS_IN_DAY.html
index 50eaa881fa..f94f8b47de 100644
--- a/arrow/array/temporal_conversions/constant.MILLISECONDS_IN_DAY.html
+++ b/arrow/array/temporal_conversions/constant.MILLISECONDS_IN_DAY.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="Number of milliseconds in a day"><title>MILLISECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</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="Number of milliseconds in a day"><title>MILLISECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.NANOSECONDS.html b/arrow/array/temporal_conversions/constant.NANOSECONDS.html
index 326adbdb3c..7ffd42a229 100644
--- a/arrow/array/temporal_conversions/constant.NANOSECONDS.html
+++ b/arrow/array/temporal_conversions/constant.NANOSECONDS.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="Number of nanoseconds in a second"><title>NANOSECONDS in arrow::array::temporal_conversions - Rust</title><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="Number of nanoseconds in a second"><title>NANOSECONDS in arrow::array::temporal_conversions - Rust</title><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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.NANOSECONDS_IN_DAY.html b/arrow/array/temporal_conversions/constant.NANOSECONDS_IN_DAY.html
index 04797871d8..6c5f1eaa7c 100644
--- a/arrow/array/temporal_conversions/constant.NANOSECONDS_IN_DAY.html
+++ b/arrow/array/temporal_conversions/constant.NANOSECONDS_IN_DAY.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="Number of nanoseconds in a day"><title>NANOSECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</title><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="Number of nanoseconds in a day"><title>NANOSECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</title><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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/constant.SECONDS_IN_DAY.html b/arrow/array/temporal_conversions/constant.SECONDS_IN_DAY.html
index 7f23c56033..f5a7031493 100644
--- a/arrow/array/temporal_conversions/constant.SECONDS_IN_DAY.html
+++ b/arrow/array/temporal_conversions/constant.SECONDS_IN_DAY.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="Number of seconds in a day"><title>SECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</title><link 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="Number of seconds in a day"><title>SECONDS_IN_DAY in arrow::array::temporal_conversions - Rust</title><link 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.as_date.html b/arrow/array/temporal_conversions/fn.as_date.html
index 6f16ff46fa..ee13d3c7d2 100644
--- a/arrow/array/temporal_conversions/fn.as_date.html
+++ b/arrow/array/temporal_conversions/fn.as_date.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="Converts an `ArrowPrimitiveType` to `NaiveDate`"><title>as_date in arrow::array::temporal_conversions - Rust</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="Converts an `ArrowPrimitiveType` to `NaiveDate`"><title>as_date in arrow::array::temporal_conversions - Rust</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>< [...]
     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>Converts an <a href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a> to <a href="https://docs.rs/chrono/lates [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.as_datetime.html b/arrow/array/temporal_conversions/fn.as_datetime.html
index 3ab9b69c9a..0c85581e32 100644
--- a/arrow/array/temporal_conversions/fn.as_datetime.html
+++ b/arrow/array/temporal_conversions/fn.as_datetime.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="Converts an `ArrowPrimitiveType` to `NaiveDateTime`"><title>as_datetime in arrow::array::temporal_conversions - 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="Converts an `ArrowPrimitiveType` to `NaiveDateTime`"><title>as_datetime in arrow::array::temporal_conversions - 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>< [...]
     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>Converts an <a href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a> to <a href="https://docs.rs/chrono/lates [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.as_datetime_with_timezone.html b/arrow/array/temporal_conversions/fn.as_datetime_with_timezone.html
index c231d31e85..cda019b334 100644
--- a/arrow/array/temporal_conversions/fn.as_datetime_with_timezone.html
+++ b/arrow/array/temporal_conversions/fn.as_datetime_with_timezone.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="Converts an `ArrowPrimitiveType` to `DateTime&lt;Tz&gt;`"><title>as_datetime_with_timezone in arrow::array::temporal_conversions - 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="Converts an `ArrowPrimitiveType` to `DateTime&lt;Tz&gt;`"><title>as_datetime_with_timezone in arrow::array::temporal_conversions - 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>< [...]
     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>Converts an <a href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a> to <a href="https://docs.rs/chrono/lates [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.as_duration.html b/arrow/array/temporal_conversions/fn.as_duration.html
index ac1ec1852f..3aab80b5c2 100644
--- a/arrow/array/temporal_conversions/fn.as_duration.html
+++ b/arrow/array/temporal_conversions/fn.as_duration.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="Converts an `ArrowPrimitiveType` to `Duration`"><title>as_duration in arrow::array::temporal_conversions - 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="Converts an `ArrowPrimitiveType` to `Duration`"><title>as_duration in arrow::array::temporal_conversions - 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>< [...]
     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>Converts an <a href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a> to <a href="https://docs.rs/chrono/lates [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.as_time.html b/arrow/array/temporal_conversions/fn.as_time.html
index c0bff1b4ee..ac958fca10 100644
--- a/arrow/array/temporal_conversions/fn.as_time.html
+++ b/arrow/array/temporal_conversions/fn.as_time.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="Converts an `ArrowPrimitiveType` to `NaiveTime`"><title>as_time in arrow::array::temporal_conversions - Rust</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="Converts an `ArrowPrimitiveType` to `NaiveTime`"><title>as_time in arrow::array::temporal_conversions - Rust</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>< [...]
     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>Converts an <a href="../../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType"><code>ArrowPrimitiveType</code></a> to <a href="https://docs.rs/chrono/lates [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.date32_to_datetime.html b/arrow/array/temporal_conversions/fn.date32_to_datetime.html
index 18d8d4184b..9a370f16e9 100644
--- a/arrow/array/temporal_conversions/fn.date32_to_datetime.html
+++ b/arrow/array/temporal_conversions/fn.date32_to_datetime.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="converts a `i32` representing a `date32` to `NaiveDateTime`"><title>date32_to_datetime in arrow::array::temporal_conversions - 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="converts a `i32` representing a `date32` to `NaiveDateTime`"><title>date32_to_datetime in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.date64_to_datetime.html b/arrow/array/temporal_conversions/fn.date64_to_datetime.html
index 94c5cf1201..80ea597563 100644
--- a/arrow/array/temporal_conversions/fn.date64_to_datetime.html
+++ b/arrow/array/temporal_conversions/fn.date64_to_datetime.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="converts a `i64` representing a `date64` to `NaiveDateTime`"><title>date64_to_datetime in arrow::array::temporal_conversions - 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="converts a `i64` representing a `date64` to `NaiveDateTime`"><title>date64_to_datetime in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.duration_ms_to_duration.html b/arrow/array/temporal_conversions/fn.duration_ms_to_duration.html
index b02f86216b..c52300ac8d 100644
--- a/arrow/array/temporal_conversions/fn.duration_ms_to_duration.html
+++ b/arrow/array/temporal_conversions/fn.duration_ms_to_duration.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="converts a `i64` representing a `duration(ms)` to `Duration`"><title>duration_ms_to_duration in arrow::array::temporal_conversions - 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="converts a `i64` representing a `duration(ms)` to `Duration`"><title>duration_ms_to_duration in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.duration_ns_to_duration.html b/arrow/array/temporal_conversions/fn.duration_ns_to_duration.html
index 00a324bd34..b6c0b8e7b9 100644
--- a/arrow/array/temporal_conversions/fn.duration_ns_to_duration.html
+++ b/arrow/array/temporal_conversions/fn.duration_ns_to_duration.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="converts a `i64` representing a `duration(ns)` to `Duration`"><title>duration_ns_to_duration in arrow::array::temporal_conversions - 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="converts a `i64` representing a `duration(ns)` to `Duration`"><title>duration_ns_to_duration in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.duration_s_to_duration.html b/arrow/array/temporal_conversions/fn.duration_s_to_duration.html
index 0eadcc5b93..08a20b06be 100644
--- a/arrow/array/temporal_conversions/fn.duration_s_to_duration.html
+++ b/arrow/array/temporal_conversions/fn.duration_s_to_duration.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="converts a `i64` representing a `duration(s)` to `Duration`"><title>duration_s_to_duration in arrow::array::temporal_conversions - 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="converts a `i64` representing a `duration(s)` to `Duration`"><title>duration_s_to_duration in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.duration_us_to_duration.html b/arrow/array/temporal_conversions/fn.duration_us_to_duration.html
index 346134c084..3ee3935486 100644
--- a/arrow/array/temporal_conversions/fn.duration_us_to_duration.html
+++ b/arrow/array/temporal_conversions/fn.duration_us_to_duration.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="converts a `i64` representing a `duration(us)` to `Duration`"><title>duration_us_to_duration in arrow::array::temporal_conversions - 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="converts a `i64` representing a `duration(us)` to `Duration`"><title>duration_us_to_duration in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time32ms_to_time.html b/arrow/array/temporal_conversions/fn.time32ms_to_time.html
index 1dcc4809a3..a1c6f260a4 100644
--- a/arrow/array/temporal_conversions/fn.time32ms_to_time.html
+++ b/arrow/array/temporal_conversions/fn.time32ms_to_time.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="converts a `i32` representing a `time32(ms)` to `NaiveDateTime`"><title>time32ms_to_time in arrow::array::temporal_conversions - 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="converts a `i32` representing a `time32(ms)` to `NaiveDateTime`"><title>time32ms_to_time in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time32s_to_time.html b/arrow/array/temporal_conversions/fn.time32s_to_time.html
index d1fd5f6cb3..74b30b4236 100644
--- a/arrow/array/temporal_conversions/fn.time32s_to_time.html
+++ b/arrow/array/temporal_conversions/fn.time32s_to_time.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="converts a `i32` representing a `time32(s)` to `NaiveDateTime`"><title>time32s_to_time in arrow::array::temporal_conversions - 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="converts a `i32` representing a `time32(s)` to `NaiveDateTime`"><title>time32s_to_time in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time64ns_to_time.html b/arrow/array/temporal_conversions/fn.time64ns_to_time.html
index 9d18b238fd..a1440684e8 100644
--- a/arrow/array/temporal_conversions/fn.time64ns_to_time.html
+++ b/arrow/array/temporal_conversions/fn.time64ns_to_time.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="converts a `i64` representing a `time64(ns)` to `NaiveDateTime`"><title>time64ns_to_time in arrow::array::temporal_conversions - 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="converts a `i64` representing a `time64(ns)` to `NaiveDateTime`"><title>time64ns_to_time in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time64us_to_time.html b/arrow/array/temporal_conversions/fn.time64us_to_time.html
index 82c4c05a85..398d9745a0 100644
--- a/arrow/array/temporal_conversions/fn.time64us_to_time.html
+++ b/arrow/array/temporal_conversions/fn.time64us_to_time.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="converts a `i64` representing a `time64(us)` to `NaiveDateTime`"><title>time64us_to_time in arrow::array::temporal_conversions - 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="converts a `i64` representing a `time64(us)` to `NaiveDateTime`"><title>time64us_to_time in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time_to_time32ms.html b/arrow/array/temporal_conversions/fn.time_to_time32ms.html
index cf6c13244c..3638605bda 100644
--- a/arrow/array/temporal_conversions/fn.time_to_time32ms.html
+++ b/arrow/array/temporal_conversions/fn.time_to_time32ms.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="converts `NaiveTime` to a `i32` representing a `time32(ms)`"><title>time_to_time32ms in arrow::array::temporal_conversions - 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="converts `NaiveTime` to a `i32` representing a `time32(ms)`"><title>time_to_time32ms in arrow::array::temporal_conversions - 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></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time_to_time32s.html b/arrow/array/temporal_conversions/fn.time_to_time32s.html
index 66d1d74701..c395d3476c 100644
--- a/arrow/array/temporal_conversions/fn.time_to_time32s.html
+++ b/arrow/array/temporal_conversions/fn.time_to_time32s.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="converts `NaiveTime` to a `i32` representing a `time32(s)`"><title>time_to_time32s in arrow::array::temporal_conversions - 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="converts `NaiveTime` to a `i32` representing a `time32(s)`"><title>time_to_time32s in arrow::array::temporal_conversions - 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></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time_to_time64ns.html b/arrow/array/temporal_conversions/fn.time_to_time64ns.html
index 3e498a0c93..6b81f2bd50 100644
--- a/arrow/array/temporal_conversions/fn.time_to_time64ns.html
+++ b/arrow/array/temporal_conversions/fn.time_to_time64ns.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="converts `NaiveTime` to a `i64` representing a `time64(ns)`"><title>time_to_time64ns in arrow::array::temporal_conversions - 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="converts `NaiveTime` to a `i64` representing a `time64(ns)`"><title>time_to_time64ns in arrow::array::temporal_conversions - 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></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.time_to_time64us.html b/arrow/array/temporal_conversions/fn.time_to_time64us.html
index f6c9335146..e469ac747a 100644
--- a/arrow/array/temporal_conversions/fn.time_to_time64us.html
+++ b/arrow/array/temporal_conversions/fn.time_to_time64us.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="converts `NaiveTime` to a `i64` representing a `time64(us)`"><title>time_to_time64us in arrow::array::temporal_conversions - 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="converts `NaiveTime` to a `i64` representing a `time64(us)`"><title>time_to_time64us in arrow::array::temporal_conversions - 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></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/temporal_conversions/fn.timestamp_ms_to_datetime.html b/arrow/array/temporal_conversions/fn.timestamp_ms_to_datetime.html
index 97cd9207e1..f8b1c3c633 100644
--- a/arrow/array/temporal_conversions/fn.timestamp_ms_to_datetime.html
+++ b/arrow/array/temporal_conversions/fn.timestamp_ms_to_datetime.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="converts a `i64` representing a `timestamp(ms)` to `NaiveDateTime`"><title>timestamp_ms_to_datetime in arrow::array::temporal_conversions - 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="converts a `i64` representing a `timestamp(ms)` to `NaiveDateTime`"><title>timestamp_ms_to_datetime in arrow::array::temporal_conversions - 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/temporal_conversions/fn.timestamp_ns_to_datetime.html b/arrow/array/temporal_conversions/fn.timestamp_ns_to_datetime.html
index b06cc9d06f..3d4156dcc7 100644
--- a/arrow/array/temporal_conversions/fn.timestamp_ns_to_datetime.html
+++ b/arrow/array/temporal_conversions/fn.timestamp_ns_to_datetime.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="converts a `i64` representing a `timestamp(ns)` to `NaiveDateTime`"><title>timestamp_ns_to_datetime in arrow::array::temporal_conversions - 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="converts a `i64` representing a `timestamp(ns)` to `NaiveDateTime`"><title>timestamp_ns_to_datetime in arrow::array::temporal_conversions - 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/temporal_conversions/fn.timestamp_s_to_datetime.html b/arrow/array/temporal_conversions/fn.timestamp_s_to_datetime.html
index 1609267717..6e05ae7765 100644
--- a/arrow/array/temporal_conversions/fn.timestamp_s_to_datetime.html
+++ b/arrow/array/temporal_conversions/fn.timestamp_s_to_datetime.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="converts a `i64` representing a `timestamp(s)` to `NaiveDateTime`"><title>timestamp_s_to_datetime in arrow::array::temporal_conversions - 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="converts a `i64` representing a `timestamp(s)` to `NaiveDateTime`"><title>timestamp_s_to_datetime in arrow::array::temporal_conversions - 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/temporal_conversions/fn.timestamp_us_to_datetime.html b/arrow/array/temporal_conversions/fn.timestamp_us_to_datetime.html
index 4200ab7bae..4934fae8ee 100644
--- a/arrow/array/temporal_conversions/fn.timestamp_us_to_datetime.html
+++ b/arrow/array/temporal_conversions/fn.timestamp_us_to_datetime.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="converts a `i64` representing a `timestamp(us)` to `NaiveDateTime`"><title>timestamp_us_to_datetime in arrow::array::temporal_conversions - 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="converts a `i64` representing a `timestamp(us)` to `NaiveDateTime`"><title>timestamp_us_to_datetime in arrow::array::temporal_conversions - 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/temporal_conversions/index.html b/arrow/array/temporal_conversions/index.html
index 01e5a2fb98..b4f6912c80 100644
--- a/arrow/array/temporal_conversions/index.html
+++ b/arrow/array/temporal_conversions/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="Conversion methods for dates and times."><title>arrow::array::temporal_conversions - Rust</title><link 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="Conversion methods for dates and times."><title>arrow::array::temporal_conversions - Rust</title><link 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="constants" class="section-header"><a href="#constants">Constants</a></h2><ul class="item-table"><li><div class="item-name"><a class="constant" href="constant.EPOCH_DAYS_FROM_CE.html" title="constant arrow::array::temporal_conversions::EPOCH_DAYS_FROM_CE">EPOCH_DAYS_FROM_CE</a></div><div class="desc docblock-short">Number of days between 0001-01-01 and 1970-01-01</div></li><li><div class="item-name"><a class="constant" href="constant.MICROSECONDS.html" title="const [...]
\ No newline at end of file
diff --git a/arrow/array/timezone/index.html b/arrow/array/timezone/index.html
index 3976807286..7d121ffe3f 100644
--- a/arrow/array/timezone/index.html
+++ b/arrow/array/timezone/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="Timezone for timestamp arrays"><title>arrow::array::timezone - Rust</title><link 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="../../../s [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Timezone for timestamp arrays"><title>arrow::array::timezone - Rust</title><link 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="../../../s [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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.Tz.html" title="struct arrow::array::timezone::Tz">Tz</a></div><div class="desc docblock-short">An Arrow <a href="https://docs.rs/chrono/latest/chrono/offset/trait.TimeZone.html" title="trait chrono::offset::TimeZone"><code>TimeZone</code></a></div></li><li><div class="item-name"><a class="struct" href="struct.TzOffset [...]
\ No newline at end of file
diff --git a/arrow/array/timezone/struct.Tz.html b/arrow/array/timezone/struct.Tz.html
index 9edaf76ab5..2dc56a2ddc 100644
--- a/arrow/array/timezone/struct.Tz.html
+++ b/arrow/array/timezone/struct.Tz.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 Arrow `TimeZone`"><title>Tz in arrow::array::timezone - Rust</title><link 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="../../../stati [...]
+<!DOCTYPE html><html lang="en"><head><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 Arrow `TimeZone`"><title>Tz in arrow::array::timezone - Rust</title><link 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="../../../stati [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="fields" class="fields section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="enum" href="../../../arrow_array/timezone/private/enum.TzInner.html" title="enum arrow_array::timezone::private::TzInner">TzInner</a></code></span><h2 id="trait-implementations" class="section-header">Trait Implementations<a href="#trait-impleme [...]
 This type is used to store the actual offset in date and time types.
diff --git a/arrow/array/timezone/struct.TzOffset.html b/arrow/array/timezone/struct.TzOffset.html
index deb651a0f5..b6dee53701 100644
--- a/arrow/array/timezone/struct.TzOffset.html
+++ b/arrow/array/timezone/struct.TzOffset.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 `Offset` for `Tz`"><title>TzOffset in arrow::array::timezone - Rust</title><link 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 `Offset` for `Tz`"><title>TzOffset in arrow::array::timezone - Rust</title><link 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>< [...]
     tz: <a class="struct" href="struct.Tz.html" title="struct arrow::array::timezone::Tz">Tz</a>,
     offset: <a class="struct" href="https://docs.rs/chrono/latest/chrono/offset/fixed/struct.FixedOffset.html" title="struct chrono::offset::fixed::FixedOffset">FixedOffset</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An <a href="https://docs.rs/chrono/latest/chrono/offset/trait.Offset.html" title="trait chrono::offset::Offset"><code>Offset</code></a> for <a href="struct.Tz.html" title="struct arrow::array::timezone::Tz"><code>Tz</code></a></p>
-</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.tz" class="structfield section-header"><a href="#structfield.tz" class="anchor field">§</a><code>tz: <a class="struct" href="struct.Tz.html" title="struct arrow::array::timezone::Tz">Tz</a></code></span><span id="structfield.offset" class="structfield section-header"><a href="#structfield.offset" class="anchor field">§</a><code>offset: <a class="struct" hre [...]
+</div></details><h2 id="fields" class="fields section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.tz" class="structfield section-header"><a href="#structfield.tz" class="anchor field">§</a><code>tz: <a class="struct" href="struct.Tz.html" title="struct arrow::array::timezone::Tz">Tz</a></code></span><span id="structfield.offset" class="structfield section-header"><a href="#structfield.offset" class="anchor field">§</a><code>offset: <a class="struct" hre [...]
     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= [...]
diff --git a/arrow/array/trait.AnyDictionaryArray.html b/arrow/array/trait.AnyDictionaryArray.html
index f6c0f4420c..d9fc2c1ca8 100644
--- a/arrow/array/trait.AnyDictionaryArray.html
+++ b/arrow/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 - Rust</title><link 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 `DictionaryArray` with the key type erased"><title>AnyDictionaryArray 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" 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 [...]
     // 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>;
diff --git a/arrow/array/trait.Array.html b/arrow/array/trait.Array.html
index 50bc31ff01..6741e015e3 100644
--- a/arrow/array/trait.Array.html
+++ b/arrow/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 - Rust</title><link 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 in the arrow columnar format"><title>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="../../ [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <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);
@@ -154,11 +154,11 @@ and therefore would not appear in <a href="trait.Array.html#method.logical_nulls
     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 class= [...]
     O: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</div></h4></section></summary><div class='docblock'>Downcast this to a <a href="type.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 rightside" hr [...]
     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="src righ [...]
-    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="metho [...]
-    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.eq" cla [...]
-by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#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 core [...]
+    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="metho [...]
+    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#tymethod.eq" [...]
 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 core [...]
+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="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="anchor"> [...]
 </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" c [...]
     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.org/nigh [...]
diff --git a/arrow/array/trait.ArrayAccessor.html b/arrow/array/trait.ArrayAccessor.html
index 228322a644..443a2c69fb 100644
--- a/arrow/array/trait.ArrayAccessor.html
+++ b/arrow/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 - Rust</title><link 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 generic trait for accessing the values of an `Array`"><title>ArrayAccessor 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" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 <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>;
 
diff --git a/arrow/array/trait.ArrayBuilder.html b/arrow/array/trait.ArrayBuilder.html
index 9c5e8a64c6..6f7f69af93 100644
--- a/arrow/array/trait.ArrayBuilder.html
+++ b/arrow/array/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 - Rust</title><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="Trait for dealing with different array builders at runtime"><title>ArrayBuilder 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/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 id [...]
     // 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>;
diff --git a/arrow/array/trait.ArrowNativeTypeOp.html b/arrow/array/trait.ArrowNativeTypeOp.html
index 1f87fe6203..7547d4c5ad 100644
--- a/arrow/array/trait.ArrowNativeTypeOp.html
+++ b/arrow/array/trait.ArrowNativeTypeOp.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 `ArrowNativeType` that adds checked and unchecked arithmetic operations, and totally ordered comparison operations"><title>ArrowNativeTypeOp 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="Trait for `ArrowNativeType` that adds checked and unchecked arithmetic operations, and totally ordered comparison operations"><title>ArrowNativeTypeOp 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 [...]
     const <a href="#associatedconstant.ZERO" class="constant">ZERO</a>: Self;
     const <a href="#associatedconstant.ONE" class="constant">ONE</a>: Self;
diff --git a/arrow/array/trait.ArrowNumericType.html b/arrow/array/trait.ArrowNumericType.html
index 912494f57e..18276ede17 100644
--- a/arrow/array/trait.ArrowNumericType.html
+++ b/arrow/array/trait.ArrowNumericType.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 subtype of primitive type that represents numeric values."><title>ArrowNumericType 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="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 subtype of primitive type that represents numeric values."><title>ArrowNumericType 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="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 id [...]
 </div></details><h2 id="object-safety" class="section-header">Object Safety<a href="#object-safety" class="anchor">§</a></h2><div class="object-safety-info">This trait is <b>not</b> <a href="https://doc.rust-lang.org/nightly/reference/items/traits.html#object-safety">object safe</a>.</div><h2 id="implementors" class="section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><section id="impl-ArrowNumericType-for-T" class="impl"><a class="src [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</div></h3></section></div><script src="../../trait.impl/arrow_array/numeric/trait.ArrowNumericType.js" async></script></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/trait.ArrowPrimitiveType.html b/arrow/array/trait.ArrowPrimitiveType.html
index c93305375b..cb7708d652 100644
--- a/arrow/array/trait.ArrowPrimitiveType.html
+++ b/arrow/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 - 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="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 - 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 [...]
     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/trait.AsArray.html b/arrow/array/trait.AsArray.html
index 67f8778388..255fa9791b 100644
--- a/arrow/array/trait.AsArray.html
+++ b/arrow/array/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 - Rust</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="An extension trait for `dyn Array` that provides ergonomic downcasting"><title>AsArray 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="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 id [...]
 <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/trait.Datum.html b/arrow/array/trait.Datum.html
index 008418cc9e..9f1dea4f19 100644
--- a/arrow/array/trait.Datum.html
+++ b/arrow/array/trait.Datum.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 possibly `Scalar` `Array`"><title>Datum 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="../../static.fil [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A possibly `Scalar` `Array`"><title>Datum 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="../../static.fil [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     // Required method
     fn <a href="#tymethod.get" class="fn">get</a>(&amp;self) -&gt; (&amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>);
diff --git a/arrow/array/trait.OffsetSizeTrait.html b/arrow/array/trait.OffsetSizeTrait.html
index 6de3282620..90ceda57ca 100644
--- a/arrow/array/trait.OffsetSizeTrait.html
+++ b/arrow/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 - 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 type that can be used within a variable-size array to encode offset information"><title>OffsetSizeTrait 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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/trait.RecordBatchReader.html b/arrow/array/trait.RecordBatchReader.html
index b870afee15..051ed96f3a 100644
--- a/arrow/array/trait.RecordBatchReader.html
+++ b/arrow/array/trait.RecordBatchReader.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 types that can read `RecordBatch`’s."><title>RecordBatchReader 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" 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="Trait for types that can read `RecordBatch`’s."><title>RecordBatchReader 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" 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 id [...]
     // Required method
     fn <a href="#tymethod.schema" class="fn">schema</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../datatypes/struct.Schema.html" title="struct arrow::datatypes::Schema">Schema</a>&gt;;
diff --git a/arrow/array/trait.RecordBatchWriter.html b/arrow/array/trait.RecordBatchWriter.html
index f7cf490f5c..66fe1a95ef 100644
--- a/arrow/array/trait.RecordBatchWriter.html
+++ b/arrow/array/trait.RecordBatchWriter.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 types that can write `RecordBatch`’s."><title>RecordBatchWriter 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" 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="Trait for types that can write `RecordBatch`’s."><title>RecordBatchWriter 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" 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 id [...]
     // Required methods
     fn <a href="#tymethod.write" class="fn">write</a>(&amp;mut self, batch: &amp;<a class="struct" href="../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="../error/enum.ArrowError. [...]
diff --git a/arrow/array/type.ArrayDataRef.html b/arrow/array/type.ArrayDataRef.html
index 211d913d41..6fd6dca28a 100644
--- a/arrow/array/type.ArrayDataRef.html
+++ b/arrow/array/type.ArrayDataRef.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="API documentation for the Rust `ArrayDataRef` type in crate `arrow`."><title>ArrayDataRef 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 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `ArrayDataRef` type in crate `arrow`."><title>ArrayDataRef 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
     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;<a class="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;&gt;,
     phantom: <a class="struct" href="https://doc.rust-lang.org/nightly/core/marker/struct.PhantomData.html" title="struct core::marker::PhantomData">PhantomData</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.ArcInner.html" title="struct alloc::sync::ArcInner">ArcInner</a>&lt;<a class="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;&gt;,
diff --git a/arrow/array/type.ArrayRef.html b/arrow/array/type.ArrayRef.html
index c36851b50b..588da45a98 100644
--- a/arrow/array/type.ArrayRef.html
+++ b/arrow/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 - Rust</title><link 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="A reference-counted reference to a generic `Array`"><title>ArrayRef 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 [...]
 </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/type.BinaryArray.html b/arrow/array/type.BinaryArray.html
index 9b0aab219e..f2b2045bf3 100644
--- a/arrow/array/type.BinaryArray.html
+++ b/arrow/array/type.BinaryArray.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` of `[u8]` using `i32` offsets"><title>BinaryArray 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" 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="A `GenericBinaryArray` of `[u8]` using `i32` offsets"><title>BinaryArray 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" 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 id [...]
 <p>The byte length of each element is represented by an i32.</p>
 <h2 id="examples"><a href="#examples">Examples</a></h2>
diff --git a/arrow/array/type.BinaryBuilder.html b/arrow/array/type.BinaryBuilder.html
index 7065818f73..a6b13ddb5e 100644
--- a/arrow/array/type.BinaryBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `BinaryArray`"><title>BinaryBuilder 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 [...]
 </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="builder/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/type.BinaryDictionaryBuilder.html b/arrow/array/type.BinaryDictionaryBuilder.html
index 712874cdac..7b70c2d33d 100644
--- a/arrow/array/type.BinaryDictionaryBuilder.html
+++ b/arrow/array/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 - Rust</title><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="Builder for `DictionaryArray` of `BinaryArray`"><title>BinaryDictionaryBuilder 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/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 [...]
 
 <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/type.BinaryRunBuilder.html b/arrow/array/type.BinaryRunBuilder.html
index 6b1707cb7a..0cfe37e8c1 100644
--- a/arrow/array/type.BinaryRunBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `RunArray` of `BinaryArray`"><title>BinaryRunBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="comment">// Create a run-end encoded array with run-end indexes data type as `i16`.
diff --git a/arrow/array/type.BooleanIter.html b/arrow/array/type.BooleanIter.html
index 5a6ad65978..4873664061 100644
--- a/arrow/array/type.BooleanIter.html
+++ b/arrow/array/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 - 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="an iterator that returns Some(T) or None, that can be used on any BooleanArray"><title>BooleanIter 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="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 id [...]
 </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/type.Date32Array.html b/arrow/array/type.Date32Array.html
index fd706a80de..bc334faceb 100644
--- a/arrow/array/type.Date32Array.html
+++ b/arrow/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 - Rust</title><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="A `PrimitiveArray` of days since UNIX epoch stored as `i32`"><title>Date32Array 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/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 id [...]
 <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/type.Date32BufferBuilder.html b/arrow/array/type.Date32BufferBuilder.html
index 6109a54d5f..f80a0a9c17 100644
--- a/arrow/array/type.Date32BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for 32-bit date type."><title>Date32BufferBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.Date32Builder.html b/arrow/array/type.Date32Builder.html
index 39b9f25f2c..beca3f8b3d 100644
--- a/arrow/array/type.Date32Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="../../s [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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="../../s [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.Date64Array.html b/arrow/array/type.Date64Array.html
index ffda8e8ae5..6dfcffb52f 100644
--- a/arrow/array/type.Date64Array.html
+++ b/arrow/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 - Rust</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 milliseconds since UNIX epoch stored as `i64`"><title>Date64Array 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=" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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>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/type.Date64BufferBuilder.html b/arrow/array/type.Date64BufferBuilder.html
index cdc36f210e..a2dc797947 100644
--- a/arrow/array/type.Date64BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for 64-bit date type."><title>Date64BufferBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.Date64Builder.html b/arrow/array/type.Date64Builder.html
index f0144cebbd..4e1e35d7b9 100644
--- a/arrow/array/type.Date64Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="../../s [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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="../../s [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.Decimal128Array.html b/arrow/array/type.Decimal128Array.html
index c7b93186bc..52fefbab91 100644
--- a/arrow/array/type.Decimal128Array.html
+++ b/arrow/array/type.Decimal128Array.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 128-bit fixed point decimals"><title>Decimal128Array 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" 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 `PrimitiveArray` of 128-bit fixed point decimals"><title>Decimal128Array 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" 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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Decimal128BufferBuilder.html b/arrow/array/type.Decimal128BufferBuilder.html
index 16fc019139..fc20a64990 100644
--- a/arrow/array/type.Decimal128BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for 128-bit decimal type."><title>Decimal128BufferBuilder 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" 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 id [...]
 </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/type.Decimal128Builder.html b/arrow/array/type.Decimal128Builder.html
index 7ecd466273..a10c03c415 100644
--- a/arrow/array/type.Decimal128Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 decimal 128 array builder"><title>Decimal128Builder 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 [...]
 </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="builder/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/type.Decimal256Array.html b/arrow/array/type.Decimal256Array.html
index 4f708a25b5..f3be28c414 100644
--- a/arrow/array/type.Decimal256Array.html
+++ b/arrow/array/type.Decimal256Array.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 256-bit fixed point decimals"><title>Decimal256Array 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" 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 `PrimitiveArray` of 256-bit fixed point decimals"><title>Decimal256Array 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" 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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Decimal256BufferBuilder.html b/arrow/array/type.Decimal256BufferBuilder.html
index 5dd017e0a2..2a66e6b363 100644
--- a/arrow/array/type.Decimal256BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for 256-bit decimal type."><title>Decimal256BufferBuilder 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" 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 id [...]
 </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/type.Decimal256Builder.html b/arrow/array/type.Decimal256Builder.html
index 7c170b3d7d..c549e50016 100644
--- a/arrow/array/type.Decimal256Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 decimal 256 array builder"><title>Decimal256Builder 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 [...]
 </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="builder/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/type.DurationMicrosecondArray.html b/arrow/array/type.DurationMicrosecondArray.html
index da5e8be206..2809bacfbc 100644
--- a/arrow/array/type.DurationMicrosecondArray.html
+++ b/arrow/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 - Rust</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 microseconds"><title>DurationMicrosecondArray 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.DurationMicrosecondBufferBuilder.html b/arrow/array/type.DurationMicrosecondBufferBuilder.html
index fcb6aefbf4..37f370a7a7 100644
--- a/arrow/array/type.DurationMicrosecondBufferBuilder.html
+++ b/arrow/array/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 - 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="Buffer builder for elaspsed time of microseconds unit."><title>DurationMicrosecondBufferBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.DurationMicrosecondBuilder.html b/arrow/array/type.DurationMicrosecondBuilder.html
index fa99f2e8c3..cabde0129a 100644
--- a/arrow/array/type.DurationMicrosecondBuilder.html
+++ b/arrow/array/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 - Rust</title><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="An elapsed time in microseconds array builder."><title>DurationMicrosecondBuilder 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/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><div id [...]
 </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="builder/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/type.DurationMillisecondArray.html b/arrow/array/type.DurationMillisecondArray.html
index 3332c18d1f..45f30a03c8 100644
--- a/arrow/array/type.DurationMillisecondArray.html
+++ b/arrow/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 - Rust</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 milliseconds"><title>DurationMillisecondArray 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.DurationMillisecondBufferBuilder.html b/arrow/array/type.DurationMillisecondBufferBuilder.html
index e9b739b38d..335fbaa065 100644
--- a/arrow/array/type.DurationMillisecondBufferBuilder.html
+++ b/arrow/array/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 - 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="Buffer builder for elaspsed time of milliseconds unit."><title>DurationMillisecondBufferBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.DurationMillisecondBuilder.html b/arrow/array/type.DurationMillisecondBuilder.html
index 0679e3a88b..ba133e1587 100644
--- a/arrow/array/type.DurationMillisecondBuilder.html
+++ b/arrow/array/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 - Rust</title><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="An elapsed time in milliseconds array builder."><title>DurationMillisecondBuilder 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/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><div id [...]
 </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="builder/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/type.DurationNanosecondArray.html b/arrow/array/type.DurationNanosecondArray.html
index 82a9f86758..92015da590 100644
--- a/arrow/array/type.DurationNanosecondArray.html
+++ b/arrow/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 - Rust</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 `PrimitiveArray` of elapsed durations in nanoseconds"><title>DurationNanosecondArray 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="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 id [...]
 </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/type.DurationNanosecondBufferBuilder.html b/arrow/array/type.DurationNanosecondBufferBuilder.html
index 1257e6b53c..7a905d0678 100644
--- a/arrow/array/type.DurationNanosecondBufferBuilder.html
+++ b/arrow/array/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 - 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="Buffer builder for elaspsed time of nanoseconds unit."><title>DurationNanosecondBufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.DurationNanosecondBuilder.html b/arrow/array/type.DurationNanosecondBuilder.html
index 998def7449..5197c6d275 100644
--- a/arrow/array/type.DurationNanosecondBuilder.html
+++ b/arrow/array/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 - Rust</title><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="An elapsed time in nanoseconds array builder."><title>DurationNanosecondBuilder 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/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 id [...]
 </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="builder/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/type.DurationSecondArray.html b/arrow/array/type.DurationSecondArray.html
index 10094f60e8..c637189cc7 100644
--- a/arrow/array/type.DurationSecondArray.html
+++ b/arrow/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 - Rust</title><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 `PrimitiveArray` of elapsed durations in seconds"><title>DurationSecondArray 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/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 [...]
 </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/type.DurationSecondBufferBuilder.html b/arrow/array/type.DurationSecondBufferBuilder.html
index 00f30640f4..c4bd75f632 100644
--- a/arrow/array/type.DurationSecondBufferBuilder.html
+++ b/arrow/array/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 - Rust</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 elaspsed time of second unit."><title>DurationSecondBufferBuilder 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="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 id [...]
 </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/type.DurationSecondBuilder.html b/arrow/array/type.DurationSecondBuilder.html
index e9fb3cbc03..ba06e8b7cb 100644
--- a/arrow/array/type.DurationSecondBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 elapsed time in seconds array builder."><title>DurationSecondBuilder 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" 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 [...]
 </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="builder/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/type.DynComparator.html b/arrow/array/type.DynComparator.html
index beddf059e7..41819e1517 100644
--- a/arrow/array/type.DynComparator.html
+++ b/arrow/array/type.DynComparator.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="Compare the values at two arbitrary indices in two arrays."><title>DynComparator 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/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="Compare the values at two arbitrary indices in two arrays."><title>DynComparator 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/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 [...]
 </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 DynComparator(<a class="struct" href="https://doc.rust-lang.org/nightly/core/ptr/unique/struct.Unique.html" title="struct core::ptr::unique::Unique">Unique</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=" [...]
\ No newline at end of file
diff --git a/arrow/array/type.FixedSizeBinaryIter.html b/arrow/array/type.FixedSizeBinaryIter.html
index 5da748cf4a..d750310cd2 100644
--- a/arrow/array/type.FixedSizeBinaryIter.html
+++ b/arrow/array/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 - 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 FixedSizeBinaryArray"><title>FixedSizeBinaryIter 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><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/type.FixedSizeListIter.html b/arrow/array/type.FixedSizeListIter.html
index da0f1b7ff8..44224875ab 100644
--- a/arrow/array/type.FixedSizeListIter.html
+++ b/arrow/array/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 - 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="an iterator that returns Some(T) or None, that can be used on any FixedSizeListArray"><title>FixedSizeListIter 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 [...]
 </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/type.Float16Array.html b/arrow/array/type.Float16Array.html
index bae9750239..001a3702a8 100644
--- a/arrow/array/type.Float16Array.html
+++ b/arrow/array/type.Float16Array.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 `f16`"><title>Float16Array 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="../../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="A `PrimitiveArray` of `f16`"><title>Float16Array 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="../../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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Float16BufferBuilder.html b/arrow/array/type.Float16BufferBuilder.html
index 2de1a53279..62e37d7410 100644
--- a/arrow/array/type.Float16BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 16-bit floating point type."><title>Float16BufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.Float16Builder.html b/arrow/array/type.Float16Builder.html
index d990bd937b..984e23c41b 100644
--- a/arrow/array/type.Float16Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="A 16-bit floating point array builder."><title>Float16Builder 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 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><div id [...]
 </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="builder/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/type.Float32Array.html b/arrow/array/type.Float32Array.html
index bee8869d12..5bbdd5ba88 100644
--- a/arrow/array/type.Float32Array.html
+++ b/arrow/array/type.Float32Array.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 `f32`"><title>Float32Array 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="../../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="A `PrimitiveArray` of `f32`"><title>Float32Array 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="../../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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Float32BufferBuilder.html b/arrow/array/type.Float32BufferBuilder.html
index 10029c1a42..2ade3e8465 100644
--- a/arrow/array/type.Float32BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 floating point type."><title>Float32BufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.Float32Builder.html b/arrow/array/type.Float32Builder.html
index 2e65023225..e406586af0 100644
--- a/arrow/array/type.Float32Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="A 32-bit floating point array builder."><title>Float32Builder 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 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><div id [...]
 </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="builder/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/type.Float64Array.html b/arrow/array/type.Float64Array.html
index bd3b10783b..a06e47e9b6 100644
--- a/arrow/array/type.Float64Array.html
+++ b/arrow/array/type.Float64Array.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 `f64`"><title>Float64Array 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="../../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="A `PrimitiveArray` of `f64`"><title>Float64Array 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="../../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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Float64BufferBuilder.html b/arrow/array/type.Float64BufferBuilder.html
index fd7297b6fc..d34504e7fd 100644
--- a/arrow/array/type.Float64BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 floating point type."><title>Float64BufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.Float64Builder.html b/arrow/array/type.Float64Builder.html
index 7bbfdf978d..cb03d3ddb2 100644
--- a/arrow/array/type.Float64Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="A 64-bit floating point array builder."><title>Float64Builder 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 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><div id [...]
 </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="builder/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/type.GenericBinaryArray.html b/arrow/array/type.GenericBinaryArray.html
index 197d2c1f58..be6a6610f7 100644
--- a/arrow/array/type.GenericBinaryArray.html
+++ b/arrow/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 - Rust</title><link 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="A `GenericBinaryArray` for storing `[u8]`"><title>GenericBinaryArray 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" 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><div id [...]
 </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/type.GenericBinaryBuilder.html b/arrow/array/type.GenericBinaryBuilder.html
index ed28355b60..2f50d218c5 100644
--- a/arrow/array/type.GenericBinaryBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Array builder for `GenericBinaryArray`"><title>GenericBinaryBuilder 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 [...]
 </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="builder/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/type.GenericBinaryIter.html b/arrow/array/type.GenericBinaryIter.html
index 1432082649..42e3b64f1a 100644
--- a/arrow/array/type.GenericBinaryIter.html
+++ b/arrow/array/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 - 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="an iterator that returns Some(T) or None, that can be used on any BinaryArray"><title>GenericBinaryIter 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.GenericListArrayIter.html b/arrow/array/type.GenericListArrayIter.html
index 6098cf2f20..8f778d71c4 100644
--- a/arrow/array/type.GenericListArrayIter.html
+++ b/arrow/array/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 - 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="an iterator that returns Some(T) or None, that can be used on any ListArray"><title>GenericListArrayIter 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" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.GenericStringArray.html b/arrow/array/type.GenericStringArray.html
index c56e137fda..fa0c9aea73 100644
--- a/arrow/array/type.GenericStringArray.html
+++ b/arrow/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 - Rust</title><link 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 `GenericByteArray` for storing `str`"><title>GenericStringArray 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 [...]
 </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/type.GenericStringBuilder.html b/arrow/array/type.GenericStringBuilder.html
index 775ae3d239..2d86844504 100644
--- a/arrow/array/type.GenericStringBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Array builder for `GenericStringArray`"><title>GenericStringBuilder 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 [...]
 <p>Values can be appended using <a href="builder/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="builder/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/type.GenericStringIter.html b/arrow/array/type.GenericStringIter.html
index a46db8d158..02c5779335 100644
--- a/arrow/array/type.GenericStringIter.html
+++ b/arrow/array/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 - 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 Utf8Array"><title>GenericStringIter 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 [...]
 </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/type.Int16Array.html b/arrow/array/type.Int16Array.html
index e12ee81243..a2bee5936d 100644
--- a/arrow/array/type.Int16Array.html
+++ b/arrow/array/type.Int16Array.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 `i16`"><title>Int16Array 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="../../stati [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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="../../stati [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Int16BufferBuilder.html b/arrow/array/type.Int16BufferBuilder.html
index 28b1b2829d..21cd24b82b 100644
--- a/arrow/array/type.Int16BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for signed 16-bit integer type."><title>Int16BufferBuilder 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" 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 id [...]
 </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/type.Int16Builder.html b/arrow/array/type.Int16Builder.html
index dc743d4a0e..231128d523 100644
--- a/arrow/array/type.Int16Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 signed 16-bit integer array builder."><title>Int16Builder 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 [...]
 </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="builder/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/type.Int16DictionaryArray.html b/arrow/array/type.Int16DictionaryArray.html
index fa37109a46..9feae92104 100644
--- a/arrow/array/type.Int16DictionaryArray.html
+++ b/arrow/array/type.Int16DictionaryArray.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` indexed by `i16`"><title>Int16DictionaryArray 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="A `DictionaryArray` indexed by `i16`"><title>Int16DictionaryArray 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.Int16RunArray.html b/arrow/array/type.Int16RunArray.html
index 9b1002ede8..31bab31eae 100644
--- a/arrow/array/type.Int16RunArray.html
+++ b/arrow/array/type.Int16RunArray.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` with `i16` run ends"><title>Int16RunArray 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="A `RunArray` with `i16` run ends"><title>Int16RunArray 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.Int32Array.html b/arrow/array/type.Int32Array.html
index 22de28ec7d..1fd80a5b61 100644
--- a/arrow/array/type.Int32Array.html
+++ b/arrow/array/type.Int32Array.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 `i32`"><title>Int32Array 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="../../stati [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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="../../stati [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Int32BufferBuilder.html b/arrow/array/type.Int32BufferBuilder.html
index 1358d9aae2..69bc73c301 100644
--- a/arrow/array/type.Int32BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for signed 32-bit integer type."><title>Int32BufferBuilder 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" 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 id [...]
 </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/type.Int32Builder.html b/arrow/array/type.Int32Builder.html
index dc1733023b..878ace5a65 100644
--- a/arrow/array/type.Int32Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 signed 32-bit integer array builder."><title>Int32Builder 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 [...]
 </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="builder/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/type.Int32DictionaryArray.html b/arrow/array/type.Int32DictionaryArray.html
index 9d70caee5e..901f142341 100644
--- a/arrow/array/type.Int32DictionaryArray.html
+++ b/arrow/array/type.Int32DictionaryArray.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` indexed by `i32`"><title>Int32DictionaryArray 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="A `DictionaryArray` indexed by `i32`"><title>Int32DictionaryArray 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.Int32RunArray.html b/arrow/array/type.Int32RunArray.html
index 26d3b1357c..03ce5ad8a6 100644
--- a/arrow/array/type.Int32RunArray.html
+++ b/arrow/array/type.Int32RunArray.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` with `i32` run ends"><title>Int32RunArray 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="A `RunArray` with `i32` run ends"><title>Int32RunArray 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.Int64Array.html b/arrow/array/type.Int64Array.html
index 58b264e8ef..06f2b18e63 100644
--- a/arrow/array/type.Int64Array.html
+++ b/arrow/array/type.Int64Array.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 `i64`"><title>Int64Array 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="../../stati [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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="../../stati [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Int64BufferBuilder.html b/arrow/array/type.Int64BufferBuilder.html
index 3f92dacd09..861ba100e1 100644
--- a/arrow/array/type.Int64BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for signed 64-bit integer type."><title>Int64BufferBuilder 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" 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 id [...]
 </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/type.Int64Builder.html b/arrow/array/type.Int64Builder.html
index 996a0b3c13..156360f6fb 100644
--- a/arrow/array/type.Int64Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 signed 64-bit integer array builder."><title>Int64Builder 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 [...]
 </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="builder/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/type.Int64DictionaryArray.html b/arrow/array/type.Int64DictionaryArray.html
index 3a81247db5..5f988c7f3b 100644
--- a/arrow/array/type.Int64DictionaryArray.html
+++ b/arrow/array/type.Int64DictionaryArray.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` indexed by `i64`"><title>Int64DictionaryArray 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="A `DictionaryArray` indexed by `i64`"><title>Int64DictionaryArray 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.Int64RunArray.html b/arrow/array/type.Int64RunArray.html
index e01a2e83ed..33c7be688e 100644
--- a/arrow/array/type.Int64RunArray.html
+++ b/arrow/array/type.Int64RunArray.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` with `i64` run ends"><title>Int64RunArray 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="A `RunArray` with `i64` run ends"><title>Int64RunArray 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.Int8Array.html b/arrow/array/type.Int8Array.html
index c4a54dced5..7a3e20819f 100644
--- a/arrow/array/type.Int8Array.html
+++ b/arrow/array/type.Int8Array.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 `i8`"><title>Int8Array 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="../../static. [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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. [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.Int8BufferBuilder.html b/arrow/array/type.Int8BufferBuilder.html
index 8a1f3477f2..f3cf10fdcc 100644
--- a/arrow/array/type.Int8BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for signed 8-bit integer type."><title>Int8BufferBuilder 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" 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 [...]
 </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/type.Int8Builder.html b/arrow/array/type.Int8Builder.html
index 3a1c2e360b..0a4d88c5ea 100644
--- a/arrow/array/type.Int8Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 signed 8-bit integer array builder."><title>Int8Builder 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 [...]
 </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="builder/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/type.Int8DictionaryArray.html b/arrow/array/type.Int8DictionaryArray.html
index 8c86b4e246..a548129296 100644
--- a/arrow/array/type.Int8DictionaryArray.html
+++ b/arrow/array/type.Int8DictionaryArray.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` indexed by `i8`"><title>Int8DictionaryArray 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  [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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><div id [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.IntervalDayTimeArray.html b/arrow/array/type.IntervalDayTimeArray.html
index 47bf84bf28..9a0eaa1b94 100644
--- a/arrow/array/type.IntervalDayTimeArray.html
+++ b/arrow/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 - 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 “calendar” intervals in days and milliseconds"><title>IntervalDayTimeArray 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="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 id [...]
 <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/type.IntervalDayTimeBufferBuilder.html b/arrow/array/type.IntervalDayTimeBufferBuilder.html
index d35cd161e3..49f4ad5bc0 100644
--- a/arrow/array/type.IntervalDayTimeBufferBuilder.html
+++ b/arrow/array/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 - 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 days and milliseconds."><title>IntervalDayTimeBufferBuilder 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 [...]
 </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/type.IntervalDayTimeBuilder.html b/arrow/array/type.IntervalDayTimeBuilder.html
index 8887d23bc3..60bbd0d72f 100644
--- a/arrow/array/type.IntervalDayTimeBuilder.html
+++ b/arrow/array/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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" t [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" t [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.IntervalMonthDayNanoArray.html b/arrow/array/type.IntervalMonthDayNanoArray.html
index 1f450473e2..bbd525741a 100644
--- a/arrow/array/type.IntervalMonthDayNanoArray.html
+++ b/arrow/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 - 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 “calendar” intervals in  months, days, and nanoseconds."><title>IntervalMonthDayNanoArray 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 [...]
 <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/type.IntervalMonthDayNanoBufferBuilder.html b/arrow/array/type.IntervalMonthDayNanoBufferBuilder.html
index f8b8d93688..bef908f8d0 100644
--- a/arrow/array/type.IntervalMonthDayNanoBufferBuilder.html
+++ b/arrow/array/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 - 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="Buffer builder “calendar” interval in months, days, and nanoseconds."><title>IntervalMonthDayNanoBufferBuilder 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 [...]
 </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/type.IntervalMonthDayNanoBuilder.html b/arrow/array/type.IntervalMonthDayNanoBuilder.html
index a5c2cf3d50..e696815150 100644
--- a/arrow/array/type.IntervalMonthDayNanoBuilder.html
+++ b/arrow/array/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 - 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 months, days, and nanoseconds array builder."><title>IntervalMonthDayNanoBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.IntervalYearMonthArray.html b/arrow/array/type.IntervalYearMonthArray.html
index b9f3460737..127fc78ada 100644
--- a/arrow/array/type.IntervalYearMonthArray.html
+++ b/arrow/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 - Rust</title><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 `PrimitiveArray` of “calendar” intervals in months"><title>IntervalYearMonthArray 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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>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/type.IntervalYearMonthBufferBuilder.html b/arrow/array/type.IntervalYearMonthBufferBuilder.html
index aa52365727..2eb5cb9ce8 100644
--- a/arrow/array/type.IntervalYearMonthBufferBuilder.html
+++ b/arrow/array/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 - Rust</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 “calendar” interval in months."><title>IntervalYearMonthBufferBuilder 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.IntervalYearMonthBuilder.html b/arrow/array/type.IntervalYearMonthBuilder.html
index 45bb6566b1..b13df02725 100644
--- a/arrow/array/type.IntervalYearMonthBuilder.html
+++ b/arrow/array/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 - Rust</title><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="A “calendar” interval in months array builder."><title>IntervalYearMonthBuilder 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/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 id [...]
 </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="builder/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/type.LargeBinaryArray.html b/arrow/array/type.LargeBinaryArray.html
index 5d46442ea4..c92daad344 100644
--- a/arrow/array/type.LargeBinaryArray.html
+++ b/arrow/array/type.LargeBinaryArray.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` of `[u8]` using `i64` offsets"><title>LargeBinaryArray 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 [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Create a LargeBinaryArray from a vector of byte slices.</p>
diff --git a/arrow/array/type.LargeBinaryBuilder.html b/arrow/array/type.LargeBinaryBuilder.html
index dd200af77c..7638ae7ee1 100644
--- a/arrow/array/type.LargeBinaryBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `LargeBinaryArray`"><title>LargeBinaryBuilder 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 [...]
 </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="builder/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/type.LargeBinaryDictionaryBuilder.html b/arrow/array/type.LargeBinaryDictionaryBuilder.html
index 17bdd2849a..e2ee168229 100644
--- a/arrow/array/type.LargeBinaryDictionaryBuilder.html
+++ b/arrow/array/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 - Rust</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="Builder for `DictionaryArray` of `LargeBinaryArray`"><title>LargeBinaryDictionaryBuilder 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.LargeBinaryRunBuilder.html b/arrow/array/type.LargeBinaryRunBuilder.html
index f22208231e..485b662a05 100644
--- a/arrow/array/type.LargeBinaryRunBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `RunArray` of `LargeBinaryArray`"><title>LargeBinaryRunBuilder 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" 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 id [...]
 </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="builder/struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
diff --git a/arrow/array/type.LargeListArray.html b/arrow/array/type.LargeListArray.html
index 801de620c4..c5f2ea55f3 100644
--- a/arrow/array/type.LargeListArray.html
+++ b/arrow/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 - 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 `GenericListArray` of variable size lists, storing offsets as `i64`."><title>LargeListArray 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.LargeListBuilder.html b/arrow/array/type.LargeListBuilder.html
index dd4cd9b54e..033c0a9df4 100644
--- a/arrow/array/type.LargeListBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `LargeListArray`"><title>LargeListBuilder 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 [...]
 </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="builder/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/type.LargeStringArray.html b/arrow/array/type.LargeStringArray.html
index 3e3134239f..af412e4ac6 100644
--- a/arrow/array/type.LargeStringArray.html
+++ b/arrow/array/type.LargeStringArray.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 `GenericStringArray` of `str` using `i64` offsets"><title>LargeStringArray 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" [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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 id [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.LargeStringBuilder.html b/arrow/array/type.LargeStringBuilder.html
index efee263fe2..38978efc07 100644
--- a/arrow/array/type.LargeStringBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 `LargeStringArray`"><title>LargeStringBuilder 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 [...]
 </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="builder/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/type.LargeStringDictionaryBuilder.html b/arrow/array/type.LargeStringDictionaryBuilder.html
index ea4f198862..246f3facf2 100644
--- a/arrow/array/type.LargeStringDictionaryBuilder.html
+++ b/arrow/array/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 - Rust</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="Builder for `DictionaryArray` of `LargeStringArray`"><title>LargeStringDictionaryBuilder 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.LargeStringRunBuilder.html b/arrow/array/type.LargeStringRunBuilder.html
index 626f1186d4..2d43083422 100644
--- a/arrow/array/type.LargeStringRunBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `RunArray` of `LargeStringArray`"><title>LargeStringRunBuilder 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" 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 id [...]
 </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="builder/struct.PrimitiveBuilder.html" title="struct arrow::array::builder::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
diff --git a/arrow/array/type.ListArray.html b/arrow/array/type.ListArray.html
index 098f04a678..7e83611a8e 100644
--- a/arrow/array/type.ListArray.html
+++ b/arrow/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 - Rust</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 `GenericListArray` of variable size lists, storing offsets as `i32`."><title>ListArray 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= [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.ListBuilder.html b/arrow/array/type.ListBuilder.html
index f8eeaf8960..850423de27 100644
--- a/arrow/array/type.ListBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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.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 `ListArray`"><title>ListBuilder 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="../../static.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 id [...]
 </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="builder/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/type.MapArrayIter.html b/arrow/array/type.MapArrayIter.html
index d55ac90782..7ea933c4e6 100644
--- a/arrow/array/type.MapArrayIter.html
+++ b/arrow/array/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 - 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 iterator that returns Some(T) or None, that can be used on any MapArray"><title>MapArrayIter 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.PrimitiveIter.html b/arrow/array/type.PrimitiveIter.html
index 5f303e30e2..95c13b3b8f 100644
--- a/arrow/array/type.PrimitiveIter.html
+++ b/arrow/array/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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" a [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" a [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.StringArray.html b/arrow/array/type.StringArray.html
index eef7621787..b232f5b902 100644
--- a/arrow/array/type.StringArray.html
+++ b/arrow/array/type.StringArray.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 `GenericStringArray` of `str` using `i32` offsets"><title>StringArray 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" 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 `GenericStringArray` of `str` using `i32` offsets"><title>StringArray 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" 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.StringBuilder.html b/arrow/array/type.StringBuilder.html
index 86438f03f1..b338828d55 100644
--- a/arrow/array/type.StringBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `StringArray`"><title>StringBuilder 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 [...]
 </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="builder/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/type.StringDictionaryBuilder.html b/arrow/array/type.StringDictionaryBuilder.html
index b3bdc8dcec..b1f88b6bf9 100644
--- a/arrow/array/type.StringDictionaryBuilder.html
+++ b/arrow/array/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 - Rust</title><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="Builder for `DictionaryArray` of `StringArray`"><title>StringDictionaryBuilder 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/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 [...]
 
 <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/type.StringRunBuilder.html b/arrow/array/type.StringRunBuilder.html
index f7e692e1c7..9749e6d8aa 100644
--- a/arrow/array/type.StringRunBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Builder for `RunArray` of `StringArray`"><title>StringRunBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="comment">// Create a run-end encoded array with run-end indexes data type as `i16`.
diff --git a/arrow/array/type.Time32MillisecondArray.html b/arrow/array/type.Time32MillisecondArray.html
index c4ca1c2355..2f9bfb1ff9 100644
--- a/arrow/array/type.Time32MillisecondArray.html
+++ b/arrow/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 - 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 milliseconds since midnight stored as `i32`"><title>Time32MillisecondArray 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="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 id [...]
 <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/type.Time32MillisecondBufferBuilder.html b/arrow/array/type.Time32MillisecondBufferBuilder.html
index 972eea2eb4..c3208994b0 100644
--- a/arrow/array/type.Time32MillisecondBufferBuilder.html
+++ b/arrow/array/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 - 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 32-bit elaspsed time since midnight of millisecond unit."><title>Time32MillisecondBufferBuilder 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><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/type.Time32MillisecondBuilder.html b/arrow/array/type.Time32MillisecondBuilder.html
index 50509491f1..ac14fdb67e 100644
--- a/arrow/array/type.Time32MillisecondBuilder.html
+++ b/arrow/array/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 - Rust</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 32-bit elaspsed time in milliseconds array builder."><title>Time32MillisecondBuilder 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="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 id [...]
 </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="builder/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/type.Time32SecondArray.html b/arrow/array/type.Time32SecondArray.html
index 90eca903a4..8b20b9aa6a 100644
--- a/arrow/array/type.Time32SecondArray.html
+++ b/arrow/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 - Rust</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 `PrimitiveArray` of seconds since midnight stored as `i32`"><title>Time32SecondArray 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="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 id [...]
 <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/type.Time32SecondBufferBuilder.html b/arrow/array/type.Time32SecondBufferBuilder.html
index 5fef387505..511b16acc4 100644
--- a/arrow/array/type.Time32SecondBufferBuilder.html
+++ b/arrow/array/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 - 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 32-bit elaspsed time since midnight of second unit."><title>Time32SecondBufferBuilder 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" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.Time32SecondBuilder.html b/arrow/array/type.Time32SecondBuilder.html
index b950e32c0c..70fd51ab29 100644
--- a/arrow/array/type.Time32SecondBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 32-bit elaspsed time in seconds array builder."><title>Time32SecondBuilder 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" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.Time64MicrosecondArray.html b/arrow/array/type.Time64MicrosecondArray.html
index c96d5a5c9d..5f74fe4ed4 100644
--- a/arrow/array/type.Time64MicrosecondArray.html
+++ b/arrow/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 - 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 microseconds since midnight stored as `i64`"><title>Time64MicrosecondArray 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="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 id [...]
 <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/type.Time64MicrosecondBufferBuilder.html b/arrow/array/type.Time64MicrosecondBufferBuilder.html
index a545ecdcea..df1910fc7a 100644
--- a/arrow/array/type.Time64MicrosecondBufferBuilder.html
+++ b/arrow/array/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 - 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 64-bit elaspsed time since midnight of microsecond unit."><title>Time64MicrosecondBufferBuilder 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><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/type.Time64MicrosecondBuilder.html b/arrow/array/type.Time64MicrosecondBuilder.html
index ca977fe6a3..a54c4f2270 100644
--- a/arrow/array/type.Time64MicrosecondBuilder.html
+++ b/arrow/array/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 - Rust</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 64-bit elaspsed time in microseconds array builder."><title>Time64MicrosecondBuilder 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="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 id [...]
 </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="builder/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/type.Time64NanosecondArray.html b/arrow/array/type.Time64NanosecondArray.html
index b202389e58..daef219b4c 100644
--- a/arrow/array/type.Time64NanosecondArray.html
+++ b/arrow/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 - 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 nanoseconds since midnight stored as `i64`"><title>Time64NanosecondArray 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" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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>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/type.Time64NanosecondBufferBuilder.html b/arrow/array/type.Time64NanosecondBufferBuilder.html
index c4ab545270..2f667b9ef9 100644
--- a/arrow/array/type.Time64NanosecondBufferBuilder.html
+++ b/arrow/array/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 - 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 64-bit elaspsed time since midnight of nanosecond unit."><title>Time64NanosecondBufferBuilder 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><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/type.Time64NanosecondBuilder.html b/arrow/array/type.Time64NanosecondBuilder.html
index 38db7499a7..480cb6f92e 100644
--- a/arrow/array/type.Time64NanosecondBuilder.html
+++ b/arrow/array/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 - Rust</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 64-bit elaspsed time in nanoseconds array builder."><title>Time64NanosecondBuilder 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="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 id [...]
 </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="builder/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/type.TimestampMicrosecondArray.html b/arrow/array/type.TimestampMicrosecondArray.html
index 6f57bda8ff..80ff96791b 100644
--- a/arrow/array/type.TimestampMicrosecondArray.html
+++ b/arrow/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 - 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 microseconds since UNIX epoch stored as `i64`"><title>TimestampMicrosecondArray 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 [...]
 <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/type.TimestampMicrosecondBufferBuilder.html b/arrow/array/type.TimestampMicrosecondBufferBuilder.html
index 1dbb1a597c..94e5f7e224 100644
--- a/arrow/array/type.TimestampMicrosecondBufferBuilder.html
+++ b/arrow/array/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 - 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 timestamp type of microsecond unit."><title>TimestampMicrosecondBufferBuilder 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="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 id [...]
 </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/type.TimestampMicrosecondBuilder.html b/arrow/array/type.TimestampMicrosecondBuilder.html
index ee7a537462..281d43b95c 100644
--- a/arrow/array/type.TimestampMicrosecondBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 timestamp microsecond array builder."><title>TimestampMicrosecondBuilder 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" 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 id [...]
 </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="builder/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/type.TimestampMillisecondArray.html b/arrow/array/type.TimestampMillisecondArray.html
index 55b7092bce..a02302fa39 100644
--- a/arrow/array/type.TimestampMillisecondArray.html
+++ b/arrow/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 - 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 milliseconds since UNIX epoch stored as `i64`"><title>TimestampMillisecondArray 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 [...]
 <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/type.TimestampMillisecondBufferBuilder.html b/arrow/array/type.TimestampMillisecondBufferBuilder.html
index e0b3034aa8..abe0a4558a 100644
--- a/arrow/array/type.TimestampMillisecondBufferBuilder.html
+++ b/arrow/array/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 - 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 timestamp type of millisecond unit."><title>TimestampMillisecondBufferBuilder 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="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 id [...]
 </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/type.TimestampMillisecondBuilder.html b/arrow/array/type.TimestampMillisecondBuilder.html
index bd605dd835..e4f2970540 100644
--- a/arrow/array/type.TimestampMillisecondBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 timestamp millisecond array builder."><title>TimestampMillisecondBuilder 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" 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 id [...]
 </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="builder/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/type.TimestampNanosecondArray.html b/arrow/array/type.TimestampNanosecondArray.html
index 3002b06623..8d51cd9119 100644
--- a/arrow/array/type.TimestampNanosecondArray.html
+++ b/arrow/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 - 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 nanoseconds since UNIX epoch stored as `i64`"><title>TimestampNanosecondArray 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 [...]
 <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/type.TimestampNanosecondBufferBuilder.html b/arrow/array/type.TimestampNanosecondBufferBuilder.html
index a7c18e0485..fc5fa84d20 100644
--- a/arrow/array/type.TimestampNanosecondBufferBuilder.html
+++ b/arrow/array/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 - 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="Buffer builder for timestamp type of nanosecond unit."><title>TimestampNanosecondBufferBuilder 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" [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.TimestampNanosecondBuilder.html b/arrow/array/type.TimestampNanosecondBuilder.html
index 669d4b10b0..0c8ff7695c 100644
--- a/arrow/array/type.TimestampNanosecondBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="A timestamp nanosecond array builder."><title>TimestampNanosecondBuilder 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" 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 id [...]
 </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="builder/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/type.TimestampSecondArray.html b/arrow/array/type.TimestampSecondArray.html
index 33d69e8fe0..840a57ecf0 100644
--- a/arrow/array/type.TimestampSecondArray.html
+++ b/arrow/array/type.TimestampSecondArray.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 UNIX epoch stored as `i64`"><title>TimestampSecondArray 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" 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 `PrimitiveArray` of seconds since UNIX epoch stored as `i64`"><title>TimestampSecondArray 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" 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 id [...]
 <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>
diff --git a/arrow/array/type.TimestampSecondBufferBuilder.html b/arrow/array/type.TimestampSecondBufferBuilder.html
index 73f1297fa8..3293447112 100644
--- a/arrow/array/type.TimestampSecondBufferBuilder.html
+++ b/arrow/array/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 - Rust</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="Buffer builder for timestamp type of second unit."><title>TimestampSecondBufferBuilder 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="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 id [...]
 </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/type.TimestampSecondBuilder.html b/arrow/array/type.TimestampSecondBuilder.html
index a7a4b4e9c5..c441eb9bfe 100644
--- a/arrow/array/type.TimestampSecondBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 timestamp second array builder."><title>TimestampSecondBuilder 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.UInt16Array.html b/arrow/array/type.UInt16Array.html
index e9592aa172..122529d328 100644
--- a/arrow/array/type.UInt16Array.html
+++ b/arrow/array/type.UInt16Array.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 `u16`"><title>UInt16Array 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="A `PrimitiveArray` of `u16`"><title>UInt16Array 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.UInt16BufferBuilder.html b/arrow/array/type.UInt16BufferBuilder.html
index d20814cc12..dde6104533 100644
--- a/arrow/array/type.UInt16BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 usigned 16-bit integer type."><title>UInt16BufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.UInt16Builder.html b/arrow/array/type.UInt16Builder.html
index d9ea2f7f67..654c3f20ce 100644
--- a/arrow/array/type.UInt16Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="An usigned 16-bit integer array builder."><title>UInt16Builder 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 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><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="builder/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/type.UInt16DictionaryArray.html b/arrow/array/type.UInt16DictionaryArray.html
index f5b03186e3..d9eae2101e 100644
--- a/arrow/array/type.UInt16DictionaryArray.html
+++ b/arrow/array/type.UInt16DictionaryArray.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` indexed by `u16`"><title>UInt16DictionaryArray 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" crossorig [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorig [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.UInt32Array.html b/arrow/array/type.UInt32Array.html
index 0685107a27..c4232eb41f 100644
--- a/arrow/array/type.UInt32Array.html
+++ b/arrow/array/type.UInt32Array.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 `u32`"><title>UInt32Array 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="A `PrimitiveArray` of `u32`"><title>UInt32Array 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.UInt32BufferBuilder.html b/arrow/array/type.UInt32BufferBuilder.html
index 1301d1a3eb..d35684dbde 100644
--- a/arrow/array/type.UInt32BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 usigned 32-bit integer type."><title>UInt32BufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.UInt32Builder.html b/arrow/array/type.UInt32Builder.html
index d8069fc749..12ec6c1493 100644
--- a/arrow/array/type.UInt32Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="An usigned 32-bit integer array builder."><title>UInt32Builder 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 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><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="builder/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/type.UInt32DictionaryArray.html b/arrow/array/type.UInt32DictionaryArray.html
index 06b45fe60b..6a94cb357a 100644
--- a/arrow/array/type.UInt32DictionaryArray.html
+++ b/arrow/array/type.UInt32DictionaryArray.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` indexed by `u32`"><title>UInt32DictionaryArray 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" crossorig [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorig [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.UInt64Array.html b/arrow/array/type.UInt64Array.html
index 4ce1014e15..2ebbf15f37 100644
--- a/arrow/array/type.UInt64Array.html
+++ b/arrow/array/type.UInt64Array.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 `u64`"><title>UInt64Array 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="A `PrimitiveArray` of `u64`"><title>UInt64Array 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.UInt64BufferBuilder.html b/arrow/array/type.UInt64BufferBuilder.html
index 06e5ea8d00..cea5e1d51a 100644
--- a/arrow/array/type.UInt64BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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 usigned 64-bit integer type."><title>UInt64BufferBuilder 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"  [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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/type.UInt64Builder.html b/arrow/array/type.UInt64Builder.html
index fb9dbee36a..fe6031c722 100644
--- a/arrow/array/type.UInt64Builder.html
+++ b/arrow/array/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 - Rust</title><link 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="An usigned 64-bit integer array builder."><title>UInt64Builder 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 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><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="builder/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/type.UInt64DictionaryArray.html b/arrow/array/type.UInt64DictionaryArray.html
index a9d61002b6..8b1b75c97f 100644
--- a/arrow/array/type.UInt64DictionaryArray.html
+++ b/arrow/array/type.UInt64DictionaryArray.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` indexed by `u64`"><title>UInt64DictionaryArray 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" crossorig [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorig [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/type.UInt8Array.html b/arrow/array/type.UInt8Array.html
index 85deb17c65..99fe43a5ea 100644
--- a/arrow/array/type.UInt8Array.html
+++ b/arrow/array/type.UInt8Array.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 `u8`"><title>UInt8Array 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="../../static [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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 [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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 [...]
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Construction</p>
diff --git a/arrow/array/type.UInt8BufferBuilder.html b/arrow/array/type.UInt8BufferBuilder.html
index 3976f41742..877e3c09e1 100644
--- a/arrow/array/type.UInt8BufferBuilder.html
+++ b/arrow/array/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 - Rust</title><link 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="Buffer builder for usigned 8-bit integer type."><title>UInt8BufferBuilder 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" 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 id [...]
 </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/type.UInt8Builder.html b/arrow/array/type.UInt8Builder.html
index 1f31cd7129..05131fa690 100644
--- a/arrow/array/type.UInt8Builder.html
+++ b/arrow/array/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 - Rust</title><link 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 hre [...]
+<!DOCTYPE html><html lang="en"><head><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 - Rust</title><link 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 hre [...]
     <main><div class="width-limiter"><nav class="sub"><form class="search-form"><span></span><div id="sidebar-button" tabindex="-1"><a href="../../arrow/all.html" title="show sidebar"></a></div><input class="search-input" name="search" aria-label="Run search in the documentation" autocomplete="off" spellcheck="false" placeholder="Click 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="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="builder/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/type.UInt8DictionaryArray.html b/arrow/array/type.UInt8DictionaryArray.html
index bdc0311eb3..a19d04b5d0 100644
--- a/arrow/array/type.UInt8DictionaryArray.html
+++ b/arrow/array/type.UInt8DictionaryArray.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` indexed by `u8`"><title>UInt8DictionaryArray 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 [...]
+<!DOCTYPE html><html lang="en"><head><meta 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 - Rust</title><link 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><div id [...]
 <h2 id="example-using-collect"><a href="#example-using-collect">Example: Using <code>collect</code></a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/types/fn.validate_decimal_precision_and_scale.html b/arrow/array/types/fn.validate_decimal_precision_and_scale.html
index 4b5e7f79c4..4105a4daf2 100644
--- a/arrow/array/types/fn.validate_decimal_precision_and_scale.html
+++ b/arrow/array/types/fn.validate_decimal_precision_and_scale.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="Validate that `precision` and `scale` are valid for `T`"><title>validate_decimal_precision_and_scale in arrow::array::types - 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="Validate that `precision` and `scale` are valid for `T`"><title>validate_decimal_precision_and_scale in arrow::array::types - 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>< [...]
     precision: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>,
     scale: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>
diff --git a/arrow/array/types/index.html b/arrow/array/types/index.html
index b4e245a2a1..513de7574e 100644
--- a/arrow/array/types/index.html
+++ b/arrow/array/types/index.html
... 51350 lines suppressed ...