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/09/01 11:15:18 UTC

[arrow-rs] branch asf-site updated: deploy: 4927c1ef1c22373d30c82203577db0bac2ee8eb9

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 874f48698e deploy: 4927c1ef1c22373d30c82203577db0bac2ee8eb9
874f48698e is described below

commit 874f48698e090c0caaae5daf917d3b45a7053a39
Author: tustvold <tu...@users.noreply.github.com>
AuthorDate: Fri Sep 1 11:15:05 2023 +0000

    deploy: 4927c1ef1c22373d30c82203577db0bac2ee8eb9
---
 arrow/all.html                                     |   2 +-
 arrow/alloc/constant.ALIGNMENT.html                |   2 +-
 arrow/alloc/index.html                             |   2 +-
 arrow/alloc/trait.Allocation.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                  |   4 +-
 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/struct.ArrayData.html                  |  30 +-
 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              |   2 +-
 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           |  28 +-
 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             | 124 +++----
 arrow/array/struct.PrimitiveBuilder.html           |   2 +-
 arrow/array/struct.PrimitiveDictionaryBuilder.html |   2 +-
 arrow/array/struct.PrimitiveRunBuilder.html        |   2 +-
 arrow/array/struct.RunArray.html                   |   2 +-
 arrow/array/struct.StructArray.html                |   6 +-
 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 +-
 arrow/array/trait.AnyDictionaryArray.html          |   2 +-
 arrow/array/trait.Array.html                       |  14 +-
 arrow/array/trait.ArrayAccessor.html               |   2 +-
 arrow/array/trait.ArrayBuilder.html                |   2 +-
 arrow/array/trait.ArrowPrimitiveType.html          |   2 +-
 arrow/array/trait.AsArray.html                     |   2 +-
 arrow/array/trait.OffsetSizeTrait.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 +-
 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             |  10 +-
 arrow/buffer/struct.Buffer.html                    | 204 +++++------
 arrow/buffer/struct.MutableBuffer.html             | 382 ++++++++++-----------
 arrow/buffer/struct.NullBuffer.html                |   4 +-
 arrow/buffer/struct.OffsetBuffer.html              | 200 +++++------
 arrow/buffer/struct.RunEndBuffer.html              |   2 +-
 arrow/buffer/struct.ScalarBuffer.html              | 208 +++++------
 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.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 +-
 .../kernels/comparison/fn.no_simd_compare_op.html  |   2 +-
 .../comparison/fn.no_simd_compare_op_scalar.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 +-
 .../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     |   6 +-
 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  |   6 +-
 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                 |  14 +-
 arrow/datatypes/enum.IntervalUnit.html             |   2 +-
 arrow/datatypes/enum.TimeUnit.html                 |   2 +-
 arrow/datatypes/enum.UnionMode.html                |   2 +-
 arrow/datatypes/ffi/index.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                  |  10 +-
 arrow/datatypes/struct.Fields.html                 | 202 +++++------
 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                 |  10 +-
 arrow/datatypes/struct.SchemaBuilder.html          |   8 +-
 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                   |   8 +-
 arrow/datatypes/trait.ArrowDictionaryKeyType.html  |   2 +-
 arrow/datatypes/trait.ArrowNativeType.html         |   4 +-
 arrow/datatypes/trait.ArrowNativeTypeOp.html       |   4 +-
 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                   |  12 +-
 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.to_ffi.html                           |   2 +-
 arrow/ffi/index.html                               |   2 +-
 arrow/ffi/struct.ArrowArray.html                   |   2 +-
 arrow/ffi/struct.FFI_ArrowArray.html               |   2 +-
 arrow/ffi/struct.FFI_ArrowSchema.html              |  10 +-
 arrow/ffi/struct.Flags.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  |   6 +-
 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                                   |   4 +-
 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/index.html                           |  37 +-
 arrow/pyarrow/struct.ArrowException.html           |  10 +-
 arrow/pyarrow/struct.PyArrowType.html              |   9 +-
 arrow/pyarrow/trait.FromPyArrow.html               |   5 +-
 arrow/pyarrow/trait.IntoPyArrow.html               |   6 +-
 arrow/pyarrow/trait.ToPyArrow.html                 |   4 +-
 arrow/pyarrow/type.PyArrowException.html           |   2 +-
 arrow/record_batch/index.html                      |   4 +-
 arrow/record_batch/sidebar-items.js                |   2 +-
 arrow/record_batch/struct.RecordBatch.html         |  10 +-
 .../record_batch/struct.RecordBatchIterator.html   |  51 ++-
 arrow/record_batch/struct.RecordBatchOptions.html  |   2 +-
 arrow/record_batch/trait.RecordBatchReader.html    |   9 +-
 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 +-
 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 +-
 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.is_nan.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.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 +-
 .../aggregate/simd/fn.simd_aggregation.html        |   2 +-
 arrow_arith/aggregate/simd/index.html              |   2 +-
 .../aggregate/simd/struct.MaxAggregate.html        |   2 +-
 .../aggregate/simd/struct.MinAggregate.html        |   2 +-
 .../aggregate/simd/struct.SumAggregate.html        |   2 +-
 .../aggregate/simd/trait.SimdAggregate.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              |   4 +-
 arrow_arith/numeric/trait.IntervalOp.html          |  14 +-
 arrow_arith/numeric/trait.TimestampOp.html         |   4 +-
 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        |   4 +-
 arrow_array/array/binary_array/index.html          |   2 +-
 .../array/binary_array/type.BinaryArray.html       |   2 +-
 .../binary_array/type.GenericBinaryArray.html      |   4 +-
 .../array/binary_array/type.LargeBinaryArray.html  |   2 +-
 arrow_array/array/boolean_array/index.html         |   2 +-
 .../array/boolean_array/struct.BooleanArray.html   |   6 +-
 arrow_array/array/byte_array/index.html            |   2 +-
 .../array/byte_array/struct.GenericByteArray.html  |  10 +-
 arrow_array/array/dictionary_array/index.html      |   2 +-
 .../dictionary_array/struct.DictionaryArray.html   |  16 +-
 .../struct.TypedDictionaryArray.html               |   4 +-
 .../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               |   8 +-
 arrow_array/array/fixed_size_list_array/index.html |   2 +-
 .../struct.FixedSizeListArray.html                 |   8 +-
 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                       |   4 +-
 arrow_array/array/list_array/index.html            |   2 +-
 .../array/list_array/struct.GenericListArray.html  |   8 +-
 .../array/list_array/trait.OffsetSizeTrait.html    |   2 +-
 .../array/list_array/type.LargeListArray.html      |   2 +-
 arrow_array/array/list_array/type.ListArray.html   |   2 +-
 arrow_array/array/map_array/index.html             |   2 +-
 arrow_array/array/map_array/struct.MapArray.html   |   8 +-
 arrow_array/array/null_array/index.html            |   2 +-
 arrow_array/array/null_array/struct.NullArray.html |   6 +-
 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     |  62 ++--
 .../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   |   6 +-
 .../array/run_array/struct.TypedRunArray.html      |   8 +-
 .../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         |   6 +-
 arrow_array/array/struct.DictionaryArray.html      |  16 +-
 arrow_array/array/struct.FixedSizeBinaryArray.html |   8 +-
 arrow_array/array/struct.FixedSizeListArray.html   |   8 +-
 arrow_array/array/struct.GenericByteArray.html     |  10 +-
 arrow_array/array/struct.GenericListArray.html     |   8 +-
 arrow_array/array/struct.MapArray.html             |   8 +-
 arrow_array/array/struct.NativeAdapter.html        |   4 +-
 arrow_array/array/struct.NullArray.html            |   6 +-
 arrow_array/array/struct.PrimitiveArray.html       |  62 ++--
 arrow_array/array/struct.RunArray.html             |   6 +-
 arrow_array/array/struct.StructArray.html          |   6 +-
 arrow_array/array/struct.TypedDictionaryArray.html |   4 +-
 arrow_array/array/struct.TypedRunArray.html        |   8 +-
 arrow_array/array/struct.UnionArray.html           |   6 +-
 arrow_array/array/struct_array/index.html          |   2 +-
 .../array/struct_array/struct.StructArray.html     |   6 +-
 arrow_array/array/trait.AnyDictionaryArray.html    |   2 +-
 arrow_array/array/trait.Array.html                 |  18 +-
 arrow_array/array/trait.ArrayAccessor.html         |   2 +-
 arrow_array/array/trait.OffsetSizeTrait.html       |   2 +-
 arrow_array/array/type.ArrayRef.html               |   4 +-
 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       |   6 +-
 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            |   4 +-
 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/macro.make_numeric_type.html   |   2 +-
 arrow_array/numeric/trait.ArrowNumericType.html    |   2 +-
 arrow_array/record_batch/index.html                |   2 +-
 arrow_array/record_batch/struct.RecordBatch.html   |   4 +-
 .../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                |   4 +-
 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  |   2 +-
 arrow_array/timezone/struct.Tz.html                |   2 +-
 arrow_array/timezone/struct.TzOffset.html          |   2 +-
 arrow_array/trait.ArrowNativeTypeOp.html           |   4 +-
 arrow_array/trait.ArrowNumericType.html            |   2 +-
 arrow_array/trait.Datum.html                       |   2 +-
 arrow_array/trait.RecordBatchReader.html           |   2 +-
 arrow_array/trait.RecordBatchWriter.html           |   2 +-
 arrow_array/trusted_len/fn.trusted_len_unzip.html  |   2 +-
 arrow_array/trusted_len/index.html                 |   2 +-
 arrow_array/types/bytes/index.html                 |   2 +-
 .../types/bytes/trait.ByteArrayNativeType.html     |   2 +-
 .../types/bytes/trait.ByteArrayTypeSealed.html     |   2 +-
 arrow_array/types/decimal/index.html               |   2 +-
 .../types/decimal/trait.DecimalTypeSealed.html     |   2 +-
 arrow_array/types/fn.add_day_time.html             |   2 +-
 arrow_array/types/fn.add_month_day_nano.html       |   2 +-
 arrow_array/types/fn.add_year_months.html          |   2 +-
 arrow_array/types/fn.format_decimal_str.html       |   2 +-
 arrow_array/types/fn.subtract_day_time.html        |   2 +-
 arrow_array/types/fn.subtract_month_day_nano.html  |   2 +-
 arrow_array/types/fn.subtract_year_months.html     |   2 +-
 .../fn.validate_decimal_precision_and_scale.html   |   2 +-
 arrow_array/types/index.html                       |   2 +-
 arrow_array/types/macro.make_type.html             |   2 +-
 arrow_array/types/primitive/index.html             |   2 +-
 .../types/primitive/trait.PrimitiveTypeSealed.html |   2 +-
 arrow_array/types/struct.BooleanType.html          |   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_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   | 378 ++++++++++----------
 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   | 202 +++++------
 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       | 382 ++++++++++-----------
 .../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         | 200 +++++------
 .../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         | 212 ++++++------
 arrow_buffer/buffer/struct.BooleanBuffer.html      |   4 +-
 arrow_buffer/buffer/struct.Buffer.html             | 202 +++++------
 arrow_buffer/buffer/struct.MutableBuffer.html      | 382 ++++++++++-----------
 arrow_buffer/buffer/struct.NullBuffer.html         |   4 +-
 arrow_buffer/buffer/struct.OffsetBuffer.html       | 200 +++++------
 arrow_buffer/buffer/struct.RunEndBuffer.html       |   2 +-
 arrow_buffer/buffer/struct.ScalarBuffer.html       | 212 ++++++------
 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     |   2 +-
 arrow_buffer/builder/struct.NullBufferBuilder.html |   2 +-
 arrow_buffer/bytes/index.html                      |   2 +-
 arrow_buffer/bytes/struct.Bytes.html               | 200 +++++------
 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     |   4 +-
 arrow_buffer/native/trait.ToByteSlice.html         |   2 +-
 arrow_buffer/struct.i256.html                      |  12 +-
 arrow_buffer/trait.ArrowNativeType.html            |   4 +-
 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 +-
 .../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_container.html        |   2 +-
 arrow_cast/cast/fn.cast_list_inner.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_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 +-
 .../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             |   2 +-
 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         |   4 +-
 arrow_cast/display/trait.DisplayIndexState.html    | 120 +++----
 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                 |   4 +-
 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.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_DATE_FORMAT.html |   2 +-
 arrow_csv/writer/constant.DEFAULT_NULL_VALUE.html  |   2 +-
 .../writer/constant.DEFAULT_TIMESTAMP_FORMAT.html  |   2 +-
 .../constant.DEFAULT_TIMESTAMP_TZ_FORMAT.html      |   2 +-
 arrow_csv/writer/constant.DEFAULT_TIME_FORMAT.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/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                |   8 +-
 .../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                |   8 +-
 .../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      |   2 +-
 arrow_flight/gen/struct.FlightEndpoint.html        |   4 +-
 arrow_flight/gen/struct.FlightInfo.html            |   2 +-
 arrow_flight/gen/struct.HandshakeRequest.html      |   2 +-
 arrow_flight/gen/struct.HandshakeResponse.html     |   2 +-
 arrow_flight/gen/struct.Location.html              |   2 +-
 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.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 +-
 .../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.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          |   2 +-
 arrow_flight/struct.FlightEndpoint.html            |   4 +-
 arrow_flight/struct.FlightInfo.html                |   2 +-
 arrow_flight/struct.HandshakeRequest.html          |   2 +-
 arrow_flight/struct.HandshakeResponse.html         |   2 +-
 arrow_flight/struct.IpcMessage.html                | 202 +++++------
 arrow_flight/struct.Location.html                  |   2 +-
 arrow_flight/struct.PutResult.html                 |   2 +-
 arrow_flight/struct.Result.html                    |   2 +-
 arrow_flight/struct.SchemaAsIpc.html               |   4 +-
 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  |   4 +-
 .../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         |   4 +-
 .../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 |   4 +-
 .../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 +-
 arrow_integration_testing/fn.read_gzip_json.html   |   2 +-
 arrow_integration_testing/fn.read_json_file.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               |   2 +-
 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        |   2 +-
 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.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.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.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     |   4 +-
 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 +-
 .../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/macro.serialize_numeric.html |   2 +-
 .../reader/serializer/struct.ListSerializer.html   |  10 +-
 .../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             |   4 +-
 arrow_json/writer/fn.array_to_json_array.html      |   2 +-
 arrow_json/writer/fn.primitive_array_to_json.html  |   2 +-
 .../writer/fn.record_batches_to_json_rows.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/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 +-
 .../fn.canonicalize_schema.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                         |   2 +-
 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                  |   4 +-
 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/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 +-
 .../dictionary/fn.compute_dictionary_mapping.html  |   2 +-
 arrow_row/dictionary/fn.decode_binary.html         |   2 +-
 arrow_row/dictionary/fn.decode_bool.html           |   2 +-
 arrow_row/dictionary/fn.decode_dictionary.html     |   2 +-
 arrow_row/dictionary/fn.decode_fixed.html          |   2 +-
 arrow_row/dictionary/fn.decode_primitive.html      |   2 +-
 arrow_row/dictionary/fn.decode_string.html         |   2 +-
 arrow_row/dictionary/fn.encode_dictionary.html     |   2 +-
 .../dictionary/fn.encode_dictionary_values.html    |   2 +-
 arrow_row/dictionary/index.html                    |   2 +-
 .../dictionary/macro.decode_primitive_helper.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.null_sentinel.html                    |   2 +-
 arrow_row/fn.row_lengths.html                      |   2 +-
 arrow_row/index.html                               |   2 +-
 arrow_row/interner/index.html                      |   2 +-
 arrow_row/interner/struct.Bucket.html              |   2 +-
 arrow_row/interner/struct.InternBuffer.html        |   2 +-
 arrow_row/interner/struct.Interned.html            |   2 +-
 .../interner/struct.OrderPreservingInterner.html   |   2 +-
 arrow_row/interner/struct.Slot.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_dictionary_helper.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 +-
 .../variable/constant.NON_EMPTY_SENTINEL.html      |   2 +-
 arrow_row/variable/fn.decode_binary.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_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           |  10 +-
 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                    |  10 +-
 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           |  12 +-
 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                 |  12 +-
 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             | 202 +++++------
 arrow_schema/fields/struct.UnionFields.html        |   2 +-
 arrow_schema/index.html                            |   2 +-
 arrow_schema/schema/index.html                     |   2 +-
 arrow_schema/schema/struct.Schema.html             |   6 +-
 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                    | 202 +++++------
 arrow_schema/struct.Schema.html                    |   6 +-
 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/index.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_fallback.html         |   2 +-
 .../interleave/fn.interleave_primitive.html        |   2 +-
 arrow_select/interleave/index.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             |   4 +-
 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/fn.main.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.KeyValue.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                                          |   2 +-
 implementors/clap_builder/derive/trait.Args.js     |   2 +-
 .../clap_builder/derive/trait.CommandFactory.js    |   2 +-
 implementors/clap_builder/derive/trait.Parser.js   |   2 +-
 .../clap_builder/derive/trait.ValueEnum.js         |   2 +-
 implementors/core/clone/trait.Clone.js             |  26 +-
 implementors/core/cmp/trait.Eq.js                  |  18 +-
 implementors/core/cmp/trait.Ord.js                 |   8 +-
 implementors/core/cmp/trait.PartialEq.js           |  22 +-
 implementors/core/cmp/trait.PartialOrd.js          |  10 +-
 implementors/core/convert/trait.AsRef.js           |   4 +-
 implementors/core/convert/trait.From.js            |  18 +-
 implementors/core/convert/trait.TryFrom.js         |   6 +-
 implementors/core/default/trait.Default.js         |  20 +-
 implementors/core/fmt/trait.Debug.js               |  44 +--
 implementors/core/fmt/trait.Display.js             |   6 +-
 implementors/core/hash/trait.Hash.js               |  10 +-
 .../core/iter/traits/collect/trait.Extend.js       |   6 +-
 .../core/iter/traits/collect/trait.FromIterator.js |   6 +-
 .../core/iter/traits/collect/trait.IntoIterator.js |   4 +-
 .../double_ended/trait.DoubleEndedIterator.js      |   2 +-
 .../traits/exact_size/trait.ExactSizeIterator.js   |   2 +-
 .../core/iter/traits/iterator/trait.Iterator.js    |  14 +-
 implementors/core/marker/trait.Copy.js             |  16 +-
 implementors/core/marker/trait.Send.js             |   2 +-
 implementors/core/marker/trait.StructuralEq.js     |  14 +-
 .../core/marker/trait.StructuralPartialEq.js       |  12 +-
 implementors/core/marker/trait.Sync.js             |   2 +-
 implementors/core/ops/arith/trait.Add.js           |   2 +-
 implementors/core/ops/arith/trait.Div.js           |   2 +-
 implementors/core/ops/arith/trait.Mul.js           |   2 +-
 implementors/core/ops/arith/trait.Rem.js           |   2 +-
 implementors/core/ops/arith/trait.Sub.js           |   2 +-
 implementors/core/ops/bit/trait.BitOr.js           |   2 +-
 implementors/core/ops/bit/trait.BitXor.js          |   2 +-
 implementors/core/ops/bit/trait.Not.js             |   2 +-
 implementors/core/ops/deref/trait.Deref.js         |   4 +-
 implementors/core/str/traits/trait.FromStr.js      |   4 +-
 .../endian_scalar/trait.EndianScalar.js            |   2 +-
 implementors/flatbuffers/follow/trait.Follow.js    |   2 +-
 implementors/flatbuffers/push/trait.Push.js        |   2 +-
 .../verifier/trait.SimpleToVerifyInSlice.js        |   2 +-
 .../flatbuffers/verifier/trait.Verifiable.js       |   2 +-
 implementors/futures_core/stream/trait.Stream.js   |   2 +-
 implementors/num_traits/cast/trait.AsPrimitive.js  |   2 +-
 implementors/prost/message/trait.Message.js        |   2 +-
 implementors/pyo3/conversion/trait.FromPyObject.js |   2 +-
 implementors/serde/de/trait.Deserialize.js         |   4 +-
 implementors/serde/ser/trait.Serialize.js          |   6 +-
 .../thrift/protocol/trait.TSerializable.js         |   2 +-
 index.html                                         |   2 +-
 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 +-
 .../arrow_reader/selection/fn.add_selector.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/arrow_writer/enum.ArrowColumnWriter.html |   2 +-
 .../arrow_writer/fn.get_arrow_column_writer.html   |   2 +-
 .../arrow_writer/fn.get_bool_array_slice.html      |   2 +-
 .../fn.get_decimal_128_array_slice.html            |   2 +-
 .../fn.get_decimal_256_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_leaves.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.LevelContext.html   |   2 +-
 .../arrow_writer/levels/struct.LevelInfo.html      |   2 +-
 .../arrow_writer/struct.ArrowColumnChunk.html      |   2 +-
 .../arrow/arrow_writer/struct.ArrowPageWriter.html |   2 +-
 .../arrow_writer/struct.ArrowRowGroupWriter.html   |   2 +-
 parquet/arrow/arrow_writer/struct.ArrowWriter.html |   2 +-
 parquet/arrow/arrow_writer/struct.ChainReader.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 +-
 .../async_reader/struct.ParquetObjectReader.html   |   2 +-
 .../struct.ParquetRecordBatchStream.html           |   2 +-
 .../arrow/async_reader/struct.ReaderFactory.html   |   2 +-
 .../arrow/async_reader/trait.AsyncFileReader.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/struct.ScalarBuffer.html  |   2 +-
 .../record_reader/buffer/trait.BufferQueue.html    |   2 +-
 .../record_reader/buffer/trait.ScalarValue.html    |   4 +-
 .../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                |   2 +-
 parquet/basic/enum.Compression.html                |   4 +-
 parquet/basic/enum.ConvertedType.html              |   4 +-
 parquet/basic/enum.Encoding.html                   |   4 +-
 parquet/basic/enum.LogicalType.html                |   4 +-
 parquet/basic/enum.PageType.html                   |   2 +-
 parquet/basic/enum.Repetition.html                 |   4 +-
 parquet/basic/enum.SortOrder.html                  |   2 +-
 parquet/basic/enum.Type.html                       |   4 +-
 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 +-
 .../reader/decoder/trait.LevelsBufferSlice.html    |   2 +-
 .../decoder/trait.RepetitionLevelDecoder.html      |   2 +-
 .../reader/decoder/trait.ValuesBufferSlice.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/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  |   4 +-
 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  |  42 +--
 parquet/data_type/struct.BoolType.html             |   2 +-
 parquet/data_type/struct.ByteArray.html            |  10 +-
 parquet/data_type/struct.ByteArrayType.html        |   2 +-
 parquet/data_type/struct.DoubleType.html           |   2 +-
 parquet/data_type/struct.FixedLenByteArray.html    |  18 +-
 .../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               |   4 +-
 parquet/data_type/trait.DataType.html              |   2 +-
 parquet/data_type/trait.SliceAsBytes.html          |   4 +-
 parquet/data_type/trait.SliceAsBytesDataType.html  |   2 +-
 parquet/errors/enum.ParquetError.html              |   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/fn.read_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 +-
 .../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       |   2 +-
 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   |  12 +-
 .../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               |   4 +-
 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.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                |   2 +-
 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                 |   2 +-
 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                 |   6 +-
 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                     |   2 +-
 parquet/record/index.html                          |   2 +-
 .../record/reader/constant.DEFAULT_BATCH_SIZE.html |   2 +-
 parquet/record/reader/enum.Either.html             |   2 +-
 parquet/record/reader/enum.Reader.html             |   2 +-
 parquet/record/reader/index.html                   |   2 +-
 parquet/record/reader/struct.ReaderIter.html       |   2 +-
 parquet/record/reader/struct.RowIter.html          |   2 +-
 parquet/record/reader/struct.TreeBuilder.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                     |   6 +-
 parquet/record/struct.RowColumnIter.html           |   6 +-
 parquet/record/trait.ListAccessor.html             |   2 +-
 parquet/record/trait.MapAccessor.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_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.ParquetRecordWriter.html     |   2 +-
 parquet_derive/index.html                          |   2 +-
 .../parquet_field/enum.ThirdPartyType.html         |   2 +-
 parquet_derive/parquet_field/enum.Type.html        |   2 +-
 parquet_derive/parquet_field/index.html            |   2 +-
 parquet_derive/parquet_field/struct.Field.html     |   2 +-
 parquet_derive_test/all.html                       |   2 +-
 parquet_derive_test/index.html                     |   2 +-
 parquet_derive_test/struct.ACompleteRecord.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                                    |  24 +-
 settings.html                                      |   2 +-
 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/ffi.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                              |   6 +-
 src/arrow/pyarrow.rs.html                          | 114 +++++-
 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_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/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/sort.rs.html                         |   2 +-
 src/arrow_row/dictionary.rs.html                   |   2 +-
 src/arrow_row/fixed.rs.html                        |   2 +-
 src/arrow_row/interner.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/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                  |   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/util/bit_pack.rs.html                  |   2 +-
 src/parquet/util/bit_util.rs.html                  |   2 +-
 src/parquet/util/interner.rs.html                  |   2 +-
 src/parquet/util/memory.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 +-
 3989 files changed, 7023 insertions(+), 6870 deletions(-)

diff --git a/arrow/all.html b/arrow/all.html
index ddf10b33c3..6c556a32f2 100644
--- a/arrow/all.html
+++ b/arrow/all.html
@@ -1 +1 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
\ No newline at end of file
+<!DOCTYPE html><html lang="en"><head><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 [...]
\ No newline at end of file
diff --git a/arrow/alloc/constant.ALIGNMENT.html b/arrow/alloc/constant.ALIGNMENT.html
index 2e7ecbef1d..8ad3102db5 100644
--- a/arrow/alloc/constant.ALIGNMENT.html
+++ b/arrow/alloc/constant.ALIGNMENT.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="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 [...]
 </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 1fe723ebd9..d06e872c72 100644
--- a/arrow/alloc/index.html
+++ b/arrow/alloc/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="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 [...]
 </div></details><h2 id="constants" class="small-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="small-section-header"><a href="#traits">Traits</a></h2><ul class="item-table"><li><div class="item-name"><a clas [...]
 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 bf711d886a..f5a59d8089 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 [...]
 The trait implementation is responsible for dropping the allocations once no more references exist.</p>
 </div></details><h2 id="implementors" class="small-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<span [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.RefUnwindSafe.html" title="trait core::panic::unwind_safe::RefUnwindSafe">RefUnwindSafe</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</span></h3></section></div><script src="../../ [...]
\ No newline at end of file
diff --git a/arrow/array/enum.BufferSpec.html b/arrow/array/enum.BufferSpec.html
index ca20d3abf3..812ef9d3ef 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 [...]
     FixedWidth {
         byte_width: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
         alignment: <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 7571b915f6..c6186cd09a 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 [...]
     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>, <a class="struct" href [...]
     Struct(<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/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="enum.Capacities.html" title="enum arrow::array::Capacities">Capacities</a>, <a class="struct" href=" [...]
diff --git a/arrow/array/ffi/fn.export_array_into_raw.html b/arrow/array/ffi/fn.export_array_into_raw.html
index 07607b3643..3008975035 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 [...]
     src: <a class="type" href="../type.ArrayRef.html" title="type arrow::array::ArrayRef">ArrayRef</a>,
     out_array: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../../ffi/struct.FFI_ArrowArray.html" title="struct arrow::ffi::FFI_ArrowArray">FFI_ArrowArray</a>,
     out_schema: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../../ffi/struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a>
diff --git a/arrow/array/ffi/index.html b/arrow/array/ffi/index.html
index c3f9e3dd0f..daa81b2844 100644
--- a/arrow/array/ffi/index.html
+++ b/arrow/array/ffi/index.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="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/ [...]
 </div></details><h2 id="functions" class="small-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 consume [...]
\ 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 fe6f256dea..c435f2c03a 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  [...]
 <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>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
diff --git a/arrow/array/fn.as_decimal_array.html b/arrow/array/fn.as_decimal_array.html
index 19a2f21336..3516a2f2cb 100644
--- a/arrow/array/fn.as_decimal_array.html
+++ b/arrow/array/fn.as_decimal_array.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="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 [...]
 </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 345e48edcc..6e96280ce1 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 [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></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"><co [...]
 <a href="struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray"><code>DictionaryArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/array/fn.as_fixed_size_list_array.html b/arrow/array/fn.as_fixed_size_list_array.html
index 775ebe1697..0b461a7c21 100644
--- a/arrow/array/fn.as_fixed_size_list_array.html
+++ b/arrow/array/fn.as_fixed_size_list_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 `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 [...]
 <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 ab487988a7..c5b46a3ebf 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 [...]
     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;<span class="where fmt-newline">where
     S: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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
diff --git a/arrow/array/fn.as_generic_list_array.html b/arrow/array/fn.as_generic_list_array.html
index 9d74871b7f..2559d161f8 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 [...]
     S: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/fn.as_large_list_array.html b/arrow/array/fn.as_large_list_array.html
index eb53cb91cd..2634281041 100644
--- a/arrow/array/fn.as_large_list_array.html
+++ b/arrow/array/fn.as_large_list_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 `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">< [...]
 <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 9a27c831ba..a6e1511c13 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 [...]
     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 [...]
 <a href="type.LargeStringArray.html" title="type arrow::array::LargeStringArray"><code>LargeStringArray</code></a>, panicking on failure.</p>
diff --git a/arrow/array/fn.as_list_array.html b/arrow/array/fn.as_list_array.html
index 71016c4eee..b4a8b18f53 100644
--- a/arrow/array/fn.as_list_array.html
+++ b/arrow/array/fn.as_list_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 `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 [...]
 <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 b8f510b334..f5c05f6227 100644
--- a/arrow/array/fn.as_map_array.html
+++ b/arrow/array/fn.as_map_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  `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 [...]
 <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 d6a622a14a..33e7e163c6 100644
--- a/arrow/array/fn.as_null_array.html
+++ b/arrow/array/fn.as_null_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  `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=" [...]
 <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 3c885391ab..5a8b3752a5 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 [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef< [...]
 <a href="struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray"><code>PrimitiveArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/array/fn.as_run_array.html b/arrow/array/fn.as_run_array.html
index 4673826d4a..7bd09c6539 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 [...]
     T: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Force downcast of an <a href="trait.Array.html" title="trait arrow::array::Array"><code>Array</code></a>, such as an <a href="type.ArrayRef.html" title="type arrow::array::ArrayRef"><code>ArrayRef</code></a> to
 <a href="struct.RunArray.html" title="struct arrow::array::RunArray"><code>RunArray&lt;T&gt;</code></a>, panic’ing on failure.</p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/array/fn.as_string_array.html b/arrow/array/fn.as_string_array.html
index aadda9b2bd..0b8d26db54 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 [...]
     arr: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; &amp;<a class="struct" href="struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summ [...]
 <a href="type.StringArray.html" title="type arrow::array::StringArray"><code>StringArray</code></a>, panicking on failure.</p>
diff --git a/arrow/array/fn.as_struct_array.html b/arrow/array/fn.as_struct_array.html
index 3b1bdb7712..59d48c6d52 100644
--- a/arrow/array/fn.as_struct_array.html
+++ b/arrow/array/fn.as_struct_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  `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 [...]
 <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 2fff593b51..0a3e61e1e2 100644
--- a/arrow/array/fn.as_union_array.html
+++ b/arrow/array/fn.as_union_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  `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 [...]
 <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 88dc049d1d..851e611d1a 100644
--- a/arrow/array/fn.build_compare.html
+++ b/arrow/array/fn.build_compare.html
@@ -1,7 +1,7 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="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 [...]
     left: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>,
     right: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize [...]
 between the two arrays.
 The arrays’ types must be equal.</p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/array/fn.downcast_array.html b/arrow/array/fn.downcast_array.html
index 85ef74f0c9..484b1bf431 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 [...]
     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;,</span></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>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">struct </span>ConcreteBatch {
diff --git a/arrow/array/fn.export_array_into_raw.html b/arrow/array/fn.export_array_into_raw.html
index d173df4182..106c6718d9 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=" [...]
     src: <a class="type" href="type.ArrayRef.html" title="type arrow::array::ArrayRef">ArrayRef</a>,
     out_array: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../ffi/struct.FFI_ArrowArray.html" title="struct arrow::ffi::FFI_ArrowArray">FFI_ArrowArray</a>,
     out_schema: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*mut </a><a class="struct" href="../ffi/struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a>
diff --git a/arrow/array/fn.layout.html b/arrow/array/fn.layout.html
index 0f52c182a0..bc4e151758 100644
--- a/arrow/array/fn.layout.html
+++ b/arrow/array/fn.layout.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="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 [...]
 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 654bfb5838..a220abf6bf 100644
--- a/arrow/array/fn.make_array.html
+++ b/arrow/array/fn.make_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="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 [...]
 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 0d18827bc6..31fa32523e 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 [...]
     datatype: &amp;<a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     capacity: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::ArrayBuilder">ArrayBuilder</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</sp [...]
diff --git a/arrow/array/fn.new_empty_array.html b/arrow/array/fn.new_empty_array.html
index 0f03b03691..49908473c0 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 [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>std::sync::Arc;
 <span class="kw">use </span>arrow_schema::DataType;
diff --git a/arrow/array/fn.new_null_array.html b/arrow/array/fn.new_null_array.html
index 65baf28d72..d94d62fb6b 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 [...]
     data_type: &amp;<a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
 ) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.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>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class [...]
diff --git a/arrow/array/index.html b/arrow/array/index.html
index c960bb22e4..1ea51f3edb 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="../. [...]
 <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="small-section-header"><a href="#modules">Modules</a></h2><ul class="item-table"><li><div class="item-name"><a class="mod" href="ffi/index.html" title="mod arrow::array::ffi">ffi</a><span title="Restricted Visibility">&nbsp;🔒</span> </div><div class="desc docblock-short">Contains functionality to load an ArrayData from the C Data Interface</div></li></ul><h2 id="structs" class="small-section-header"><a href="#structs">Structs</a></h2><ul class="item [...]
 operations for Arrow array. Specific operations for different arrays types (e.g.,
diff --git a/arrow/array/struct.ArrayData.html b/arrow/array/struct.ArrayData.html
index 0251744f26..c9411f79a7 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="An 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="An 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 [...]
     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>,
     offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -173,21 +173,21 @@ 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#1512">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="small-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#220">source</a><a href="#impl-Clone-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl <a  [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="small-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#220">source</a><a href="#impl-Clone-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl <a  [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></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-19" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#578">source</a><a href="#method.from-19" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-14" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#493">source</a><a href="#method.from-14" 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>,</span></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 [...]
+</div><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/dictionary_array.rs.html#578">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::arra [...]
+    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-8" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#493">source</a><a href="#method.from-8" 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>,</span></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/list_array.rs.html#374">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></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-4" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1387">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::arra [...]
-    R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span></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/run_array.rs.html#269">source</a><a href="#method.from-11" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-23" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#626">source</a><a href="#method.from-23" class="anchor">§</a><h4 class="code-header"> [...]
-    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span></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#523">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>,</span></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/list_array.rs.html#382">source</a><a href="#method.from-9" 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>,</span></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#972">source</a><a href="#method.from-13" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
-    R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span></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#296">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-22" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1387">source</a><a href="#method.from-22" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::ar [...]
+    R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span></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#269">source</a><a href="#method.from-16" 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>,</span></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/dictionary_array.rs.html#626">source</a><a href="#method.from-13" class="anchor">§</a><h4 class="code-header"> [...]
+    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-14" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#523">source</a><a href="#method.from-14" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-20" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#382">source</a><a href="#method.from-20" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></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/primitive_array.rs.html#972">source</a><a href="#method.from-21" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
+    R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span></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/run_array.rs.html#296">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
 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#226">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#182-198">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> [...]
+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#218-234">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>,</span></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#136">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></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>,</span></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 [...]
@@ -196,8 +196,8 @@ sufficient, and should not be overridden without very good reason.</div></detail
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt;,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.into" class="method trait-impl"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/convert/mod.rs.html#715">source</a><a href="#method.into" class="anchor">§</a><h4 class="code-header">fn <a href [...]
 <p>That is, this conversion is whatever the implementation of
 <code><a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;T&gt; for U</code> chooses to do.</p>
-</div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-IntoPyArrow-for-ArrayData" class="impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#64-68">source</a><a href="#impl-IntoPyArrow-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../pyarrow/trait.IntoPyArrow.html" title="trait arrow::pyarrow::IntoPyArrow">IntoPyArrow</a> for T<span class="where fmt-newline">where
-    T: <a class="trait" href="../pyarrow/trait.ToPyArrow.html" title="trait arrow::pyarrow::ToPyArrow">ToPyArrow</a>,</span></h3></section></summary><div class="impl-items"><section id="method.into_pyarrow" class="method trait-impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#65-67">source</a><a href="#method.into_pyarrow" class="anchor">§</a><h4 class="code-header">fn <a href="../pyarrow/trait.IntoPyArrow.html#tymethod.into_pyarrow" class="fn">into_pyarrow</a>(self, p [...]
+</div></details></div></details><details class="toggle implementors-toggle"><summary><section id="impl-IntoPyArrow-for-ArrayData" class="impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#100-104">source</a><a href="#impl-IntoPyArrow-for-ArrayData" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="../pyarrow/trait.IntoPyArrow.html" title="trait arrow::pyarrow::IntoPyArrow">IntoPyArrow</a> for T<span class="where fmt-newline">where
+    T: <a class="trait" href="../pyarrow/trait.ToPyArrow.html" title="trait arrow::pyarrow::ToPyArrow">ToPyArrow</a>,</span></h3></section></summary><div class="impl-items"><section id="method.into_pyarrow" class="method trait-impl"><a class="src rightside" href="../../src/arrow/pyarrow.rs.html#101-103">source</a><a href="#method.into_pyarrow" class="anchor">§</a><h4 class="code-header">fn <a href="../pyarrow/trait.IntoPyArrow.html#tymethod.into_pyarrow" class="fn">into_pyarrow</a>(self, [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Owned" class="associatedtype trait-impl"><a href="#associatedtype.Owned" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/alloc/borrow/trait.ToOwned.html#associatedtype.Owned" class="associat [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.Into.html" title="trait core::convert::Into">Into</a>&lt;T&gt;,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error-1" class="associatedtype trait-impl"><a href="#associatedtype.Error-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" c [...]
     U: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::convert::TryFrom">TryFrom</a>&lt;T&gt;,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryInto.html#associatedtype.Err [...]
diff --git a/arrow/array/struct.ArrayDataBuilder.html b/arrow/array/struct.ArrayDataBuilder.html
index 7744c2d657..fc8df95b77 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="../. [...]
     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>,
     null_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.ArrayIter.html b/arrow/array/struct.ArrayIter.html
index a11536c31e..a32622948d 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=" [...]
     T: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>,</span>{
     array: T,
     logical_nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
diff --git a/arrow/array/struct.BooleanArray.html b/arrow/array/struct.BooleanArray.html
index 56ff1f2161..3f32a66c51 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 [...]
     values: <a class="struct" href="../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#fixed-size-primitive-layout">boolean values</a></p>
@@ -80,7 +80,7 @@ When using this function on a slice, the index is relative to the slice. <a href
 When using this function on a slice, the index is relative to the slice. <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#252">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp [...]
     &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;,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary>< [...]
     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;,</span></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#226">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 7f5a81a14d..08db0fa4af 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=". [...]
     buffer: <a class="struct" href="../buffer/struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer"><code>BooleanBuffer</code></a></p>
diff --git a/arrow/array/struct.BooleanBuilder.html b/arrow/array/struct.BooleanBuilder.html
index 4f469ecac6..d7b0a008f7 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 [...]
     values_builder: <a class="struct" href="struct.BooleanBufferBuilder.html" title="struct arrow::array::BooleanBufferBuilder">BooleanBufferBuilder</a>,
     null_buffer_builder: <a class="struct" href="../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="struct.BooleanArray.html" title="struct arrow::array::BooleanArray"><code>BooleanArray</code></a></p>
diff --git a/arrow/array/struct.BufferBuilder.html b/arrow/array/struct.BufferBuilder.html
index 565ee25c9f..6443bafa4e 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 [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span>{
     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.DataTypeLayout.html b/arrow/array/struct.DataTypeLayout.html
index 6ca3accde3..e3e4c9a75c 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 [...]
     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>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;,
     pub can_contain_null_mask: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Layout specification for a data type</p>
diff --git a/arrow/array/struct.DictionaryArray.html b/arrow/array/struct.DictionaryArray.html
index 76ed9d42b9..1fcb71797e 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 [...]
     K: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span>{
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     keys: <a class="struct" href="struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;K&gt;,
@@ -182,7 +182,7 @@ When using this function on a slice, the index is relative to the slice. <a href
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#578">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::array::A [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#626">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of strings.</p>
-<h4 id="example-2"><a href="#example-2">Example:</a></h4>
+<h4 id="example-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">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>];
@@ -191,10 +191,10 @@ When using this function on a slice, the index is relative to the slice. <a href
     <span class="string">&quot;DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  1,\n  2,\n] values: StringArray\n[\n  \&quot;a\&quot;,\n  \&quot;b\&quot;,\n  \&quot;c\&quot;,\n]}\n&quot;</span>,
     <span class="macro">format!</span>(<span class="string">&quot;{:?}&quot;</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#679">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#679">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 = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,</span></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.f [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></h3></section></summary><div class="docblock"><p>Constructs a <code>DictionaryArray</code> from an iterator of optional strings.</p>
-<h4 id="example-1"><a href="#example-1">Example:</a></h4>
+<h4 id="example-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">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>];
@@ -206,7 +206,7 @@ When using this function on a slice, the index is relative to the slice. <a href
     <span class="string">&quot;DictionaryArray {keys: PrimitiveArray&lt;Int8&gt;\n[\n  0,\n  0,\n  null,\n  1,\n] values: StringArray\n[\n  \&quot;a\&quot;,\n  \&quot;c\&quot;,\n]}\n&quot;</span>,
     <span class="macro">format!</span>(<span class="string">&quot;{:?}&quot;</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#655">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#655">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 = <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;,</span></h4></section></summary><div class='docblock [...]
     K: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#464">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc [...]
 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#226">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 aecba2d793..488d4f710c 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 [...]
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     value_data: <a class="struct" href="../buffer/struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -130,8 +130,8 @@ When using this function on a slice, the index is relative to the slice. <a href
 ) -&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-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#499">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 [...]
+) -&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#499">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#226">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="small-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" 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>,</span></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#136">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
diff --git a/arrow/array/struct.FixedSizeBinaryBuilder.html b/arrow/array/struct.FixedSizeBinaryBuilder.html
index 51b4548f40..81a8481e91 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 [...]
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::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>,
     value_length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>,
diff --git a/arrow/array/struct.FixedSizeListArray.html b/arrow/array/struct.FixedSizeListArray.html
index fbd89e8d09..f2bcf076e2 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" [...]
     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>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -137,15 +137,15 @@ The buffers store bytes in the Arrow memory format, and include the data as well
 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#193">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=" [...]
 When using this function on a slice, the index is relative to the slice. <a href="trait.Array.html#method.is_null">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.is_valid" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#233">source</a><a href="#method.is_valid" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_valid" class="fn">is_valid</a>(&amp;self, in [...]
-When using this function on a slice, the index is relative to the slice. <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#252">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp [...]
+When using this function on a slice, the index is relative to the slice. <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#252">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp [...]
     &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-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#499">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>,</span></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#397">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nig [...]
+) -&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#499">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>,</span></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#397">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#226">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="small-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=" [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></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#136">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
diff --git a/arrow/array/struct.FixedSizeListBuilder.html b/arrow/array/struct.FixedSizeListBuilder.html
index 3a7ad8b5e2..2da8f9e5f5 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 [...]
     T: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::ArrayBuilder">ArrayBuilder</a>,</span>{
     null_buffer_builder: <a class="struct" href="../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
     values_builder: T,
diff --git a/arrow/array/struct.GenericByteArray.html b/arrow/array/struct.GenericByteArray.html
index 643b015f83..e0a0bf3604 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 [...]
     T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span>{
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     value_offsets: <a class="struct" href="../buffer/struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer">OffsetBuffer</a>&lt;&lt;T as <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
@@ -148,39 +148,39 @@ When using this function on a slice, the index is relative to the slice. <a href
 ) -&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>,</span></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/ [...]
     T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span></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#420">source</a><a href="#method.fmt" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-9" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/byte_array.rs.html#493">source</a><a href="#method.from-9" 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>,</span></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#81">source</a><a href="#method.from-4" 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>,</span></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#493">source</a><a href="#method.from-3" 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>,</span></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#81">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
     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>,</span></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/binary_array.rs.html#128">source</a><a href="#method.from-3" 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>,</span></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#128">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
     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>,</span></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/byte_array.rs.html#523">source</a><a href="#method.from-6" 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>,</span></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#73">source</a><a href="#method.from-11" 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>,</span></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#523">source</a><a href="#method.from-4" 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>,</span></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#73">source</a><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
     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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-10" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#120">source</a><a href="#method.from-10" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#114">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
+    T: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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#120">source</a><a href="#method.from-9" 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>,</span></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#114">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang [...]
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>], <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;
 ) -&gt; <a class="struct" href="struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../datatypes/struct.GenericBinaryType.html" title="struct arrow::datatypes::GenericBinaryType">GenericBinaryType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>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>,</span></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#95">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>,</span></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#108">source</a><a href="#method.from-8" 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>,</span></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#95">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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#108">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
     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;, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glo [...]
 ) -&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>,</span></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#89">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>,</span></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#89">source</a><a href="#method.from-5" 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.str.html">str</a>&gt;, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glo [...]
 ) -&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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/string_array.rs.html#103">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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#103">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
     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;, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Glo [...]
 ) -&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>,</span></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#109">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
     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="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&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="../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,</span></h3></section></summary><div clas [...]
+    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,</span></h3></section></summary><div clas [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &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;,</span></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/ [...]
     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;,</span></h3></section></summary><div class="im [...]
+    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;,</span></h3></section></summary><div class="im [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;Ptr&gt;&gt;,</span></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/c [...]
     T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item-1" class="associatedtype trait-impl"><a href="#associatedtype.Item-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associatedtype.Item"  [...]
     OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.eq-1" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#482">source</a><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/co [...]
diff --git a/arrow/array/struct.GenericByteBuilder.html b/arrow/array/struct.GenericByteBuilder.html
index bc8268ed8f..7615ad8111 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=" [...]
     T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</span>{
     value_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::BufferBuilder">BufferBuilder</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::BufferBuilder">BufferBuilder</a>&lt;&lt;T as <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ByteArrayType.html#associatedtype.Offset" title="type arrow::datatypes::ByteArrayType::Offset">Offset</a>&gt;,
diff --git a/arrow/array/struct.GenericByteDictionaryBuilder.html b/arrow/array/struct.GenericByteDictionaryBuilder.html
index 3a824d6665..341d87943c 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= [...]
     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>,</span>{
     state: RandomState,
diff --git a/arrow/array/struct.GenericByteRunBuilder.html b/arrow/array/struct.GenericByteRunBuilder.html
index 609ef6cd65..6234119192 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 [...]
     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>,</span>{
     run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;,
diff --git a/arrow/array/struct.GenericListArray.html b/arrow/array/struct.GenericListArray.html
index 34bcc578b4..27a07f464f 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 [...]
     OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span>{
     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;,
@@ -142,13 +142,13 @@ When using this function on a slice, the index is relative to the slice. <a href
 ) -&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>,</span></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/n [...]
     OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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#531">source</a><a href="#method.fmt" 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>,</span></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#374">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nig [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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#397">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>,</span></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#382">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>,</span></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#73">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>,</span></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>,</span></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#397">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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-4" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/list_array.rs.html#382">source</a><a href="#method.from-4" 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>,</span></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#73">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.or [...]
     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>,</span></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/binary_array.rs.html#120">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightl [...]
+    T: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-5" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/binary_array.rs.html#120">source</a><a href="#method.from-5" 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>,</span></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#494">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/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#226">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="small-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">i [...]
diff --git a/arrow/array/struct.GenericListBuilder.html b/arrow/array/struct.GenericListBuilder.html
index 6fd602464b..e953888308 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=" [...]
     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::ArrayBuilder">ArrayBuilder</a>,</span>{
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::BufferBuilder">BufferBuilder</a>&lt;OffsetSize&gt;,
diff --git a/arrow/array/struct.MapArray.html b/arrow/array/struct.MapArray.html
index 253aa6396e..058f30bac3 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 [...]
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
     entries: <a class="struct" href="struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a>,
@@ -74,7 +74,7 @@ When using this function on a slice, the index is relative to the slice. <a href
 When using this function on a slice, the index is relative to the slice. <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#252">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp [...]
     &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#226">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="small-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-lan [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></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#136">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
diff --git a/arrow/array/struct.MapBuilder.html b/arrow/array/struct.MapBuilder.html
index a3d44f6255..75924686ee 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 [...]
     K: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::ArrayBuilder">ArrayBuilder</a>,
     V: <a class="trait" href="trait.ArrayBuilder.html" title="trait arrow::array::ArrayBuilder">ArrayBuilder</a>,</span>{
     offsets_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::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/struct.MapFieldNames.html b/arrow/array/struct.MapFieldNames.html
index 50d67cb3ef..d5d8bf4bbf 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=". [...]
     pub entry: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
     pub key: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
     pub value: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
diff --git a/arrow/array/struct.MutableArrayData.html b/arrow/array/struct.MutableArrayData.html
index a9e720699a..00e9a827e1 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. [...]
     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>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;,
     data: <a class="struct" href="../../arrow_data/transform/struct._MutableArrayData.html" title="struct arrow_data::transform::_MutableArrayData">_MutableArrayData</a>&lt;'a&gt;,
     dictionary: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>&gt;,
diff --git a/arrow/array/struct.NativeAdapter.html b/arrow/array/struct.NativeAdapter.html
index c1109cdb23..3d98776eb8 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 [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span>{
     pub native: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;T as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An optional primitive value</p>
@@ -10,8 +10,8 @@ the type can be collected to <code>PrimitiveArray</code>.</p>
 </div><h2 id="trait-implementations" class="small-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#1162">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-header" [...]
     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>,</span></h3></section></summary><div cla [...]
-    T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-14" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1205">source</a><a href="#method.from-14" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-9" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1197">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="ht [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></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/primitive_array.rs.html#1205">source</a><a href="#method.from" 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>,</span></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/primitive_array.rs.html#1197">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="ht [...]
     &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>,</span></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 5352637b4a..34c9f9a58b 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 [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>An array of <a href="https://arrow.apache.org/docs/format/Columnar.html#null-layout">null values</a></p>
 <p>A <code>NullArray</code> is a simplified array where all values are null.</p>
diff --git a/arrow/array/struct.NullBuilder.html b/arrow/array/struct.NullBuilder.html
index 1b2511734d..5762e41100 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 [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Builder for <a href="struct.NullArray.html" title="struct arrow::array::NullArray"><code>NullArray</code></a></p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/array/struct.PrimitiveArray.html b/arrow/array/struct.PrimitiveArray.html
index 78aca9b4ab..5da6211a71 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="../../ [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span>{
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     values: <a class="struct" href="../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;&lt;T as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
@@ -256,126 +256,126 @@ When using this function on a slice, the index is relative to the slice. <a href
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></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#485">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>,</span></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#1088">source</a><a href="#method.fmt" 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>,</span></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-15" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1387">source</a><a href="#method.from-15" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow::ar [...]
-    T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-38" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#972">source</a><a href="#method.from-38" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-54" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1387">source</a><a href="#method.from-54" 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>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-40" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/primitive_array.rs.html#972">source</a><a href="#method.from-40" class="anchor">§</a><h4 class="code-header">fn <a href="h [...]
     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 [...]
+) -&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 63363bf9f3..bf493663fe 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="../. [...]
     T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span>{
     values_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::BufferBuilder">BufferBuilder</a>&lt;&lt;T as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
     null_buffer_builder: <a class="struct" href="../../arrow_buffer/builder/null/struct.NullBufferBuilder.html" title="struct arrow_buffer::builder::null::NullBufferBuilder">NullBufferBuilder</a>,
diff --git a/arrow/array/struct.PrimitiveDictionaryBuilder.html b/arrow/array/struct.PrimitiveDictionaryBuilder.html
index 60bf700e54..cc50286a88 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 [...]
     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>,</span>{
     keys_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::PrimitiveBuilder">PrimitiveBuilder</a>&lt;K&gt;,
diff --git a/arrow/array/struct.PrimitiveRunBuilder.html b/arrow/array/struct.PrimitiveRunBuilder.html
index cd235ee573..d48c86960f 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 [...]
     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>,</span>{
     run_ends_builder: <a class="struct" href="struct.PrimitiveBuilder.html" title="struct arrow::array::PrimitiveBuilder">PrimitiveBuilder</a>&lt;R&gt;,
diff --git a/arrow/array/struct.RunArray.html b/arrow/array/struct.RunArray.html
index 0b7abb4b39..a86382336a 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="../../ [...]
     R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span>{
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     run_ends: <a class="struct" href="../buffer/struct.RunEndBuffer.html" title="struct arrow::buffer::RunEndBuffer">RunEndBuffer</a>&lt;&lt;R as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
diff --git a/arrow/array/struct.StructArray.html b/arrow/array/struct.StructArray.html
index 733d17be8c..7049cf6d1a 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 [...]
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     nulls: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.NullBuffer.html" title="struct arrow::buffer::NullBuffer">NullBuffer</a>&gt;,
@@ -98,9 +98,9 @@ The buffers store bytes in the Arrow memory format, and include the data as well
 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#193">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=" [...]
 When using this function on a slice, the index is relative to the slice. <a href="trait.Array.html#method.is_null">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.is_valid" class="method trait-impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#233">source</a><a href="#method.is_valid" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_valid" class="fn">is_valid</a>(&amp;self, in [...]
-When using this function on a slice, the index is relative to the slice. <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#252">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp [...]
+When using this function on a slice, the index is relative to the slice. <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#252">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp [...]
     pair: (<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;<a class="struct" href="../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc:: [...]
-) -&gt; <a class="struct" href="struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CArrayData%3E-for-StructArray" class="impl"><a class="src rightside" href="../../src/arrow_array/array/struct_array.rs.html#279">source</a><a href="#impl-From%3CArrayData%3E-fo [...]
+) -&gt; <a class="struct" href="struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From%3CArrayData%3E-for-StructArray" class="impl"><a class="src rightside" href="../../src/arrow_array/array/struct_array.rs.html#279">source</a><a href="#impl-From%3CArrayData%3E-fo [...]
     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="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;<a class="struct" href="../datatypes/struct.Field.html" title="struct arrow::datatypes::Field">Field</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
 ) -&gt; <a class="struct" href="struct.StructArray.html" title="struct arrow::array::StructArray">StructArray</a></h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Index%3C%26str%3E-for-StructArray" class="impl"><a class="src rightside" href="../../src/arrow_array/array/struct_array.rs.html#427">source</a><a href="#impl-Index%3C%26str%3E-for-St [...]
 <p>Note: A schema can currently have duplicate field names, in which case
diff --git a/arrow/array/struct.StructBuilder.html b/arrow/array/struct.StructBuilder.html
index 44deea1007..f7ae821c45 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 [...]
     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::ArrayBuilder">ArrayBuilder</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct [...]
     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.TypedDictionaryArray.html b/arrow/array/struct.TypedDictionaryArray.html
index a2abf2efba..66fd04fbbf 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 [...]
     K: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span>{
     dictionary: &amp;'a <a class="struct" href="struct.DictionaryArray.html" title="struct arrow::array::DictionaryArray">DictionaryArray</a>&lt;K&gt;,
     values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>,
diff --git a/arrow/array/struct.TypedRunArray.html b/arrow/array/struct.TypedRunArray.html
index 9b3f703ce0..909a08f070 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 [...]
     R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span>{
     run_array: &amp;'a <a class="struct" href="struct.RunArray.html" title="struct arrow::array::RunArray">RunArray</a>&lt;R&gt;,
     values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>,
diff --git a/arrow/array/struct.UnionArray.html b/arrow/array/struct.UnionArray.html
index 3acae4b930..0ba7ff9b99 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="../ [...]
     data_type: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     type_ids: <a class="struct" href="../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>&gt;,
     offsets: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../buffer/struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>&gt;&gt;,
diff --git a/arrow/array/struct.UnionBuilder.html b/arrow/array/struct.UnionBuilder.html
index 9f67809eff..5c3e20ce04 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 [...]
     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>, <a cl [...]
     type_id_builder: <a class="struct" href="struct.BufferBuilder.html" title="struct arrow::array::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/trait.AnyDictionaryArray.html b/arrow/array/trait.AnyDictionaryArray.html
index ca73c7d6b4..457027c4f4 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 [...]
     // Required methods
     fn <a href="#tymethod.keys" class="fn">keys</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>;
 <span class="item-spacer"></span>    fn <a href="#tymethod.values" class="fn">values</a>(&amp;self) -&gt; &amp;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;;
diff --git a/arrow/array/trait.Array.html b/arrow/array/trait.Array.html
index cd82dd99e8..0124e33458 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="../../ [...]
 <details class="toggle type-contents-toggle"><summary class="hideme"><span>Show 16 methods</span></summary>    // Required methods
     fn <a href="#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static);
 <span class="item-spacer"></span>    fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="struct.ArrayData.html" title="struct arrow::array::ArrayData">ArrayData</a>;
@@ -149,13 +149,13 @@ 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>,</span></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" h [...]
     O: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></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 rig [...]
     K: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</span></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="meth [...]
-    T: <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>,</span></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#446">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#226">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%3Cdyn+Array+%2B+'_%3E-for-dyn+Array+%2B+'_" class="impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#439">source</a><a href="#impl-PartialEq%3Cdyn+Array+%2B+'_%3E-for-dyn+Array+%2B+'_" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.or [...]
+    T: <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>,</span></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#446">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" cl [...]
 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#226">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="small-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,+Global%3E" class="impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#283">source</a><a href="#impl-Array-for-Arc%3Cdyn+Array,+Glob [...]
-</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#284">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>,</span></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#350">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/nig [...]
+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%3Cdyn+Array+%2B+'_%3E-for-dyn+Array+%2B+'_" class="impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#439">source</a><a href="#impl-PartialEq%3Cdyn+Array+%2B+'_%3E-for-dyn+Array+%2B+'_" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.or [...]
+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#226">source</a></span><a href="#method.ne-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" cl [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="foreign-impls" class="small-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-%26'a+T" class="impl"><a class="src rightside" href="../../src/arrow_array/array/mod.rs.html#349">source</a><a href="#impl-Array-for-%26'a+T" class="anchor">§</a><h3 class=" [...]
+    T: <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>,</span></h3></section></summary><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#350">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 [...]
+</div><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#284">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/nightly/core/any/trait.Any.html" title="trait core::any::Any">Any</a> + 'static)</h4></section><section id="method.to_dat [...]
     K: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</span></h3></section><section id="impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a class="src rightside" href="../../src/arrow_array/array/run_array.rs.html#569">source</a><a href="#impl-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="trait.Array.html" title="trait  [...]
     R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,
diff --git a/arrow/array/trait.ArrayAccessor.html b/arrow/array/trait.ArrayAccessor.html
index 11fb53b483..c2659efabc 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" [...]
     type <a href="#associatedtype.Item" class="associatedtype">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>;
 
     // Required methods
diff --git a/arrow/array/trait.ArrayBuilder.html b/arrow/array/trait.ArrayBuilder.html
index b0348b7886..75906a9add 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 [...]
     // Required methods
     fn <a href="#tymethod.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>;
 <span class="item-spacer"></span>    fn <a href="#tymethod.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;;
diff --git a/arrow/array/trait.ArrowPrimitiveType.html b/arrow/array/trait.ArrowPrimitiveType.html
index bc9d41a3e9..f497dc91e2 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 [...]
     type <a href="#associatedtype.Native" class="associatedtype">Native</a>: <a class="trait" href="../datatypes/trait.ArrowNativeTypeOp.html" title="trait arrow::datatypes::ArrowNativeTypeOp">ArrowNativeTypeOp</a>;
 
     const <a href="#associatedconstant.DATA_TYPE" class="constant">DATA_TYPE</a>: <a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>;
diff --git a/arrow/array/trait.AsArray.html b/arrow/array/trait.AsArray.html
index faff83397d..ffc86c843f 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 [...]
 <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;;
 <span class="item-spacer"></span>    fn <a href="#tymethod.as_primitive_opt" class="fn">as_primitive_opt</a>&lt;T&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="struct" href="struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;&gt;
diff --git a/arrow/array/trait.OffsetSizeTrait.html b/arrow/array/trait.OffsetSizeTrait.html
index 6ea1a1e677..c51d8bef11 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 [...]
     const <a href="#associatedconstant.IS_LARGE" class="constant">IS_LARGE</a>: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>;
     const <a href="#associatedconstant.PREFIX" class="constant">PREFIX</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>;
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A type that can be used within a variable-size array to encode offset information</p>
diff --git a/arrow/array/type.ArrayDataRef.html b/arrow/array/type.ArrayDataRef.html
index 9aef063ac4..84731ebbcb 100644
--- a/arrow/array/type.ArrayDataRef.html
+++ b/arrow/array/type.ArrayDataRef.html
@@ -1 +1 @@
-<!DOCTYPE html><html lang="en"><head><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 [...]
\ No newline at end of file
+<!DOCTYPE html><html lang="en"><head><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 [...]
\ No newline at end of file
diff --git a/arrow/array/type.ArrayRef.html b/arrow/array/type.ArrayRef.html
index 96731ba324..abeb0fe271 100644
--- a/arrow/array/type.ArrayRef.html
+++ b/arrow/array/type.ArrayRef.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.BinaryArray.html b/arrow/array/type.BinaryArray.html
index da66d5ee3d..1262d37372 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 [...]
 <p>The byte length of each element is represented by an i32.</p>
 <h2 id="examples"><a href="#examples">Examples</a></h2>
 <p>Create a BinaryArray from a vector of byte slices.</p>
diff --git a/arrow/array/type.BinaryBuilder.html b/arrow/array/type.BinaryBuilder.html
index 2793bdf4a2..7fd8fb1366 100644
--- a/arrow/array/type.BinaryBuilder.html
+++ b/arrow/array/type.BinaryBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.BinaryDictionaryBuilder.html b/arrow/array/type.BinaryDictionaryBuilder.html
index 2abdb6f0d3..f5a6cce6b5 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 [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create a dictionary array indexed by bytes whose values are binary.
 // It can thus hold up to 256 distinct binary values.
diff --git a/arrow/array/type.BinaryRunBuilder.html b/arrow/array/type.BinaryRunBuilder.html
index 4c5d0edf02..85e85822c9 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 [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create a run-end encoded array with run-end indexes data type as `i16`.
 // The encoded data is binary values.
diff --git a/arrow/array/type.BooleanIter.html b/arrow/array/type.BooleanIter.html
index 7278d860ff..51237786a2 100644
--- a/arrow/array/type.BooleanIter.html
+++ b/arrow/array/type.BooleanIter.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Date32Array.html b/arrow/array/type.Date32Array.html
index 1cc51edc64..7dd2a835ce 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 [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/date/struct.NaiveDate.html" title="struct chrono::naive::date::NaiveDate"><code>chrono::NaiveDate</code></a> type and can hold
 values such as <code>2018-11-13</code></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Date32BufferBuilder.html b/arrow/array/type.Date32BufferBuilder.html
index 68a6e1f786..03deeab7c6 100644
--- a/arrow/array/type.Date32BufferBuilder.html
+++ b/arrow/array/type.Date32BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Date32Builder.html b/arrow/array/type.Date32Builder.html
index 7648701771..4deb755a1f 100644
--- a/arrow/array/type.Date32Builder.html
+++ b/arrow/array/type.Date32Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Date64Array.html b/arrow/array/type.Date64Array.html
index ca461fcc1b..12ef5efb6a 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=" [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/date/struct.NaiveDate.html" title="struct chrono::naive::date::NaiveDate"><code>chrono::NaiveDate</code></a> type and can hold
 values such as <code>2018-11-13</code></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Date64BufferBuilder.html b/arrow/array/type.Date64BufferBuilder.html
index 44a562b411..d4b60e85f1 100644
--- a/arrow/array/type.Date64BufferBuilder.html
+++ b/arrow/array/type.Date64BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Date64Builder.html b/arrow/array/type.Date64Builder.html
index a3f08aef1d..03928f831a 100644
--- a/arrow/array/type.Date64Builder.html
+++ b/arrow/array/type.Date64Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Decimal128Array.html b/arrow/array/type.Decimal128Array.html
index 4fd78089fb..2dbae1030a 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 [...]
 <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 89ddbbe43d..83b7d8128b 100644
--- a/arrow/array/type.Decimal128BufferBuilder.html
+++ b/arrow/array/type.Decimal128BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Decimal128Builder.html b/arrow/array/type.Decimal128Builder.html
index 9bd1f34a8b..8bb7a2efc7 100644
--- a/arrow/array/type.Decimal128Builder.html
+++ b/arrow/array/type.Decimal128Builder.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="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="../. [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Decimal256Array.html b/arrow/array/type.Decimal256Array.html
index 4a931ec7e5..96b425eaad 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 [...]
 <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 67d19e7413..41fba85915 100644
--- a/arrow/array/type.Decimal256BufferBuilder.html
+++ b/arrow/array/type.Decimal256BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Decimal256Builder.html b/arrow/array/type.Decimal256Builder.html
index 068b638fc8..14558b24a0 100644
--- a/arrow/array/type.Decimal256Builder.html
+++ b/arrow/array/type.Decimal256Builder.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="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="../. [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationMicrosecondArray.html b/arrow/array/type.DurationMicrosecondArray.html
index 47068ed5d9..ee146e4e9f 100644
--- a/arrow/array/type.DurationMicrosecondArray.html
+++ b/arrow/array/type.DurationMicrosecondArray.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="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= [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationMicrosecondBufferBuilder.html b/arrow/array/type.DurationMicrosecondBufferBuilder.html
index e526d85e19..4bf74415d9 100644
--- a/arrow/array/type.DurationMicrosecondBufferBuilder.html
+++ b/arrow/array/type.DurationMicrosecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationMicrosecondBuilder.html b/arrow/array/type.DurationMicrosecondBuilder.html
index 5a2ee1c649..60b2f42c24 100644
--- a/arrow/array/type.DurationMicrosecondBuilder.html
+++ b/arrow/array/type.DurationMicrosecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationMillisecondArray.html b/arrow/array/type.DurationMillisecondArray.html
index 9c5423b50d..94b2105e99 100644
--- a/arrow/array/type.DurationMillisecondArray.html
+++ b/arrow/array/type.DurationMillisecondArray.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="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= [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationMillisecondBufferBuilder.html b/arrow/array/type.DurationMillisecondBufferBuilder.html
index 32d10e6bda..dd4ee468d3 100644
--- a/arrow/array/type.DurationMillisecondBufferBuilder.html
+++ b/arrow/array/type.DurationMillisecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationMillisecondBuilder.html b/arrow/array/type.DurationMillisecondBuilder.html
index 008d5754c6..e638d0609c 100644
--- a/arrow/array/type.DurationMillisecondBuilder.html
+++ b/arrow/array/type.DurationMillisecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationNanosecondArray.html b/arrow/array/type.DurationNanosecondArray.html
index a874867a1d..ac8e9c5ab9 100644
--- a/arrow/array/type.DurationNanosecondArray.html
+++ b/arrow/array/type.DurationNanosecondArray.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationNanosecondBufferBuilder.html b/arrow/array/type.DurationNanosecondBufferBuilder.html
index 1b271a2e33..4062ccce62 100644
--- a/arrow/array/type.DurationNanosecondBufferBuilder.html
+++ b/arrow/array/type.DurationNanosecondBufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationNanosecondBuilder.html b/arrow/array/type.DurationNanosecondBuilder.html
index faad153f7f..3a9b66a394 100644
--- a/arrow/array/type.DurationNanosecondBuilder.html
+++ b/arrow/array/type.DurationNanosecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationSecondArray.html b/arrow/array/type.DurationSecondArray.html
index 43b7faeaf6..6c87265dbf 100644
--- a/arrow/array/type.DurationSecondArray.html
+++ b/arrow/array/type.DurationSecondArray.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationSecondBufferBuilder.html b/arrow/array/type.DurationSecondBufferBuilder.html
index 0fa65d3599..7def99fc9f 100644
--- a/arrow/array/type.DurationSecondBufferBuilder.html
+++ b/arrow/array/type.DurationSecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DurationSecondBuilder.html b/arrow/array/type.DurationSecondBuilder.html
index bf31fe8984..806360a163 100644
--- a/arrow/array/type.DurationSecondBuilder.html
+++ b/arrow/array/type.DurationSecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.DynComparator.html b/arrow/array/type.DynComparator.html
index 091366c691..94332fe0bf 100644
--- a/arrow/array/type.DynComparator.html
+++ b/arrow/array/type.DynComparator.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.FixedSizeBinaryIter.html b/arrow/array/type.FixedSizeBinaryIter.html
index dab59a611a..d14a2bf653 100644
--- a/arrow/array/type.FixedSizeBinaryIter.html
+++ b/arrow/array/type.FixedSizeBinaryIter.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.FixedSizeListIter.html b/arrow/array/type.FixedSizeListIter.html
index d8a4e42776..79565c2ae0 100644
--- a/arrow/array/type.FixedSizeListIter.html
+++ b/arrow/array/type.FixedSizeListIter.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Float16Array.html b/arrow/array/type.Float16Array.html
index 545fdddac0..73c5245d95 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 [...]
 <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 f15bd15d49..e83a75004d 100644
--- a/arrow/array/type.Float16BufferBuilder.html
+++ b/arrow/array/type.Float16BufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Float16Builder.html b/arrow/array/type.Float16Builder.html
index 6449f4b302..5b823e4039 100644
--- a/arrow/array/type.Float16Builder.html
+++ b/arrow/array/type.Float16Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Float32Array.html b/arrow/array/type.Float32Array.html
index 5884f78b10..ae8f23bc8c 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 [...]
 <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 f8901c5a7f..b50340ae1c 100644
--- a/arrow/array/type.Float32BufferBuilder.html
+++ b/arrow/array/type.Float32BufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Float32Builder.html b/arrow/array/type.Float32Builder.html
index 0c67b63e13..34758fda05 100644
--- a/arrow/array/type.Float32Builder.html
+++ b/arrow/array/type.Float32Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Float64Array.html b/arrow/array/type.Float64Array.html
index 12133ca2e9..9d228da68b 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 [...]
 <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 c4b66b117b..6db65b38a2 100644
--- a/arrow/array/type.Float64BufferBuilder.html
+++ b/arrow/array/type.Float64BufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Float64Builder.html b/arrow/array/type.Float64Builder.html
index 7e145d5d20..bbc22461d9 100644
--- a/arrow/array/type.Float64Builder.html
+++ b/arrow/array/type.Float64Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.GenericBinaryArray.html b/arrow/array/type.GenericBinaryArray.html
index 6af52a27ef..74ea24a61f 100644
--- a/arrow/array/type.GenericBinaryArray.html
+++ b/arrow/array/type.GenericBinaryArray.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.GenericBinaryBuilder.html b/arrow/array/type.GenericBinaryBuilder.html
index 849f78cb5c..54247e0f0b 100644
--- a/arrow/array/type.GenericBinaryBuilder.html
+++ b/arrow/array/type.GenericBinaryBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.GenericBinaryIter.html b/arrow/array/type.GenericBinaryIter.html
index 79c6266ff3..b1a742d84b 100644
--- a/arrow/array/type.GenericBinaryIter.html
+++ b/arrow/array/type.GenericBinaryIter.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.GenericListArrayIter.html b/arrow/array/type.GenericListArrayIter.html
index 434be845ae..ea27b8084f 100644
--- a/arrow/array/type.GenericListArrayIter.html
+++ b/arrow/array/type.GenericListArrayIter.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="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" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.GenericStringArray.html b/arrow/array/type.GenericStringArray.html
index a465b9a407..686f449c1c 100644
--- a/arrow/array/type.GenericStringArray.html
+++ b/arrow/array/type.GenericStringArray.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.GenericStringBuilder.html b/arrow/array/type.GenericStringBuilder.html
index cb07954bf4..153b28df94 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 [...]
 <p>Values can be appended using <a href="struct.GenericByteBuilder.html#method.append_value" title="method arrow::array::GenericByteBuilder::append_value"><code>GenericByteBuilder::append_value</code></a>, and nulls with
 <a href="struct.GenericByteBuilder.html#method.append_null" title="method arrow::array::GenericByteBuilder::append_null"><code>GenericByteBuilder::append_null</code></a> as normal.</p>
 <p>Additionally implements <a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write"><code>std::fmt::Write</code></a> with any written data included in the next
diff --git a/arrow/array/type.GenericStringIter.html b/arrow/array/type.GenericStringIter.html
index e821fef468..bc8a8022e6 100644
--- a/arrow/array/type.GenericStringIter.html
+++ b/arrow/array/type.GenericStringIter.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int16Array.html b/arrow/array/type.Int16Array.html
index e49e156c55..c39e3d50c4 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 [...]
 <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 3bc648ea9f..7740330bc0 100644
--- a/arrow/array/type.Int16BufferBuilder.html
+++ b/arrow/array/type.Int16BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int16Builder.html b/arrow/array/type.Int16Builder.html
index 6abd639c75..43d122ba89 100644
--- a/arrow/array/type.Int16Builder.html
+++ b/arrow/array/type.Int16Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int16DictionaryArray.html b/arrow/array/type.Int16DictionaryArray.html
index fb57d465e6..8d08766826 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 [...]
 <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>
 <span class="kw">let </span>array: Int16DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.Int16RunArray.html b/arrow/array/type.Int16RunArray.html
index 3262db0081..ebdffa571f 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="../ [...]
 <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>
 <span class="kw">let </span>array: Int16RunArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.Int32Array.html b/arrow/array/type.Int32Array.html
index eccbd997f6..f37753081e 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 [...]
 <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 32c3dfe060..eeb3cdfb77 100644
--- a/arrow/array/type.Int32BufferBuilder.html
+++ b/arrow/array/type.Int32BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int32Builder.html b/arrow/array/type.Int32Builder.html
index dfe82804f1..2928abd91d 100644
--- a/arrow/array/type.Int32Builder.html
+++ b/arrow/array/type.Int32Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int32DictionaryArray.html b/arrow/array/type.Int32DictionaryArray.html
index d08556849d..4b76fcb3d6 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 [...]
 <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>
 <span class="kw">let </span>array: Int32DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.Int32RunArray.html b/arrow/array/type.Int32RunArray.html
index 1396d832e9..466685a25c 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="../ [...]
 <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>
 <span class="kw">let </span>array: Int32RunArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.Int64Array.html b/arrow/array/type.Int64Array.html
index 13aad22acd..fe501d97b4 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 [...]
 <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 a397f88dce..657116702a 100644
--- a/arrow/array/type.Int64BufferBuilder.html
+++ b/arrow/array/type.Int64BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int64Builder.html b/arrow/array/type.Int64Builder.html
index d90cd42369..2c8d988a88 100644
--- a/arrow/array/type.Int64Builder.html
+++ b/arrow/array/type.Int64Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int64DictionaryArray.html b/arrow/array/type.Int64DictionaryArray.html
index dd3fe5b25b..db6164f881 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 [...]
 <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>
 <span class="kw">let </span>array: Int64DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.Int64RunArray.html b/arrow/array/type.Int64RunArray.html
index 2eafe68996..b497636f65 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="../ [...]
 <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>
 <span class="kw">let </span>array: Int64RunArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.Int8Array.html b/arrow/array/type.Int8Array.html
index 1907b06b2b..91e820038f 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. [...]
 <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 efd95e4dfa..e3172b2314 100644
--- a/arrow/array/type.Int8BufferBuilder.html
+++ b/arrow/array/type.Int8BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int8Builder.html b/arrow/array/type.Int8Builder.html
index f6562e2cd7..dadc9ab907 100644
--- a/arrow/array/type.Int8Builder.html
+++ b/arrow/array/type.Int8Builder.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="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=" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Int8DictionaryArray.html b/arrow/array/type.Int8DictionaryArray.html
index 8057dfad0e..a12f025d7d 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  [...]
 <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>
 <span class="kw">let </span>array: Int8DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.IntervalDayTimeArray.html b/arrow/array/type.IntervalDayTimeArray.html
index 3ccdb6bede..618e6319d3 100644
--- a/arrow/array/type.IntervalDayTimeArray.html
+++ b/arrow/array/type.IntervalDayTimeArray.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalDayTimeBufferBuilder.html b/arrow/array/type.IntervalDayTimeBufferBuilder.html
index 413bccbf97..cc7a258232 100644
--- a/arrow/array/type.IntervalDayTimeBufferBuilder.html
+++ b/arrow/array/type.IntervalDayTimeBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalDayTimeBuilder.html b/arrow/array/type.IntervalDayTimeBuilder.html
index c805c7c2c3..4465b296bc 100644
--- a/arrow/array/type.IntervalDayTimeBuilder.html
+++ b/arrow/array/type.IntervalDayTimeBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalMonthDayNanoArray.html b/arrow/array/type.IntervalMonthDayNanoArray.html
index af406c8f4a..38151b4b50 100644
--- a/arrow/array/type.IntervalMonthDayNanoArray.html
+++ b/arrow/array/type.IntervalMonthDayNanoArray.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="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="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="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="pr [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalMonthDayNanoBufferBuilder.html b/arrow/array/type.IntervalMonthDayNanoBufferBuilder.html
index 2661313d55..d8c086affc 100644
--- a/arrow/array/type.IntervalMonthDayNanoBufferBuilder.html
+++ b/arrow/array/type.IntervalMonthDayNanoBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalMonthDayNanoBuilder.html b/arrow/array/type.IntervalMonthDayNanoBuilder.html
index 3ffca53917..56eff5d5da 100644
--- a/arrow/array/type.IntervalMonthDayNanoBuilder.html
+++ b/arrow/array/type.IntervalMonthDayNanoBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalYearMonthArray.html b/arrow/array/type.IntervalYearMonthArray.html
index ca5c8ec206..3dd5611b10 100644
--- a/arrow/array/type.IntervalYearMonthArray.html
+++ b/arrow/array/type.IntervalYearMonthArray.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalYearMonthBufferBuilder.html b/arrow/array/type.IntervalYearMonthBufferBuilder.html
index d6dae3ce25..44e31685f5 100644
--- a/arrow/array/type.IntervalYearMonthBufferBuilder.html
+++ b/arrow/array/type.IntervalYearMonthBufferBuilder.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="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= [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.IntervalYearMonthBuilder.html b/arrow/array/type.IntervalYearMonthBuilder.html
index a1987f83ce..7289cf10a0 100644
--- a/arrow/array/type.IntervalYearMonthBuilder.html
+++ b/arrow/array/type.IntervalYearMonthBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeBinaryArray.html b/arrow/array/type.LargeBinaryArray.html
index b27587eef6..6794485d01 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 [...]
 <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 fe045f0448..ee3feacb43 100644
--- a/arrow/array/type.LargeBinaryBuilder.html
+++ b/arrow/array/type.LargeBinaryBuilder.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="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=" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeBinaryDictionaryBuilder.html b/arrow/array/type.LargeBinaryDictionaryBuilder.html
index e36697403b..3a0ffab035 100644
--- a/arrow/array/type.LargeBinaryDictionaryBuilder.html
+++ b/arrow/array/type.LargeBinaryDictionaryBuilder.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="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= [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeBinaryRunBuilder.html b/arrow/array/type.LargeBinaryRunBuilder.html
index bf285598c9..71bc7b7c07 100644
--- a/arrow/array/type.LargeBinaryRunBuilder.html
+++ b/arrow/array/type.LargeBinaryRunBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeListArray.html b/arrow/array/type.LargeListArray.html
index 47af91053d..30b41531be 100644
--- a/arrow/array/type.LargeListArray.html
+++ b/arrow/array/type.LargeListArray.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeListBuilder.html b/arrow/array/type.LargeListBuilder.html
index 240c7eeffa..b51eb564fe 100644
--- a/arrow/array/type.LargeListBuilder.html
+++ b/arrow/array/type.LargeListBuilder.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="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="../. [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeStringArray.html b/arrow/array/type.LargeStringArray.html
index 44ccffb245..0df6565e4b 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" [...]
 <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 abe7eaaf59..a90eaf0c80 100644
--- a/arrow/array/type.LargeStringBuilder.html
+++ b/arrow/array/type.LargeStringBuilder.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="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=" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeStringDictionaryBuilder.html b/arrow/array/type.LargeStringDictionaryBuilder.html
index f581871a18..e322a5e619 100644
--- a/arrow/array/type.LargeStringDictionaryBuilder.html
+++ b/arrow/array/type.LargeStringDictionaryBuilder.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="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= [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.LargeStringRunBuilder.html b/arrow/array/type.LargeStringRunBuilder.html
index 45607ceab1..a12ed52a0d 100644
--- a/arrow/array/type.LargeStringRunBuilder.html
+++ b/arrow/array/type.LargeStringRunBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.ListArray.html b/arrow/array/type.ListArray.html
index 5abf9c1d5d..818e326a13 100644
--- a/arrow/array/type.ListArray.html
+++ b/arrow/array/type.ListArray.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="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= [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.ListBuilder.html b/arrow/array/type.ListBuilder.html
index effc8f44a0..0551ea4689 100644
--- a/arrow/array/type.ListBuilder.html
+++ b/arrow/array/type.ListBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.MapArrayIter.html b/arrow/array/type.MapArrayIter.html
index e1dc049510..5ff29dacdd 100644
--- a/arrow/array/type.MapArrayIter.html
+++ b/arrow/array/type.MapArrayIter.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.PrimitiveIter.html b/arrow/array/type.PrimitiveIter.html
index 15d88014d3..9091bf8633 100644
--- a/arrow/array/type.PrimitiveIter.html
+++ b/arrow/array/type.PrimitiveIter.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.StringArray.html b/arrow/array/type.StringArray.html
index 6db238e25b..b48d1fef9d 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 [...]
 <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 9247c20bce..cbe67e8879 100644
--- a/arrow/array/type.StringBuilder.html
+++ b/arrow/array/type.StringBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.StringDictionaryBuilder.html b/arrow/array/type.StringDictionaryBuilder.html
index 6c3956fc82..4ee010793d 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 [...]
 
 <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.
 // It can thus hold up to 256 distinct string values.
diff --git a/arrow/array/type.StringRunBuilder.html b/arrow/array/type.StringRunBuilder.html
index 95cec59642..665b7ca227 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 [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="comment">// Create a run-end encoded array with run-end indexes data type as `i16`.
 // The encoded values are Strings.
diff --git a/arrow/array/type.Time32MillisecondArray.html b/arrow/array/type.Time32MillisecondArray.html
index d797723378..71b6fd7942 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 [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00.123</code></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time32MillisecondBufferBuilder.html b/arrow/array/type.Time32MillisecondBufferBuilder.html
index d63adc06f2..2676aa78db 100644
--- a/arrow/array/type.Time32MillisecondBufferBuilder.html
+++ b/arrow/array/type.Time32MillisecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time32MillisecondBuilder.html b/arrow/array/type.Time32MillisecondBuilder.html
index fe0530654a..4bfd3c2767 100644
--- a/arrow/array/type.Time32MillisecondBuilder.html
+++ b/arrow/array/type.Time32MillisecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time32SecondArray.html b/arrow/array/type.Time32SecondArray.html
index 9017b4b82e..2d222396a6 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 [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00</code></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time32SecondBufferBuilder.html b/arrow/array/type.Time32SecondBufferBuilder.html
index ec50c8c285..52d5d29c19 100644
--- a/arrow/array/type.Time32SecondBufferBuilder.html
+++ b/arrow/array/type.Time32SecondBufferBuilder.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="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" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time32SecondBuilder.html b/arrow/array/type.Time32SecondBuilder.html
index 59d1b2b098..c3990721cf 100644
--- a/arrow/array/type.Time32SecondBuilder.html
+++ b/arrow/array/type.Time32SecondBuilder.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="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" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time64MicrosecondArray.html b/arrow/array/type.Time64MicrosecondArray.html
index ee7833d08d..f62ca94507 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 [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00.123456</code></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time64MicrosecondBufferBuilder.html b/arrow/array/type.Time64MicrosecondBufferBuilder.html
index 54576bd8e6..aec2110b18 100644
--- a/arrow/array/type.Time64MicrosecondBufferBuilder.html
+++ b/arrow/array/type.Time64MicrosecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time64MicrosecondBuilder.html b/arrow/array/type.Time64MicrosecondBuilder.html
index a6267ab642..07fdc3b6b9 100644
--- a/arrow/array/type.Time64MicrosecondBuilder.html
+++ b/arrow/array/type.Time64MicrosecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time64NanosecondArray.html b/arrow/array/type.Time64NanosecondArray.html
index 65f5e37f70..59946ccbae 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" [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/naive/time/struct.NaiveTime.html" title="struct chrono::naive::time::NaiveTime"><code>chrono::NaiveTime</code></a> type and can
 hold values such as <code>00:02:00.123456789</code></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time64NanosecondBufferBuilder.html b/arrow/array/type.Time64NanosecondBufferBuilder.html
index 478ea38b18..6521d23556 100644
--- a/arrow/array/type.Time64NanosecondBufferBuilder.html
+++ b/arrow/array/type.Time64NanosecondBufferBuilder.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="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=" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.Time64NanosecondBuilder.html b/arrow/array/type.Time64NanosecondBuilder.html
index 06146f6c8d..184b449aa0 100644
--- a/arrow/array/type.Time64NanosecondBuilder.html
+++ b/arrow/array/type.Time64NanosecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampMicrosecondArray.html b/arrow/array/type.TimestampMicrosecondArray.html
index 5df94cbb5a..fb140778de 100644
--- a/arrow/array/type.TimestampMicrosecondArray.html
+++ b/arrow/array/type.TimestampMicrosecondArray.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="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 [...]
 <p>See examples for <a href="type.TimestampSecondArray.html" title="type arrow::array::TimestampSecondArray"><code>TimestampSecondArray</code></a></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampMicrosecondBufferBuilder.html b/arrow/array/type.TimestampMicrosecondBufferBuilder.html
index 51eca49e7d..5c3900fda0 100644
--- a/arrow/array/type.TimestampMicrosecondBufferBuilder.html
+++ b/arrow/array/type.TimestampMicrosecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampMicrosecondBuilder.html b/arrow/array/type.TimestampMicrosecondBuilder.html
index 9059355a2b..79a3944b36 100644
--- a/arrow/array/type.TimestampMicrosecondBuilder.html
+++ b/arrow/array/type.TimestampMicrosecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampMillisecondArray.html b/arrow/array/type.TimestampMillisecondArray.html
index 4b83597e30..5f876608a6 100644
--- a/arrow/array/type.TimestampMillisecondArray.html
+++ b/arrow/array/type.TimestampMillisecondArray.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="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 [...]
 <p>See examples for <a href="type.TimestampSecondArray.html" title="type arrow::array::TimestampSecondArray"><code>TimestampSecondArray</code></a></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampMillisecondBufferBuilder.html b/arrow/array/type.TimestampMillisecondBufferBuilder.html
index 58322addd7..61fd35968c 100644
--- a/arrow/array/type.TimestampMillisecondBufferBuilder.html
+++ b/arrow/array/type.TimestampMillisecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampMillisecondBuilder.html b/arrow/array/type.TimestampMillisecondBuilder.html
index ea971cf119..c84c3f2b13 100644
--- a/arrow/array/type.TimestampMillisecondBuilder.html
+++ b/arrow/array/type.TimestampMillisecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampNanosecondArray.html b/arrow/array/type.TimestampNanosecondArray.html
index 07b576b186..de2357b6d7 100644
--- a/arrow/array/type.TimestampNanosecondArray.html
+++ b/arrow/array/type.TimestampNanosecondArray.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="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=" [...]
 <p>See examples for <a href="type.TimestampSecondArray.html" title="type arrow::array::TimestampSecondArray"><code>TimestampSecondArray</code></a></p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampNanosecondBufferBuilder.html b/arrow/array/type.TimestampNanosecondBufferBuilder.html
index 13a58c7959..6b55871fc7 100644
--- a/arrow/array/type.TimestampNanosecondBufferBuilder.html
+++ b/arrow/array/type.TimestampNanosecondBufferBuilder.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="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" [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampNanosecondBuilder.html b/arrow/array/type.TimestampNanosecondBuilder.html
index 890b842e72..6f22bf8cc3 100644
--- a/arrow/array/type.TimestampNanosecondBuilder.html
+++ b/arrow/array/type.TimestampNanosecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampSecondArray.html b/arrow/array/type.TimestampSecondArray.html
index b6c22eda11..2f945c1b52 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 [...]
 <p>This type is similar to the <a href="https://docs.rs/chrono/latest/chrono/datetime/struct.DateTime.html" title="struct chrono::datetime::DateTime"><code>chrono::DateTime</code></a> type and can hold
 values such as <code>1970-05-09 14:25:11 +01:00</code></p>
 <p>See also <a href="../datatypes/enum.DataType.html#variant.Timestamp" title="variant arrow::datatypes::DataType::Timestamp"><code>Timestamp</code></a>.</p>
diff --git a/arrow/array/type.TimestampSecondBufferBuilder.html b/arrow/array/type.TimestampSecondBufferBuilder.html
index f788d65e25..b1f11e57e7 100644
--- a/arrow/array/type.TimestampSecondBufferBuilder.html
+++ b/arrow/array/type.TimestampSecondBufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.TimestampSecondBuilder.html b/arrow/array/type.TimestampSecondBuilder.html
index 9004231b26..a95f0e1708 100644
--- a/arrow/array/type.TimestampSecondBuilder.html
+++ b/arrow/array/type.TimestampSecondBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt16Array.html b/arrow/array/type.UInt16Array.html
index e870abbe71..2a8958fc6b 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 [...]
 <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 0bbee68aaf..a395d39e04 100644
--- a/arrow/array/type.UInt16BufferBuilder.html
+++ b/arrow/array/type.UInt16BufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt16Builder.html b/arrow/array/type.UInt16Builder.html
index 01eefbfe8c..f9eff46a40 100644
--- a/arrow/array/type.UInt16Builder.html
+++ b/arrow/array/type.UInt16Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt16DictionaryArray.html b/arrow/array/type.UInt16DictionaryArray.html
index 588bf1ec87..904e2d430e 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 [...]
 <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>
 <span class="kw">let </span>array: UInt16DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.UInt32Array.html b/arrow/array/type.UInt32Array.html
index 8cd51e29c5..86feebc6d1 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 [...]
 <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 aba102635d..4990f3f5a3 100644
--- a/arrow/array/type.UInt32BufferBuilder.html
+++ b/arrow/array/type.UInt32BufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt32Builder.html b/arrow/array/type.UInt32Builder.html
index 7ad482ff51..76c56c296b 100644
--- a/arrow/array/type.UInt32Builder.html
+++ b/arrow/array/type.UInt32Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt32DictionaryArray.html b/arrow/array/type.UInt32DictionaryArray.html
index 5d4c4a2f7f..fd3dc5d3eb 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 [...]
 <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>
 <span class="kw">let </span>array: UInt32DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.UInt64Array.html b/arrow/array/type.UInt64Array.html
index 75e2b13f43..7ee25ca19f 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 [...]
 <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 6080cfc6ef..88a626c974 100644
--- a/arrow/array/type.UInt64BufferBuilder.html
+++ b/arrow/array/type.UInt64BufferBuilder.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="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"  [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt64Builder.html b/arrow/array/type.UInt64Builder.html
index 91f8acea4a..95201e840f 100644
--- a/arrow/array/type.UInt64Builder.html
+++ b/arrow/array/type.UInt64Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt64DictionaryArray.html b/arrow/array/type.UInt64DictionaryArray.html
index c51262da04..fc877c7bfb 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 [...]
 <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>
 <span class="kw">let </span>array: UInt64DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/array/type.UInt8Array.html b/arrow/array/type.UInt8Array.html
index 128f660152..d965a937d8 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 [...]
 <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 630e91fc5e..49aa379d12 100644
--- a/arrow/array/type.UInt8BufferBuilder.html
+++ b/arrow/array/type.UInt8BufferBuilder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt8Builder.html b/arrow/array/type.UInt8Builder.html
index 2f37c7f9e5..af53e233e5 100644
--- a/arrow/array/type.UInt8Builder.html
+++ b/arrow/array/type.UInt8Builder.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="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 [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/array/type.UInt8DictionaryArray.html b/arrow/array/type.UInt8DictionaryArray.html
index 4a2136b422..3e994daa3e 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 [...]
 <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>
 <span class="kw">let </span>array: UInt8DictionaryArray = <span class="macro">vec!</span>[<span class="string">&quot;a&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>].into_iter().collect();
diff --git a/arrow/buffer/fn.bitwise_bin_op_helper.html b/arrow/buffer/fn.bitwise_bin_op_helper.html
index 3fe52a69c6..e5080e11e6 100644
--- a/arrow/buffer/fn.bitwise_bin_op_helper.html
+++ b/arrow/buffer/fn.bitwise_bin_op_helper.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise operation `op` to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>bitwise_bin_op_helper in arrow::buffer - 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="Apply a bitwise operation `op` to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>bitwise_bin_op_helper in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" [...]
     left: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     left_offset_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     right: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
diff --git a/arrow/buffer/fn.bitwise_quaternary_op_helper.html b/arrow/buffer/fn.bitwise_quaternary_op_helper.html
index 0c03ea9cbb..eb966be429 100644
--- a/arrow/buffer/fn.bitwise_quaternary_op_helper.html
+++ b/arrow/buffer/fn.bitwise_quaternary_op_helper.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise operation `op` to four inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>bitwise_quaternary_op_helper in arrow::buffer - Rust</title><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="Apply a bitwise operation `op` to four inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>bitwise_quaternary_op_helper in arrow::buffer - Rust</title><link rel="preload" as="font" type="fon [...]
     buffers: [&amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">4</a>],
     offsets: [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">4</a>],
     len_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/buffer/fn.bitwise_unary_op_helper.html b/arrow/buffer/fn.bitwise_unary_op_helper.html
index 0e4cc17b94..816deba02e 100644
--- a/arrow/buffer/fn.bitwise_unary_op_helper.html
+++ b/arrow/buffer/fn.bitwise_unary_op_helper.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise operation `op` to one input and return the result as a Buffer. The input is treated as a bitmap, meaning that offset and length are specified in number of bits."><title>bitwise_unary_op_helper in arrow::buffer - 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="Apply a bitwise operation `op` to one input and return the result as a Buffer. The input is treated as a bitmap, meaning that offset and length are specified in number of bits."><title>bitwise_unary_op_helper in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2"  [...]
     left: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     offset_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     len_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/buffer/fn.buffer_bin_and.html b/arrow/buffer/fn.buffer_bin_and.html
index d42f374b91..d5a75c9a28 100644
--- a/arrow/buffer/fn.buffer_bin_and.html
+++ b/arrow/buffer/fn.buffer_bin_and.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise and to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>buffer_bin_and in arrow::buffer - Rust</title><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="Apply a bitwise and to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>buffer_bin_and in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
     left: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     left_offset_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     right: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
diff --git a/arrow/buffer/fn.buffer_bin_or.html b/arrow/buffer/fn.buffer_bin_or.html
index c031dc0b4f..e589e6e172 100644
--- a/arrow/buffer/fn.buffer_bin_or.html
+++ b/arrow/buffer/fn.buffer_bin_or.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise or to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>buffer_bin_or in arrow::buffer - Rust</title><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="Apply a bitwise or to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>buffer_bin_or in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href=". [...]
     left: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     left_offset_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     right: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
diff --git a/arrow/buffer/fn.buffer_bin_xor.html b/arrow/buffer/fn.buffer_bin_xor.html
index 7902bd6865..f4a027bf13 100644
--- a/arrow/buffer/fn.buffer_bin_xor.html
+++ b/arrow/buffer/fn.buffer_bin_xor.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise xor to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>buffer_bin_xor in arrow::buffer - Rust</title><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="Apply a bitwise xor to two inputs and return the result as a Buffer. The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits."><title>buffer_bin_xor in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
     left: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     left_offset_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     right: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
diff --git a/arrow/buffer/fn.buffer_unary_not.html b/arrow/buffer/fn.buffer_unary_not.html
index bff5f9dc95..8bad6221a8 100644
--- a/arrow/buffer/fn.buffer_unary_not.html
+++ b/arrow/buffer/fn.buffer_unary_not.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Apply a bitwise not to one input and return the result as a Buffer. The input is treated as a bitmap, meaning that offset and length are specified in number of bits."><title>buffer_unary_not in arrow::buffer - Rust</title><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="Apply a bitwise not to one input and return the result as a Buffer. The input is treated as a bitmap, meaning that offset and length are specified in number of bits."><title>buffer_unary_not in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
     left: &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     offset_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     len_in_bits: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
diff --git a/arrow/buffer/index.html b/arrow/buffer/index.html
index ca9e47bc19..53648de287 100644
--- a/arrow/buffer/index.html
+++ b/arrow/buffer/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="Types of shared memory region"><title>arrow::buffer - Rust</title><link rel="preload" 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/Fir [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Types of shared memory region"><title>arrow::buffer - Rust</title><link rel="preload" 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/Fir [...]
 </div></details><h2 id="structs" class="small-section-header"><a href="#structs">Structs</a></h2><ul class="item-table"><li><div class="item-name"><a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></div><div class="desc docblock-short">A slice-able <a href="struct.Buffer.html" title="struct arrow::buffer::Buffer"><code>Buffer</code></a> containing bit-packed booleans</div></li><li><div class="item-name"><a class="struct" href= [...]
 thread boundaries.</div></li><li><div class="item-name"><a class="struct" href="struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer">MutableBuffer</a></div><div class="desc docblock-short">A <a href="struct.MutableBuffer.html" title="struct arrow::buffer::MutableBuffer"><code>MutableBuffer</code></a> is Arrow’s interface to build a <a href="struct.Buffer.html" title="struct arrow::buffer::Buffer"><code>Buffer</code></a> out of items or slices of items.</div></li><li><di [...]
 The inputs are treated as bitmaps, meaning that offsets and length are specified in number of bits.</div></li><li><div class="item-name"><a class="fn" href="fn.bitwise_quaternary_op_helper.html" title="fn arrow::buffer::bitwise_quaternary_op_helper">bitwise_quaternary_op_helper</a></div><div class="desc docblock-short">Apply a bitwise operation <code>op</code> to four inputs and return the result as a Buffer.
diff --git a/arrow/buffer/struct.BooleanBuffer.html b/arrow/buffer/struct.BooleanBuffer.html
index 73d60e72ea..07188ddfba 100644
--- a/arrow/buffer/struct.BooleanBuffer.html
+++ b/arrow/buffer/struct.BooleanBuffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A slice-able `Buffer` containing bit-packed booleans"><title>BooleanBuffer in arrow::buffer - Rust</title><link 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 slice-able `Buffer` containing bit-packed booleans"><title>BooleanBuffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2"  [...]
     buffer: <a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -37,17 +37,17 @@ return false when the arrays are logically equal</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#193">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="../util/bit_iterator/struct.BitIterator.html" title="struct arrow::util::bit_iterator::BitIterator">BitIterator</a>&lt;'_&gt; <a href="#" class="tooltip" data-notable-ty="BitIt [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_indices" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#198">source</a><h4 class="code-header">pub fn <a href="#method.set_indices" class="fn">set_indices</a>(&amp;self) -&gt; <a class="struct" href="../util/bit_iterator/struct.BitIndexIterator.html" title="struct arrow::util::bit_iterator::BitIndexIterator">BitIndexIterator</a>&lt;'_&gt; <a href="#" cl [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_slices" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#203">source</a><h4 class="code-header">pub fn <a href="#method.set_slices" class="fn">set_slices</a>(&amp;self) -&gt; <a class="struct" href="../util/bit_iterator/struct.BitSliceIterator.html" title="struct arrow::util::bit_iterator::BitSliceIterator">BitSliceIterator</a>&lt;'_&gt; <a href="#" class [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="small-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-BitAnd%3C%26BooleanBuffer%3E-for-%26BooleanBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#220">source</a><a href="#impl-BitAnd%3C%26BooleanBuffer%3E-fo [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="small-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-BitAnd%3C%26BooleanBuffer%3E-for-%26BooleanBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#220">source</a><a href="#impl-BitAnd%3C%26BooleanBuffer%3E-fo [...]
     self,
     rhs: &amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>
-) -&gt; &lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd.html" title="trait core::ops::bit::BitAnd">BitAnd</a>&lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>&gt;&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd. [...]
+) -&gt; &lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd.html" title="trait core::ops::bit::BitAnd">BitAnd</a>&lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>&gt;&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd. [...]
     self,
     rhs: &amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>
 ) -&gt; &lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitOr.html" title="trait core::ops::bit::BitOr">BitOr</a>&lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>&gt;&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitOr.html [...]
     self,
     rhs: &amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>
-) -&gt; &lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitXor.html" title="trait core::ops::bit::BitXor">BitXor</a>&lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>&gt;&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitXor. [...]
-    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;,</span></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_it [...]
+) -&gt; &lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitXor.html" title="trait core::ops::bit::BitXor">BitXor</a>&lt;&amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>&gt;&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitXor. [...]
+    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;,</span></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_it [...]
 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#226">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><section id="impl-Eq-for-BooleanBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#27">source</a><a href="#impl-Eq-for-BooleanBuffer" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.Eq.html" title="trait core::cmp::Eq">Eq</a> for <a class="struct" href="struct.BooleanBuffer [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></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#136">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
diff --git a/arrow/buffer/struct.Buffer.html b/arrow/buffer/struct.Buffer.html
index 0b8862ea97..efcf3c36c2 100644
--- a/arrow/buffer/struct.Buffer.html
+++ b/arrow/buffer/struct.Buffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 represents a contiguous memory region that can be shared with other buffers and across thread boundaries."><title>Buffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.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="Buffer represents a contiguous memory region that can be shared with other buffers and across thread boundaries."><title>Buffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.wo [...]
     data: <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="../../arrow_buffer/bytes/struct.Bytes.html" title="struct arrow_buffer::bytes::Bytes">Bytes</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;,
     ptr: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.pointer.html">*const </a><a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>,
     length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -99,7 +99,9 @@ Prefer this to <code>collect</code> whenever possible, as it is ~60% faster.</p>
 <h5 id="safety-3"><a href="#safety-3">Safety</a></h5>
 <p>This method assumes that the iterator’s size is correct and is undefined behavior
 to use it on an iterator that reports an incorrect length.</p>
-</div></details></div></details></div><h2 id="deref-methods-%5Bu8%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</span><a href="#deref-methods-%5Bu8%5D" class="anchor">§</a></h2><div id="deref-methods-%5Bu8%5D-1" class="impl-items"><details [...]
+</div></details></div></details></div><h2 id="deref-methods-%5Bu8%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</span><a href="#deref-methods-%5Bu8%5D" class="anchor">§</a></h2><div id="deref-methods-%5Bu8%5D-1" class="impl-items"><details [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.flatten" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4496">source</a><h4 class="code-header">pub fn <a href="#method.flatten" class="fn">flatten</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section><span class="item-info"><div class="stab unstable"><span clas [...]
 <h5 id="panics-3"><a href="#panics-3">Panics</a></h5>
 <p>This panics if the length of the resulting slice would overflow a <code>usize</code>.</p>
 <p>This is only possible when flattening a slice of arrays of zero-sized
@@ -120,70 +122,23 @@ types, and thus tends to be irrelevant in practice. If
 
 <span class="kw">let </span>empty_slice_of_arrays: <span class="kw-2">&amp;</span>[[u32; <span class="number">10</span>]] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert!</span>(empty_slice_of_arrays.flatten().is_empty());</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
-<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
-without checking whether they’re valid.</p>
-<h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
-<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
-<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
-but without allocating and copying temporaries.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
-treating it as an ASCII string.</p>
-<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
-<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
-<span class="kw">let </span>escaped = s.escape_ascii().to_string();
-<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
-removed.</p>
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_str" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#544">source</a><h4 class="code-header">pub fn <a href="#method.as_str" class="fn">as_str</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section><span class="item-info"><div class="stab unstable"><span cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.len-1" class="method"><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/slice/mod.rs.html#141">source</a></span><h4 class="code-header">pub fn <a href="#method.len-1" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">u [...]
-<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
+<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert_eq!</span>(a.len(), <span class="number">3</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty-1" class="method"><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/slice/mod.rs.html#157">source</a></span><h4 class="code-header">pub fn <a href="#method.is_empty-1" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitiv [...]
-<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
+<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert!</span>(!a.is_empty());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first" class="method"><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/slice/mod.rs.html#176">source</a></span><h4 class="code-header">pub fn <a href="#method.first" class="fn">first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html"  [...]
-<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
+<h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">10</span>), v.first());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.first());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#216">source</a></span><h4 class="code-header">pub fn <a href="#method.split_first" class="fn">split_first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/ [...]
-<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
+<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((first, elements)) = x.split_first() {
@@ -191,7 +146,7 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#258">source</a></span><h4 class="code-header">pub fn <a href="#method.split_last" class="fn">split_last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enu [...]
-<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
+<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((last, elements)) = x.split_last() {
@@ -199,14 +154,14 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last" class="method"><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/slice/mod.rs.html#299">source</a></span><h4 class="code-header">pub fn <a href="#method.last" class="fn">last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" tit [...]
-<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
+<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">30</span>), v.last());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.last());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#342">source</a><h4 class="code-header">pub fn <a href="#method.first_chunk" class="fn">first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nig [...]
-<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
+<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -219,7 +174,7 @@ removed.</p>
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[]), w.first_chunk::&lt;<span class="number">0</span>&gt;());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#400">source</a><h4 class="code-header">pub fn <a href="#method.split_first_chunk" class="fn">split_first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
+<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -230,7 +185,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#467">source</a><h4 class="code-header">pub fn <a href="#method.split_last_chunk" class="fn">split_last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.ru [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
+<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -240,7 +195,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#534">source</a><h4 class="code-header">pub fn <a href="#method.last_chunk" class="fn">last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightl [...]
-<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
+<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -260,7 +215,7 @@ position or <code>None</code> if out of bounds.</li>
 <li>If given a range, returns the subslice corresponding to that range,
 or <code>None</code> if out of bounds.</li>
 </ul>
-<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
+<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">40</span>), v.get(<span class="number">1</span>));
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]), v.get(<span class="number">0</span>..<span class="number">2</span>));
@@ -273,10 +228,10 @@ or <code>None</code> if out of bounds.</li>
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;,</span></h4></section></summary><div class="docblock"><p>Returns a reference to an element or subslice, without doing bounds
 checking.</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get" title="method slice::get"><code>get</code></a>.</p>
-<h5 id="safety-5"><a href="#safety-5">Safety</a></h5>
+<h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used.</p>
-<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
+<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 
 <span class="kw">unsafe </span>{
@@ -290,7 +245,7 @@ is never written to (except inside an <code>UnsafeCell</code>) using this pointe
 derived from it. If you need to mutate the contents of the slice, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.as_mut_ptr" title="method slice::as_mut_ptr"><code>as_mut_ptr</code></a>.</p>
 <p>Modifying the container referenced by this slice may cause its buffer
 to be reallocated, which would also make any pointers to it invalid.</p>
-<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
+<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span>x_ptr = x.as_ptr();
 
@@ -321,7 +276,7 @@ element of this slice:</p>
 <span class="macro">assert!</span>(!a.as_ptr_range().contains(<span class="kw-2">&amp;</span>y));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><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/slice/mod.rs.html#1001">source</a></span><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/slice/iter/struct.Iter.ht [...]
 <p>The iterator yields all items from start to end.</p>
-<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
+<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iterator = x.iter();
 
@@ -334,7 +289,7 @@ element of this slice:</p>
 <code>size</code>, the iterator returns no values.</p>
 <h5 id="panics-4"><a href="#panics-4">Panics</a></h5>
 <p>Panics if <code>size</code> is 0.</p>
-<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
+<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>, <span class="string">&#39;s&#39;</span>, <span class="string">&#39;t&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.windows(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>]);
@@ -369,7 +324,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 slice.</p>
 <h5 id="panics-5"><a href="#panics-5">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
+<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -387,7 +342,7 @@ resulting code better than in the case of <a href="https://doc.rust-lang.org/nig
 chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.rchunks_exact" title="method slice::rchunks_exact"><code>rchunks_exact</code></a> for the same iterator but starting at the end of the slice.</p>
 <h5 id="panics-6"><a href="#panics-6">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
+<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -396,13 +351,13 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 <span class="macro">assert_eq!</span>(iter.remainder(), <span class="kw-2">&amp;</span>[<span class="string">&#39;m&#39;</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_chunks_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#1259">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_chunks_unchecked" class="fn">as_chunks_unchecked</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; &amp;[<a class="pri [...]
 assuming that there’s no remainder.</p>
-<h5 id="safety-6"><a href="#safety-6">Safety</a></h5>
+<h5 id="safety-5"><a href="#safety-5">Safety</a></h5>
 <p>This may only be called when</p>
 <ul>
 <li>The slice splits exactly into <code>N</code>-element chunks (aka <code>self.len() % N == 0</code>).</li>
 <li><code>N != 0</code>.</li>
 </ul>
-<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
+<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice: <span class="kw-2">&amp;</span>[char] = <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>, <span class="string">&#39;!&#39;</span>];
 <span class="kw">let </span>chunks: <span class="kw-2">&amp;</span>[[char; <span class="number">1</span>]] =
@@ -423,7 +378,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-7"><a href="#panics-7">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
+<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(chunks, remainder) = slice.as_chunks();
@@ -444,7 +399,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-8"><a href="#panics-8">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
+<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(remainder, chunks) = slice.as_rchunks();
@@ -459,7 +414,7 @@ retrieved from the <code>remainder</code> function of the iterator.</p>
 <h5 id="panics-9"><a href="#panics-9">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
+<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_chunks();
@@ -474,7 +429,7 @@ starting at the beginning of the slice.</p>
 <h5 id="panics-10"><a href="#panics-10">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
+<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_windows)]
 </span><span class="kw">let </span>slice = [<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_windows();
@@ -491,7 +446,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 of the slice.</p>
 <h5 id="panics-11"><a href="#panics-11">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
+<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -510,7 +465,7 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 slice.</p>
 <h5 id="panics-12"><a href="#panics-12">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
+<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -523,7 +478,7 @@ of elements using the predicate to separate them.</p>
 <p>The predicate is called on two elements following themselves,
 it means the predicate is called on <code>slice[0]</code> and <code>slice[1]</code>
 then on <code>slice[1]</code> and <code>slice[2]</code> and so on.</p>
-<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
+<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_group_by)]
 
 </span><span class="kw">let </span>slice = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">2</span>];
@@ -552,7 +507,7 @@ the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-13"><a href="#panics-13">Panics</a></h5>
 <p>Panics if <code>mid &gt; len</code>.</p>
-<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
+<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
 
 {
@@ -577,11 +532,11 @@ indices from <code>[mid, len)</code> (excluding the index <code>len</code> itsel
 the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.split_at" title="method slice::split_at"><code>split_at</code></a>.</p>
-<h5 id="safety-7"><a href="#safety-7">Safety</a></h5>
+<h5 id="safety-6"><a href="#safety-6">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used. The caller has to ensure that
 <code>0 &lt;= mid &lt;= self.len()</code>.</p>
-<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
+<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_split_at_unchecked)]
 
 </span><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
@@ -609,7 +564,7 @@ the index <code>N</code> itself) and the slice will contain all
 indices from <code>[N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-14"><a href="#panics-14">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
+<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -638,7 +593,7 @@ the index <code>len - N</code> itself) and the array will contain all
 indices from <code>[len - N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-15"><a href="#panics-15">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
+<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -663,7 +618,7 @@ indices from <code>[len - N, len)</code> (excluding the index <code>len</code> i
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split" class="method"><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/slice/mod.rs.html#2222-2224">source</a></span><h4 class="code-header">pub fn <a href="#method.split" class="fn">split</a>&lt;F&gt;(&amp;self, pred: F) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core [...]
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is not contained in the subslices.</p>
-<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
+<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -695,7 +650,7 @@ present between them:</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is contained in the end of the previous
 subslice as a terminator.</p>
-<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
+<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split_inclusive(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -716,7 +671,7 @@ That slice will be the last item returned by the iterator.</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>, starting at the end of the slice and working backwards.
 The matched element is not contained in the subslices.</p>
-<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
+<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">11</span>, <span class="number">22</span>, <span class="number">33</span>, <span class="number">0</span>, <span class="number">44</span>, <span class="number">55</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rsplit(|num| <span class="kw-2">*</span>num == <span class="number">0</span>);
 
@@ -739,7 +694,7 @@ slice will be the first (or last) item returned by the iterator.</p>
 not contained in the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
+<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
 <p>Print the slice split once by numbers divisible by 3 (i.e., <code>[10, 40]</code>,
 <code>[20, 60, 50]</code>):</p>
 
@@ -755,7 +710,7 @@ the slice and works backwards. The matched element is not contained in
 the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
+<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
 <p>Print the slice split once, starting from the end, by numbers divisible
 by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
 
@@ -768,7 +723,7 @@ by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if the slice contains an element with the given value.</p>
 <p>This operation is <em>O</em>(<em>n</em>).</p>
 <p>Note that if you have a sorted slice, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a> may be faster.</p>
-<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
+<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.contains(<span class="kw-2">&amp;</span><span class="number">30</span>));
 <span class="macro">assert!</span>(!v.contains(<span class="kw-2">&amp;</span><span class="number">50</span>));</code></pre></div>
@@ -781,7 +736,7 @@ use <code>iter().any</code>:</p>
 </span><span class="macro">assert!</span>(!v.iter().any(|e| e == <span class="string">&quot;hi&quot;</span>));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.starts_with" class="method"><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/slice/mod.rs.html#2540-2542">source</a></span><h4 class="code-header">pub fn <a href="#method.starts_with" class="fn">starts_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/ni [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a prefix of the slice.</p>
-<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
+<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>]));
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]));
@@ -795,7 +750,7 @@ use <code>iter().any</code>:</p>
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[]));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.ends_with" class="method"><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/slice/mod.rs.html#2570-2572">source</a></span><h4 class="code-header">pub fn <a href="#method.ends_with" class="fn">ends_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/ [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a suffix of the slice.</p>
-<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
+<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">30</span>]));
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]));
@@ -813,7 +768,7 @@ use <code>iter().any</code>:</p>
 <p>If the slice starts with <code>prefix</code>, returns the subslice after the prefix, wrapped in <code>Some</code>.
 If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not start with <code>prefix</code>, returns <code>None</code>.</p>
-<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
+<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">30</span>][..]));
@@ -829,7 +784,7 @@ If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice ends with <code>suffix</code>, returns the subslice before the suffix, wrapped in <code>Some</code>.
 If <code>suffix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not end with <code>suffix</code>, returns <code>None</code>.</p>
-<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
+<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>][..]));
@@ -847,7 +802,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"> [...]
-<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
+<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -904,7 +859,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>par [...]
-<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
+<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -939,7 +894,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>partition_point [...]
-<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
+<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
 <p>Looks up a series of four elements in a slice of pairs sorted by
 their second elements. The first is found, with a uniquely
 determined position; the second and third are not found; the
@@ -964,10 +919,10 @@ matter, such as a sanitizer attempting to find alignment bugs. Regular code runn
 in a default (debug or release) execution <em>will</em> return a maximal middle part.</p>
 <p>This method has no purpose when either input element <code>T</code> or output element <code>U</code> are
 zero-sized and will return the original slice without splitting anything.</p>
-<h5 id="safety-8"><a href="#safety-8">Safety</a></h5>
+<h5 id="safety-7"><a href="#safety-7">Safety</a></h5>
 <p>This method is essentially a <code>transmute</code> with respect to the elements in the returned
 middle slice, so all the usual caveats pertaining to <code>transmute::&lt;T, U&gt;</code> also apply here.</p>
-<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
+<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
 <p>Basic usage:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">unsafe </span>{
@@ -1000,7 +955,7 @@ that from ever happening, as only power-of-two numbers of lanes are
 supported.  It’s possible that, in the future, those restrictions might
 be lifted in a way that would make it possible to see panics from this
 method for something like <code>LANES == 3</code>.</p>
-<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(portable_simd)]
 </span><span class="kw">use </span>core::simd::SimdFloat;
 
@@ -1035,7 +990,7 @@ slice yields exactly zero or one element, <code>true</code> is returned.</p>
 <p>Note that if <code>Self::Item</code> is only <code>PartialOrd</code>, but not <code>Ord</code>, the above definition
 implies that this function returns <code>false</code> if any two consecutive items are not
 comparable.</p>
-<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 </span><span class="kw">let </span>empty: [i32; <span class="number">0</span>] = [];
 
@@ -1055,7 +1010,7 @@ function to determine the ordering of two elements. Apart from that, it’s equi
 <p>Instead of comparing the slice’s elements directly, this function compares the keys of the
 elements, as determined by <code>f</code>. Apart from that, it’s equivalent to <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.is_sorted" title="method slice::is_sorted"><code>is_sorted</code></a>; see its
 documentation for more information.</p>
-<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 
 </span><span class="macro">assert!</span>([<span class="string">&quot;c&quot;</span>, <span class="string">&quot;bb&quot;</span>, <span class="string">&quot;aaa&quot;</span>].is_sorted_by_key(|s| s.len()));
@@ -1071,7 +1026,7 @@ For example, <code>[7, 15, 3, 5, 4, 12, 6]</code> is partitioned under the predi
 <p>If this slice is not partitioned, the returned result is unspecified and meaningless,
 as this method performs a kind of binary search.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binar [...]
-<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">6</span>, <span class="number">7</span>];
 <span class="kw">let </span>i = v.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; <span class="number">5</span>);
 
@@ -1093,6 +1048,51 @@ sort order:</p>
 <span class="kw">let </span>idx = s.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; num);
 s.insert(idx, num);
 <span class="macro">assert_eq!</span>(s, [<span class="number">0</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">8</span>, <span class="number">13</span>, <span class="number">21</span>, <span class="number">34</span>, <span class="number">42</span>, <span class="number">55</span>]);</code></p [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
+<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
+without checking whether they’re valid.</p>
+<h5 id="safety-8"><a href="#safety-8">Safety</a></h5>
+<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
+<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
+but without allocating and copying temporaries.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
+treating it as an ASCII string.</p>
+<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
+<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
+<span class="kw">let </span>escaped = s.escape_ascii().to_string();
+<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
+removed.</p>
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_ascii_uppercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/alloc/slice.rs.html#621">source</a></span><h4 class="code-header">pub fn <a href="#method.to_ascii_uppercase" class="fn">to_ascii_uppercase</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.or [...]
 is mapped to its ASCII upper case equivalent.</p>
 <p>ASCII letters ‘a’ to ‘z’ are mapped to ‘A’ to ‘Z’,
@@ -1157,8 +1157,8 @@ given separator between each.</p>
 <h5 id="examples-57"><a href="#examples-57">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="macro">assert_eq!</span>([<span class="string">&quot;hello&quot;</span>, <span class="string">&quot;world&quot;</span>].connect(<span class="string">&quot; &quot;</span>), <span class="string">&quot;hello world&quot;</span>);
 <span class="macro">assert_eq!</span>([[<span class="number">1</span>, <span class="number">2</span>], [<span class="number">3</span>, <span class="number">4</span>]].connect(<span class="kw-2">&amp;</span><span class="number">0</span>), [<span class="number">1</span>, <span class="number">2</span>, <span class="number">0</span>, <span class="number">3</span>, <span class="number">4</span>]);</code></pre></div>
-</div></details></div><h2 id="trait-implementations" class="small-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-Buffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/immutable.rs.html#33">source</a><a href="#impl-Clone-for-Buffer" class="anchor">§</a><h3 class="code-header">impl <a class="tr [...]
-    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#120">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+</div></details></div><h2 id="trait-implementations" class="small-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-Buffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/immutable.rs.html#33">source</a><a href="#impl-Clone-for-Buffer" class="anchor">§</a><h3 class="code-header">impl <a class="tr [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></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#120">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="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;,</span></h3></section></summary><div class="docblock"><p>Creating a <code>Buffer</code> instance by copying the memory from a <code>AsRef&lt;[u8]&gt;</code> into a newly
 allocated memory region.</p>
 </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_buffer/buffer/immutable.rs.html#331">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>(p: T) -&gt; <a class="struct" href="struct.Buffer.html" title="struct arrow::buffer [...]
diff --git a/arrow/buffer/struct.MutableBuffer.html b/arrow/buffer/struct.MutableBuffer.html
index 6e2ef808e5..0aa4b17650 100644
--- a/arrow/buffer/struct.MutableBuffer.html
+++ b/arrow/buffer/struct.MutableBuffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `MutableBuffer` is Arrow’s interface to build a `Buffer` out of items or slices of items."><title>MutableBuffer in arrow::buffer - 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="A `MutableBuffer` is Arrow’s interface to build a `Buffer` out of items or slices of items."><title>MutableBuffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel [...]
     data: <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="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>&gt;,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     layout: <a class="struct" href="https://doc.rust-lang.org/nightly/core/alloc/layout/struct.Layout.html" title="struct core::alloc::layout::Layout">Layout</a>,
@@ -143,7 +143,9 @@ Prefer this to <code>collect</code> whenever possible, as it is faster ~60% fast
 <h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
 <p>This method assumes that the iterator’s size is correct and is undefined behavior
 to use it on an iterator that reports an incorrect length.</p>
-</div></details></div></details></div><h2 id="deref-methods-%5Bu8%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</span><a href="#deref-methods-%5Bu8%5D" class="anchor">§</a></h2><div id="deref-methods-%5Bu8%5D-1" class="impl-items"><details [...]
+</div></details></div></details></div><h2 id="deref-methods-%5Bu8%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;</span><a href="#deref-methods-%5Bu8%5D" class="anchor">§</a></h2><div id="deref-methods-%5Bu8%5D-1" class="impl-items"><details [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.flatten" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4496">source</a><h4 class="code-header">pub fn <a href="#method.flatten" class="fn">flatten</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section><span class="item-info"><div class="stab unstable"><span clas [...]
 <h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
 <p>This panics if the length of the resulting slice would overflow a <code>usize</code>.</p>
 <p>This is only possible when flattening a slice of arrays of zero-sized
@@ -195,80 +197,36 @@ v.sort_floats();
 <span class="kw">let </span>sorted = [-f64::INFINITY, -<span class="number">1.0</span>, -<span class="number">5e-8</span>, -<span class="number">0.0</span>, <span class="number">0.0</span>, <span class="number">2.6</span>, <span class="number">8.29</span>, f64::INFINITY, f64::NAN];
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>v[..<span class="number">8</span>], <span class="kw-2">&amp;</span>sorted[..<span class="number">8</span>]);
 <span class="macro">assert!</span>(v[<span class="number">8</span>].is_nan());</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
-<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
-without checking whether they’re valid.</p>
-<h5 id="safety-5"><a href="#safety-5">Safety</a></h5>
-<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
-<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
-but without allocating and copying temporaries.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.make_ascii_uppercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#72">source</a></span><h4 class="code-header">pub fn <a href="#method.make_ascii_uppercase" class="fn">make_ascii_uppercase</a>(&amp;mut self)</h4></section></summary><div class="docb [...]
-<p>ASCII letters ‘a’ to ‘z’ are mapped to ‘A’ to ‘Z’,
-but non-ASCII letters are unchanged.</p>
-<p>To return a new uppercased value without modifying the existing one, use
-<a href="#method.to_ascii_uppercase"><code>to_ascii_uppercase</code></a>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.make_ascii_lowercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#89">source</a></span><h4 class="code-header">pub fn <a href="#method.make_ascii_lowercase" class="fn">make_ascii_lowercase</a>(&amp;mut self)</h4></section></summary><div class="docb [...]
-<p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
-but non-ASCII letters are unchanged.</p>
-<p>To return a new lowercased value without modifying the existing one, use
-<a href="#method.to_ascii_lowercase"><code>to_ascii_lowercase</code></a>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
-treating it as an ASCII string.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.sort_floats-1" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4571">source</a><h4 class="code-header">pub fn <a href="#method.sort_floats-1" class="fn">sort_floats</a>(&amp;mut self)</h4></section><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>sort_floats</c [...]
+<p>This sort is in-place (i.e. does not allocate), <em>O</em>(<em>n</em> * log(<em>n</em>)) worst-case, and uses
+the ordering defined by <a href="https://doc.rust-lang.org/nightly/std/primitive.f32.html#method.total_cmp" title="method f32::total_cmp"><code>f32::total_cmp</code></a>.</p>
+<h5 id="current-implementation-1"><a href="#current-implementation-1">Current implementation</a></h5>
+<p>This uses the same sorting algorithm as <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.sort_unstable_by" title="method slice::sort_unstable_by"><code>sort_unstable_by</code></a>.</p>
 <h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
-<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
-<span class="kw">let </span>escaped = s.escape_ascii().to_string();
-<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
-removed.</p>
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(sort_floats)]
+</span><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">2.6</span>, -<span class="number">5e-8</span>, f32::NAN, <span class="number">8.29</span>, f32::INFINITY, -<span class="number">1.0</span>, <span class="number">0.0</span>, -f32::INFINITY, -<span class="number">0.0</span>];
 
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_str" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#544">source</a><h4 class="code-header">pub fn <a href="#method.as_str" class="fn">as_str</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section><span class="item-info"><div class="stab unstable"><span cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
+v.sort_floats();
+<span class="kw">let </span>sorted = [-f32::INFINITY, -<span class="number">1.0</span>, -<span class="number">5e-8</span>, -<span class="number">0.0</span>, <span class="number">0.0</span>, <span class="number">2.6</span>, <span class="number">8.29</span>, f32::INFINITY, f32::NAN];
+<span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>v[..<span class="number">8</span>], <span class="kw-2">&amp;</span>sorted[..<span class="number">8</span>]);
+<span class="macro">assert!</span>(v[<span class="number">8</span>].is_nan());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.len-1" class="method"><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/slice/mod.rs.html#141">source</a></span><h4 class="code-header">pub fn <a href="#method.len-1" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">u [...]
-<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
+<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert_eq!</span>(a.len(), <span class="number">3</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty-1" class="method"><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/slice/mod.rs.html#157">source</a></span><h4 class="code-header">pub fn <a href="#method.is_empty-1" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitiv [...]
-<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
+<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert!</span>(!a.is_empty());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first" class="method"><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/slice/mod.rs.html#176">source</a></span><h4 class="code-header">pub fn <a href="#method.first" class="fn">first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html"  [...]
-<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
+<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">10</span>), v.first());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.first());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first_mut" class="method"><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/slice/mod.rs.html#196">source</a></span><h4 class="code-header">pub fn <a href="#method.first_mut" class="fn">first_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/en [...]
-<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
+<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>(first) = x.first_mut() {
@@ -276,7 +234,7 @@ removed.</p>
 }
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">5</span>, <span class="number">1</span>, <span class="number">2</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#216">source</a></span><h4 class="code-header">pub fn <a href="#method.split_first" class="fn">split_first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/ [...]
-<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
+<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((first, elements)) = x.split_first() {
@@ -284,7 +242,7 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first_mut" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#238">source</a></span><h4 class="code-header">pub fn <a href="#method.split_first_mut" class="fn">split_first_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nigh [...]
-<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
+<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((first, elements)) = x.split_first_mut() {
@@ -294,7 +252,7 @@ removed.</p>
 }
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#258">source</a></span><h4 class="code-header">pub fn <a href="#method.split_last" class="fn">split_last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enu [...]
-<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
+<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((last, elements)) = x.split_last() {
@@ -302,7 +260,7 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last_mut" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#280">source</a></span><h4 class="code-header">pub fn <a href="#method.split_last_mut" class="fn">split_last_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly [...]
-<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
+<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((last, elements)) = x.split_last_mut() {
@@ -312,14 +270,14 @@ removed.</p>
 }
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">4</span>, <span class="number">5</span>, <span class="number">3</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last" class="method"><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/slice/mod.rs.html#299">source</a></span><h4 class="code-header">pub fn <a href="#method.last" class="fn">last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" tit [...]
-<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
+<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">30</span>), v.last());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.last());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last_mut" class="method"><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/slice/mod.rs.html#319">source</a></span><h4 class="code-header">pub fn <a href="#method.last_mut" class="fn">last_mut</a>(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum. [...]
-<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
+<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>(last) = x.last_mut() {
@@ -327,7 +285,7 @@ removed.</p>
 }
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">10</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#342">source</a><h4 class="code-header">pub fn <a href="#method.first_chunk" class="fn">first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nig [...]
-<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
+<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -340,7 +298,7 @@ removed.</p>
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[]), w.first_chunk::&lt;<span class="number">0</span>&gt;());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first_chunk_mut" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#371">source</a><h4 class="code-header">pub fn <a href="#method.first_chunk_mut" class="fn">first_chunk_mut</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;mut self) -&gt; <a class="enum" href="https://doc.r [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
+<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -352,7 +310,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">5</span>, <span class="number">4</span>, <span class="number">2</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#400">source</a><h4 class="code-header">pub fn <a href="#method.split_first_chunk" class="fn">split_first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
+<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -365,7 +323,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
     &amp;mut self
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;(&amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">[T; N]</a>, &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>)&gt;</h4></section><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experiment [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
+<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -378,7 +336,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#467">source</a><h4 class="code-header">pub fn <a href="#method.split_last_chunk" class="fn">split_last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.ru [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
+<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -390,7 +348,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last_chunk_mut" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#499-501">source</a><h4 class="code-header">pub fn <a href="#method.split_last_chunk_mut" class="fn">split_last_chunk_mut</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(
     &amp;mut self
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;(&amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">[T; N]</a>, &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>)&gt;</h4></section><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experiment [...]
-<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
+<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -402,7 +360,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 }
 <span class="macro">assert_eq!</span>(x, <span class="kw-2">&amp;</span>[<span class="number">5</span>, <span class="number">3</span>, <span class="number">4</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#534">source</a><h4 class="code-header">pub fn <a href="#method.last_chunk" class="fn">last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightl [...]
-<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
+<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -414,7 +372,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[]), w.last_chunk::&lt;<span class="number">0</span>&gt;());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last_chunk_mut" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#566">source</a><h4 class="code-header">pub fn <a href="#method.last_chunk_mut" class="fn">last_chunk_mut</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;mut self) -&gt; <a class="enum" href="https://doc.rust [...]
-<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
+<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -433,7 +391,7 @@ position or <code>None</code> if out of bounds.</li>
 <li>If given a range, returns the subslice corresponding to that range,
 or <code>None</code> if out of bounds.</li>
 </ul>
-<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
+<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">40</span>), v.get(<span class="number">1</span>));
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]), v.get(<span class="number">0</span>..<span class="number">2</span>));
@@ -445,7 +403,7 @@ or <code>None</code> if out of bounds.</li>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;mut &lt;I as <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;&gt;::<a class="associatedtype" href="https://doc.rust-lang.org/nightly/co [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;,</span></h4></section></summary><div class="docblock"><p>Returns a mutable reference to an element or subslice depending on the
 type of index (see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get" title="method slice::get"><code>get</code></a>) or <code>None</code> if the index is out of bounds.</p>
-<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
+<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>(elem) = x.get_mut(<span class="number">1</span>) {
@@ -459,10 +417,10 @@ type of index (see <a href="https://doc.rust-lang.org/nightly/std/primitive.slic
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;,</span></h4></section></summary><div class="docblock"><p>Returns a reference to an element or subslice, without doing bounds
 checking.</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get" title="method slice::get"><code>get</code></a>.</p>
-<h5 id="safety-6"><a href="#safety-6">Safety</a></h5>
+<h5 id="safety-5"><a href="#safety-5">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used.</p>
-<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
+<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 
 <span class="kw">unsafe </span>{
@@ -475,10 +433,10 @@ even if the resulting reference is not used.</p>
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;,</span></h4></section></summary><div class="docblock"><p>Returns a mutable reference to an element or subslice, without doing
 bounds checking.</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get_mut" title="method slice::get_mut"><code>get_mut</code></a>.</p>
-<h5 id="safety-7"><a href="#safety-7">Safety</a></h5>
+<h5 id="safety-6"><a href="#safety-6">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used.</p>
-<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
+<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 
 <span class="kw">unsafe </span>{
@@ -494,7 +452,7 @@ is never written to (except inside an <code>UnsafeCell</code>) using this pointe
 derived from it. If you need to mutate the contents of the slice, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.as_mut_ptr" title="method slice::as_mut_ptr"><code>as_mut_ptr</code></a>.</p>
 <p>Modifying the container referenced by this slice may cause its buffer
 to be reallocated, which would also make any pointers to it invalid.</p>
-<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
+<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span>x_ptr = x.as_ptr();
 
@@ -508,7 +466,7 @@ to be reallocated, which would also make any pointers to it invalid.</p>
 function returns, or else it will end up pointing to garbage.</p>
 <p>Modifying the container referenced by this slice may cause its buffer
 to be reallocated, which would also make any pointers to it invalid.</p>
-<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
+<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span>x_ptr = x.as_mut_ptr();
 
@@ -558,7 +516,7 @@ common in C++.</p>
 </ul>
 <h5 id="panics-4"><a href="#panics-4">Panics</a></h5>
 <p>Panics if <code>a</code> or <code>b</code> are out of bounds.</p>
-<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
+<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>, <span class="string">&quot;d&quot;</span>, <span class="string">&quot;e&quot;</span>];
 v.swap(<span class="number">2</span>, <span class="number">4</span>);
 <span class="macro">assert!</span>(v == [<span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;e&quot;</span>, <span class="string">&quot;d&quot;</span>, <span class="string">&quot;c&quot;</span>]);</code></pre></div>
@@ -569,10 +527,10 @@ v.swap(<span class="number">2</span>, <span class="number">4</span>);
 <li>a - The index of the first element</li>
 <li>b - The index of the second element</li>
 </ul>
-<h5 id="safety-8"><a href="#safety-8">Safety</a></h5>
+<h5 id="safety-7"><a href="#safety-7">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>.
 The caller has to ensure that <code>a &lt; self.len()</code> and <code>b &lt; self.len()</code>.</p>
-<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
+<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_swap_unchecked)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="string">&quot;a&quot;</span>, <span class="string">&quot;b&quot;</span>, <span class="string">&quot;c&quot;</span>, <span class="string">&quot;d&quot;</span>];
@@ -580,13 +538,13 @@ The caller has to ensure that <code>a &lt; self.len()</code> and <code>b &lt; se
 </span><span class="kw">unsafe </span>{ v.swap_unchecked(<span class="number">1</span>, <span class="number">3</span>) };
 <span class="macro">assert!</span>(v == [<span class="string">&quot;a&quot;</span>, <span class="string">&quot;d&quot;</span>, <span class="string">&quot;c&quot;</span>, <span class="string">&quot;b&quot;</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.reverse" class="method"><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/slice/mod.rs.html#943">source</a></span><h4 class="code-header">pub fn <a href="#method.reverse" class="fn">reverse</a>(&amp;mut self)</h4></section></summary><div class="docblock"><p>Reverses the order of elements in [...]
-<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
+<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 v.reverse();
 <span class="macro">assert!</span>(v == [<span class="number">3</span>, <span class="number">2</span>, <span class="number">1</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><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/slice/mod.rs.html#1001">source</a></span><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/slice/iter/struct.Iter.ht [...]
 <p>The iterator yields all items from start to end.</p>
-<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
+<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iterator = x.iter();
 
@@ -596,7 +554,7 @@ v.reverse();
 <span class="macro">assert_eq!</span>(iterator.next(), <span class="prelude-val">None</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter_mut" class="method"><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/slice/mod.rs.html#1020">source</a></span><h4 class="code-header">pub fn <a href="#method.iter_mut" class="fn">iter_mut</a>(&amp;mut self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/slice/ite [...]
 <p>The iterator yields all items from start to end.</p>
-<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
+<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">for </span>elem <span class="kw">in </span>x.iter_mut() {
     <span class="kw-2">*</span>elem += <span class="number">2</span>;
@@ -607,7 +565,7 @@ v.reverse();
 <code>size</code>, the iterator returns no values.</p>
 <h5 id="panics-5"><a href="#panics-5">Panics</a></h5>
 <p>Panics if <code>size</code> is 0.</p>
-<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
+<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>, <span class="string">&#39;s&#39;</span>, <span class="string">&#39;t&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.windows(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>]);
@@ -642,7 +600,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 slice.</p>
 <h5 id="panics-6"><a href="#panics-6">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
+<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -658,7 +616,7 @@ exactly <code>chunk_size</code> elements, and <a href="https://doc.rust-lang.org
 the end of the slice.</p>
 <h5 id="panics-7"><a href="#panics-7">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
+<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
 
@@ -680,7 +638,7 @@ resulting code better than in the case of <a href="https://doc.rust-lang.org/nig
 chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.rchunks_exact" title="method slice::rchunks_exact"><code>rchunks_exact</code></a> for the same iterator but starting at the end of the slice.</p>
 <h5 id="panics-8"><a href="#panics-8">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
+<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -699,7 +657,7 @@ smaller chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slic
 the slice.</p>
 <h5 id="panics-9"><a href="#panics-9">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
+<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
 
@@ -712,13 +670,13 @@ the slice.</p>
 <span class="macro">assert_eq!</span>(v, <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">0</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_chunks_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#1259">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_chunks_unchecked" class="fn">as_chunks_unchecked</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; &amp;[<a class="pri [...]
 assuming that there’s no remainder.</p>
-<h5 id="safety-9"><a href="#safety-9">Safety</a></h5>
+<h5 id="safety-8"><a href="#safety-8">Safety</a></h5>
 <p>This may only be called when</p>
 <ul>
 <li>The slice splits exactly into <code>N</code>-element chunks (aka <code>self.len() % N == 0</code>).</li>
 <li><code>N != 0</code>.</li>
 </ul>
-<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
+<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice: <span class="kw-2">&amp;</span>[char] = <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>, <span class="string">&#39;!&#39;</span>];
 <span class="kw">let </span>chunks: <span class="kw-2">&amp;</span>[[char; <span class="number">1</span>]] =
@@ -739,7 +697,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-10"><a href="#panics-10">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
+<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(chunks, remainder) = slice.as_chunks();
@@ -760,7 +718,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-11"><a href="#panics-11">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
+<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(remainder, chunks) = slice.as_rchunks();
@@ -775,7 +733,7 @@ retrieved from the <code>remainder</code> function of the iterator.</p>
 <h5 id="panics-12"><a href="#panics-12">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
+<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_chunks();
@@ -787,13 +745,13 @@ error before this method gets stabilized.</p>
     &amp;mut self
 ) -&gt; &amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">[T; N]</a>]</h4></section><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>slice_as_chunks</code>)</span></div></span></summary><div class="docblock"><p>Splits the slice into a slice of <code>N</code>-element arrays,
 assuming that there’s no remainder.</p>
-<h5 id="safety-10"><a href="#safety-10">Safety</a></h5>
+<h5 id="safety-9"><a href="#safety-9">Safety</a></h5>
 <p>This may only be called when</p>
 <ul>
 <li>The slice splits exactly into <code>N</code>-element chunks (aka <code>self.len() % N == 0</code>).</li>
 <li><code>N != 0</code>.</li>
 </ul>
-<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
+<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice: <span class="kw-2">&amp;mut </span>[char] = <span class="kw-2">&amp;mut </span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>, <span class="string">&#39;!&#39;</span>];
 <span class="kw">let </span>chunks: <span class="kw-2">&amp;mut </span>[[char; <span class="number">1</span>]] =
@@ -816,7 +774,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-13"><a href="#panics-13">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
+<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
@@ -834,7 +792,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-14"><a href="#panics-14">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
+<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
@@ -855,7 +813,7 @@ can be retrieved from the <code>into_remainder</code> function of the iterator.<
 <h5 id="panics-15"><a href="#panics-15">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_chunks)]
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
@@ -872,7 +830,7 @@ starting at the beginning of the slice.</p>
 <h5 id="panics-16"><a href="#panics-16">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_windows)]
 </span><span class="kw">let </span>slice = [<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_windows();
@@ -889,7 +847,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 of the slice.</p>
 <h5 id="panics-17"><a href="#panics-17">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -905,7 +863,7 @@ exactly <code>chunk_size</code> elements, and <a href="https://doc.rust-lang.org
 beginning of the slice.</p>
 <h5 id="panics-18"><a href="#panics-18">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
 
@@ -928,7 +886,7 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 slice.</p>
 <h5 id="panics-19"><a href="#panics-19">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-52"><a href="#examples-52">Examples</a></h5>
+<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -947,7 +905,7 @@ smaller chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slic
 of the slice.</p>
 <h5 id="panics-20"><a href="#panics-20">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-53"><a href="#examples-53">Examples</a></h5>
+<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>, <span class="number">0</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">1</span>;
 
@@ -964,7 +922,7 @@ of elements using the predicate to separate them.</p>
 <p>The predicate is called on two elements following themselves,
 it means the predicate is called on <code>slice[0]</code> and <code>slice[1]</code>
 then on <code>slice[1]</code> and <code>slice[2]</code> and so on.</p>
-<h5 id="examples-54"><a href="#examples-54">Examples</a></h5>
+<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_group_by)]
 
 </span><span class="kw">let </span>slice = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">2</span>];
@@ -993,7 +951,7 @@ runs of elements using the predicate to separate them.</p>
 <p>The predicate is called on two elements following themselves,
 it means the predicate is called on <code>slice[0]</code> and <code>slice[1]</code>
 then on <code>slice[1]</code> and <code>slice[2]</code> and so on.</p>
-<h5 id="examples-55"><a href="#examples-55">Examples</a></h5>
+<h5 id="examples-52"><a href="#examples-52">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_group_by)]
 
 </span><span class="kw">let </span>slice = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">2</span>];
@@ -1022,7 +980,7 @@ the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-21"><a href="#panics-21">Panics</a></h5>
 <p>Panics if <code>mid &gt; len</code>.</p>
-<h5 id="examples-56"><a href="#examples-56">Examples</a></h5>
+<h5 id="examples-53"><a href="#examples-53">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
 
 {
@@ -1048,7 +1006,7 @@ the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-22"><a href="#panics-22">Panics</a></h5>
 <p>Panics if <code>mid &gt; len</code>.</p>
-<h5 id="examples-57"><a href="#examples-57">Examples</a></h5>
+<h5 id="examples-54"><a href="#examples-54">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">1</span>, <span class="number">0</span>, <span class="number">3</span>, <span class="number">0</span>, <span class="number">5</span>, <span class="number">6</span>];
 <span class="kw">let </span>(left, right) = v.split_at_mut(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(left, [<span class="number">1</span>, <span class="number">0</span>]);
@@ -1061,11 +1019,11 @@ right[<span class="number">1</span>] = <span class="number">4</span>;
 the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.split_at" title="method slice::split_at"><code>split_at</code></a>.</p>
-<h5 id="safety-11"><a href="#safety-11">Safety</a></h5>
+<h5 id="safety-10"><a href="#safety-10">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used. The caller has to ensure that
 <code>0 &lt;= mid &lt;= self.len()</code>.</p>
-<h5 id="examples-58"><a href="#examples-58">Examples</a></h5>
+<h5 id="examples-55"><a href="#examples-55">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_split_at_unchecked)]
 
 </span><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
@@ -1095,11 +1053,11 @@ even if the resulting reference is not used. The caller has to ensure that
 the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.split_at_mut" title="method slice::split_at_mut"><code>split_at_mut</code></a>.</p>
-<h5 id="safety-12"><a href="#safety-12">Safety</a></h5>
+<h5 id="safety-11"><a href="#safety-11">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used. The caller has to ensure that
 <code>0 &lt;= mid &lt;= self.len()</code>.</p>
-<h5 id="examples-59"><a href="#examples-59">Examples</a></h5>
+<h5 id="examples-56"><a href="#examples-56">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_split_at_unchecked)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">1</span>, <span class="number">0</span>, <span class="number">3</span>, <span class="number">0</span>, <span class="number">5</span>, <span class="number">6</span>];
@@ -1118,7 +1076,7 @@ the index <code>N</code> itself) and the slice will contain all
 indices from <code>[N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-23"><a href="#panics-23">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-60"><a href="#examples-60">Examples</a></h5>
+<h5 id="examples-57"><a href="#examples-57">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -1146,7 +1104,7 @@ the index <code>N</code> itself) and the slice will contain all
 indices from <code>[N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-24"><a href="#panics-24">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-61"><a href="#examples-61">Examples</a></h5>
+<h5 id="examples-58"><a href="#examples-58">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">0</span>, <span class="number">3</span>, <span class="number">0</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -1163,7 +1121,7 @@ the index <code>len - N</code> itself) and the array will contain all
 indices from <code>[len - N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-25"><a href="#panics-25">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-62"><a href="#examples-62">Examples</a></h5>
+<h5 id="examples-59"><a href="#examples-59">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -1192,7 +1150,7 @@ the index <code>N</code> itself) and the array will contain all
 indices from <code>[len - N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-26"><a href="#panics-26">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-63"><a href="#examples-63">Examples</a></h5>
+<h5 id="examples-60"><a href="#examples-60">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">0</span>, <span class="number">3</span>, <span class="number">0</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -1205,7 +1163,7 @@ right[<span class="number">1</span>] = <span class="number">4</span>;
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split" class="method"><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/slice/mod.rs.html#2222-2224">source</a></span><h4 class="code-header">pub fn <a href="#method.split" class="fn">split</a>&lt;F&gt;(&amp;self, pred: F) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core [...]
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is not contained in the subslices.</p>
-<h5 id="examples-64"><a href="#examples-64">Examples</a></h5>
+<h5 id="examples-61"><a href="#examples-61">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -1236,7 +1194,7 @@ present between them:</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_mut" class="method"><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/slice/mod.rs.html#2244-2246">source</a></span><h4 class="code-header">pub fn <a href="#method.split_mut" class="fn">split_mut</a>&lt;F&gt;(&amp;mut self, pred: F) -&gt; <a class="struct" href="https://doc.rust-lang. [...]
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over mutable subslices separated by elements that
 match <code>pred</code>. The matched element is not contained in the subslices.</p>
-<h5 id="examples-65"><a href="#examples-65">Examples</a></h5>
+<h5 id="examples-62"><a href="#examples-62">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>, <span class="number">20</span>, <span class="number">60</span>, <span class="number">50</span>];
 
 <span class="kw">for </span>group <span class="kw">in </span>v.split_mut(|num| <span class="kw-2">*</span>num % <span class="number">3 </span>== <span class="number">0</span>) {
@@ -1247,7 +1205,7 @@ match <code>pred</code>. The matched element is not contained in the subslices.<
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is contained in the end of the previous
 subslice as a terminator.</p>
-<h5 id="examples-66"><a href="#examples-66">Examples</a></h5>
+<h5 id="examples-63"><a href="#examples-63">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split_inclusive(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -1268,7 +1226,7 @@ That slice will be the last item returned by the iterator.</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over mutable subslices separated by elements that
 match <code>pred</code>. The matched element is contained in the previous
 subslice as a terminator.</p>
-<h5 id="examples-67"><a href="#examples-67">Examples</a></h5>
+<h5 id="examples-64"><a href="#examples-64">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>, <span class="number">20</span>, <span class="number">60</span>, <span class="number">50</span>];
 
 <span class="kw">for </span>group <span class="kw">in </span>v.split_inclusive_mut(|num| <span class="kw-2">*</span>num % <span class="number">3 </span>== <span class="number">0</span>) {
@@ -1280,7 +1238,7 @@ subslice as a terminator.</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>, starting at the end of the slice and working backwards.
 The matched element is not contained in the subslices.</p>
-<h5 id="examples-68"><a href="#examples-68">Examples</a></h5>
+<h5 id="examples-65"><a href="#examples-65">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">11</span>, <span class="number">22</span>, <span class="number">33</span>, <span class="number">0</span>, <span class="number">44</span>, <span class="number">55</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rsplit(|num| <span class="kw-2">*</span>num == <span class="number">0</span>);
 
@@ -1301,7 +1259,7 @@ slice will be the first (or last) item returned by the iterator.</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over mutable subslices separated by elements that
 match <code>pred</code>, starting at the end of the slice and working
 backwards. The matched element is not contained in the subslices.</p>
-<h5 id="examples-69"><a href="#examples-69">Examples</a></h5>
+<h5 id="examples-66"><a href="#examples-66">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">100</span>, <span class="number">400</span>, <span class="number">300</span>, <span class="number">200</span>, <span class="number">600</span>, <span class="number">500</span>];
 
 <span class="kw">let </span><span class="kw-2">mut </span>count = <span class="number">0</span>;
@@ -1316,7 +1274,7 @@ backwards. The matched element is not contained in the subslices.</p>
 not contained in the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-70"><a href="#examples-70">Examples</a></h5>
+<h5 id="examples-67"><a href="#examples-67">Examples</a></h5>
 <p>Print the slice split once by numbers divisible by 3 (i.e., <code>[10, 40]</code>,
 <code>[20, 60, 50]</code>):</p>
 
@@ -1331,7 +1289,7 @@ slice.</p>
 not contained in the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-71"><a href="#examples-71">Examples</a></h5>
+<h5 id="examples-68"><a href="#examples-68">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>, <span class="number">20</span>, <span class="number">60</span>, <span class="number">50</span>];
 
 <span class="kw">for </span>group <span class="kw">in </span>v.splitn_mut(<span class="number">2</span>, |num| <span class="kw-2">*</span>num % <span class="number">3 </span>== <span class="number">0</span>) {
@@ -1345,7 +1303,7 @@ the slice and works backwards. The matched element is not contained in
 the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-72"><a href="#examples-72">Examples</a></h5>
+<h5 id="examples-69"><a href="#examples-69">Examples</a></h5>
 <p>Print the slice split once, starting from the end, by numbers divisible
 by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
 
@@ -1361,7 +1319,7 @@ the slice and works backwards. The matched element is not contained in
 the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-73"><a href="#examples-73">Examples</a></h5>
+<h5 id="examples-70"><a href="#examples-70">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>s = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>, <span class="number">20</span>, <span class="number">60</span>, <span class="number">50</span>];
 
 <span class="kw">for </span>group <span class="kw">in </span>s.rsplitn_mut(<span class="number">2</span>, |num| <span class="kw-2">*</span>num % <span class="number">3 </span>== <span class="number">0</span>) {
@@ -1372,7 +1330,7 @@ slice.</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if the slice contains an element with the given value.</p>
 <p>This operation is <em>O</em>(<em>n</em>).</p>
 <p>Note that if you have a sorted slice, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a> may be faster.</p>
-<h5 id="examples-74"><a href="#examples-74">Examples</a></h5>
+<h5 id="examples-71"><a href="#examples-71">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.contains(<span class="kw-2">&amp;</span><span class="number">30</span>));
 <span class="macro">assert!</span>(!v.contains(<span class="kw-2">&amp;</span><span class="number">50</span>));</code></pre></div>
@@ -1385,7 +1343,7 @@ use <code>iter().any</code>:</p>
 </span><span class="macro">assert!</span>(!v.iter().any(|e| e == <span class="string">&quot;hi&quot;</span>));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.starts_with" class="method"><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/slice/mod.rs.html#2540-2542">source</a></span><h4 class="code-header">pub fn <a href="#method.starts_with" class="fn">starts_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/ni [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a prefix of the slice.</p>
-<h5 id="examples-75"><a href="#examples-75">Examples</a></h5>
+<h5 id="examples-72"><a href="#examples-72">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>]));
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]));
@@ -1399,7 +1357,7 @@ use <code>iter().any</code>:</p>
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[]));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.ends_with" class="method"><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/slice/mod.rs.html#2570-2572">source</a></span><h4 class="code-header">pub fn <a href="#method.ends_with" class="fn">ends_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/ [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a suffix of the slice.</p>
-<h5 id="examples-76"><a href="#examples-76">Examples</a></h5>
+<h5 id="examples-73"><a href="#examples-73">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">30</span>]));
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]));
@@ -1417,7 +1375,7 @@ use <code>iter().any</code>:</p>
 <p>If the slice starts with <code>prefix</code>, returns the subslice after the prefix, wrapped in <code>Some</code>.
 If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not start with <code>prefix</code>, returns <code>None</code>.</p>
-<h5 id="examples-77"><a href="#examples-77">Examples</a></h5>
+<h5 id="examples-74"><a href="#examples-74">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">30</span>][..]));
@@ -1433,7 +1391,7 @@ If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice ends with <code>suffix</code>, returns the subslice before the suffix, wrapped in <code>Some</code>.
 If <code>suffix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not end with <code>suffix</code>, returns <code>None</code>.</p>
-<h5 id="examples-78"><a href="#examples-78">Examples</a></h5>
+<h5 id="examples-75"><a href="#examples-75">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>][..]));
@@ -1451,7 +1409,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"> [...]
-<h5 id="examples-79"><a href="#examples-79">Examples</a></h5>
+<h5 id="examples-76"><a href="#examples-76">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -1508,7 +1466,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>par [...]
-<h5 id="examples-80"><a href="#examples-80">Examples</a></h5>
+<h5 id="examples-77"><a href="#examples-77">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -1543,7 +1501,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>partition_point [...]
-<h5 id="examples-81"><a href="#examples-81">Examples</a></h5>
+<h5 id="examples-78"><a href="#examples-78">Examples</a></h5>
 <p>Looks up a series of four elements in a slice of pairs sorted by
 their second elements. The first is found, with a uniquely
 determined position; the second and third are not found; the
@@ -1562,7 +1520,7 @@ fourth could match any position in <code>[1, 4]</code>.</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html" title="trait core::cmp::Ord">Ord</a>,</span></h4></section></summary><div class="docblock"><p>Sorts the slice, but might not preserve the order of equal elements.</p>
 <p>This sort is unstable (i.e., may reorder equal elements), in-place
 (i.e., does not allocate), and <em>O</em>(<em>n</em> * log(<em>n</em>)) worst-case.</p>
-<h5 id="current-implementation-1"><a href="#current-implementation-1">Current implementation</a></h5>
+<h5 id="current-implementation-2"><a href="#current-implementation-2">Current implementation</a></h5>
 <p>The current algorithm is based on <a href="https://github.com/orlp/pdqsort">pattern-defeating quicksort</a> by Orson Peters,
 which combines the fast average case of randomized quicksort with the fast worst case of
 heapsort, while achieving linear time on slices with certain patterns. It uses some
@@ -1570,7 +1528,7 @@ randomization to avoid degenerate cases, but with a fixed seed to always provide
 deterministic behavior.</p>
 <p>It is typically faster than stable sorting, except in a few special cases, e.g., when the
 slice consists of several concatenated sorted sequences.</p>
-<h5 id="examples-82"><a href="#examples-82">Examples</a></h5>
+<h5 id="examples-79"><a href="#examples-79">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [-<span class="number">5</span>, <span class="number">4</span>, <span class="number">1</span>, -<span class="number">3</span>, <span class="number">2</span>];
 
 v.sort_unstable();
@@ -1593,7 +1551,7 @@ total order if it is (for all <code>a</code>, <code>b</code> and <code>c</code>)
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>floats = [<span class="number">5f64</span>, <span class="number">4.0</span>, <span class="number">1.0</span>, <span class="number">3.0</span>, <span class="number">2.0</span>];
 floats.sort_unstable_by(|a, b| a.partial_cmp(b).unwrap());
 <span class="macro">assert_eq!</span>(floats, [<span class="number">1.0</span>, <span class="number">2.0</span>, <span class="number">3.0</span>, <span class="number">4.0</span>, <span class="number">5.0</span>]);</code></pre></div>
-<h5 id="current-implementation-2"><a href="#current-implementation-2">Current implementation</a></h5>
+<h5 id="current-implementation-3"><a href="#current-implementation-3">Current implementation</a></h5>
 <p>The current algorithm is based on <a href="https://github.com/orlp/pdqsort">pattern-defeating quicksort</a> by Orson Peters,
 which combines the fast average case of randomized quicksort with the fast worst case of
 heapsort, while achieving linear time on slices with certain patterns. It uses some
@@ -1601,7 +1559,7 @@ randomization to avoid degenerate cases, but with a fixed seed to always provide
 deterministic behavior.</p>
 <p>It is typically faster than stable sorting, except in a few special cases, e.g., when the
 slice consists of several concatenated sorted sequences.</p>
-<h5 id="examples-83"><a href="#examples-83">Examples</a></h5>
+<h5 id="examples-80"><a href="#examples-80">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">5</span>, <span class="number">4</span>, <span class="number">1</span>, <span class="number">3</span>, <span class="number">2</span>];
 v.sort_unstable_by(|a, b| a.cmp(b));
 <span class="macro">assert!</span>(v == [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>]);
@@ -1616,7 +1574,7 @@ elements.</p>
 <p>This sort is unstable (i.e., may reorder equal elements), in-place
 (i.e., does not allocate), and <em>O</em>(<em>m</em> * <em>n</em> * log(<em>n</em>)) worst-case, where the key function is
 <em>O</em>(<em>m</em>).</p>
-<h5 id="current-implementation-3"><a href="#current-implementation-3">Current implementation</a></h5>
+<h5 id="current-implementation-4"><a href="#current-implementation-4">Current implementation</a></h5>
 <p>The current algorithm is based on <a href="https://github.com/orlp/pdqsort">pattern-defeating quicksort</a> by Orson Peters,
 which combines the fast average case of randomized quicksort with the fast worst case of
 heapsort, while achieving linear time on slices with certain patterns. It uses some
@@ -1625,7 +1583,7 @@ deterministic behavior.</p>
 <p>Due to its key calling strategy, <a href="#method.sort_unstable_by_key"><code>sort_unstable_by_key</code></a>
 is likely to be slower than <a href="#method.sort_by_cached_key"><code>sort_by_cached_key</code></a> in
 cases where the key function is expensive.</p>
-<h5 id="examples-84"><a href="#examples-84">Examples</a></h5>
+<h5 id="examples-81"><a href="#examples-81">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [-<span class="number">5i32</span>, <span class="number">4</span>, <span class="number">1</span>, -<span class="number">3</span>, <span class="number">2</span>];
 
 v.sort_unstable_by_key(|k| k.abs());
@@ -1644,13 +1602,13 @@ This function is also known as “kth element” in other libraries.</p>
 the subslice prior to <code>index</code>, the element at <code>index</code>, and the subslice after <code>index</code>;
 accordingly, the values in those two subslices will respectively all be less-than-or-equal-to
 and greater-than-or-equal-to the value of the element at <code>index</code>.</p>
-<h5 id="current-implementation-4"><a href="#current-implementation-4">Current implementation</a></h5>
+<h5 id="current-implementation-5"><a href="#current-implementation-5">Current implementation</a></h5>
 <p>The current algorithm is an introselect implementation based on Pattern Defeating Quicksort, which is also
 the basis for <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.sort_unstable" title="method slice::sort_unstable"><code>sort_unstable</code></a>. The fallback algorithm is Median of Medians using Tukey’s Ninther for
 pivot selection, which guarantees linear runtime for all inputs.</p>
 <h5 id="panics-27"><a href="#panics-27">Panics</a></h5>
 <p>Panics when <code>index &gt;= len()</code>, meaning it always panics on empty slices.</p>
-<h5 id="examples-85"><a href="#examples-85">Examples</a></h5>
+<h5 id="examples-82"><a href="#examples-82">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [-<span class="number">5i32</span>, <span class="number">4</span>, <span class="number">1</span>, -<span class="number">3</span>, <span class="number">2</span>];
 
 <span class="comment">// Find the median
@@ -1679,13 +1637,13 @@ the slice reordered according to the provided comparator function: the subslice
 <code>index</code>, the element at <code>index</code>, and the subslice after <code>index</code>; accordingly, the values in
 those two subslices will respectively all be less-than-or-equal-to and greater-than-or-equal-to
 the value of the element at <code>index</code>.</p>
-<h5 id="current-implementation-5"><a href="#current-implementation-5">Current implementation</a></h5>
+<h5 id="current-implementation-6"><a href="#current-implementation-6">Current implementation</a></h5>
 <p>The current algorithm is an introselect implementation based on Pattern Defeating Quicksort, which is also
 the basis for <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.sort_unstable" title="method slice::sort_unstable"><code>sort_unstable</code></a>. The fallback algorithm is Median of Medians using Tukey’s Ninther for
 pivot selection, which guarantees linear runtime for all inputs.</p>
 <h5 id="panics-28"><a href="#panics-28">Panics</a></h5>
 <p>Panics when <code>index &gt;= len()</code>, meaning it always panics on empty slices.</p>
-<h5 id="examples-86"><a href="#examples-86">Examples</a></h5>
+<h5 id="examples-83"><a href="#examples-83">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [-<span class="number">5i32</span>, <span class="number">4</span>, <span class="number">1</span>, -<span class="number">3</span>, <span class="number">2</span>];
 
 <span class="comment">// Find the median as if the slice were sorted in descending order.
@@ -1715,13 +1673,13 @@ the slice reordered according to the provided key extraction function: the subsl
 <code>index</code>, the element at <code>index</code>, and the subslice after <code>index</code>; accordingly, the values in
 those two subslices will respectively all be less-than-or-equal-to and greater-than-or-equal-to
 the value of the element at <code>index</code>.</p>
-<h5 id="current-implementation-6"><a href="#current-implementation-6">Current implementation</a></h5>
+<h5 id="current-implementation-7"><a href="#current-implementation-7">Current implementation</a></h5>
 <p>The current algorithm is an introselect implementation based on Pattern Defeating Quicksort, which is also
 the basis for <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.sort_unstable" title="method slice::sort_unstable"><code>sort_unstable</code></a>. The fallback algorithm is Median of Medians using Tukey’s Ninther for
 pivot selection, which guarantees linear runtime for all inputs.</p>
 <h5 id="panics-29"><a href="#panics-29">Panics</a></h5>
 <p>Panics when <code>index &gt;= len()</code>, meaning it always panics on empty slices.</p>
-<h5 id="examples-87"><a href="#examples-87">Examples</a></h5>
+<h5 id="examples-84"><a href="#examples-84">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>v = [-<span class="number">5i32</span>, <span class="number">4</span>, <span class="number">1</span>, -<span class="number">3</span>, <span class="number">2</span>];
 
 <span class="comment">// Return the median as if the array were sorted according to absolute value.
@@ -1739,7 +1697,7 @@ pivot selection, which guarantees linear runtime for all inputs.</p>
 <p>Returns two slices. The first contains no consecutive repeated elements.
 The second contains all the duplicates in no specified order.</p>
 <p>If the slice is sorted, the first returned slice contains no duplicates.</p>
-<h5 id="examples-88"><a href="#examples-88">Examples</a></h5>
+<h5 id="examples-85"><a href="#examples-85">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_partition_dedup)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">2</span>, <span class="number">1</span>, <span class="number">1</span>];
@@ -1758,7 +1716,7 @@ must determine if the elements compare equal. The elements are passed in opposit
 from their order in the slice, so if <code>same_bucket(a, b)</code> returns <code>true</code>, <code>a</code> is moved
 at the end of the slice.</p>
 <p>If the slice is sorted, the first returned slice contains no duplicates.</p>
-<h5 id="examples-89"><a href="#examples-89">Examples</a></h5>
+<h5 id="examples-86"><a href="#examples-86">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_partition_dedup)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice = [<span class="string">&quot;foo&quot;</span>, <span class="string">&quot;Foo&quot;</span>, <span class="string">&quot;BAZ&quot;</span>, <span class="string">&quot;Bar&quot;</span>, <span class="string">&quot;bar&quot;</span>, <span class="string">&quot;baz&quot;</span>, <span class="string">&quot;BAZ&quot;</span>];
@@ -1774,7 +1732,7 @@ to the same key.</p>
 <p>Returns two slices. The first contains no consecutive repeated elements.
 The second contains all the duplicates in no specified order.</p>
 <p>If the slice is sorted, the first returned slice contains no duplicates.</p>
-<h5 id="examples-90"><a href="#examples-90">Examples</a></h5>
+<h5 id="examples-87"><a href="#examples-87">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_partition_dedup)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice = [<span class="number">10</span>, <span class="number">20</span>, <span class="number">21</span>, <span class="number">30</span>, <span class="number">30</span>, <span class="number">20</span>, <span class="number">11</span>, <span class="number">13</span>];
@@ -1793,7 +1751,7 @@ slice. Note that <code>mid == self.len()</code> does <em>not</em> panic and is a
 rotation.</p>
 <h5 id="complexity"><a href="#complexity">Complexity</a></h5>
 <p>Takes linear (in <code>self.len()</code>) time.</p>
-<h5 id="examples-91"><a href="#examples-91">Examples</a></h5>
+<h5 id="examples-88"><a href="#examples-88">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>a = [<span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>, <span class="string">&#39;d&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;f&#39;</span>];
 a.rotate_left(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(a, [<span class="string">&#39;c&#39;</span>, <span class="string">&#39;d&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;f&#39;</span>, <span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>]);</code></pre></div>
@@ -1812,7 +1770,7 @@ slice. Note that <code>k == self.len()</code> does <em>not</em> panic and is a n
 rotation.</p>
 <h5 id="complexity-1"><a href="#complexity-1">Complexity</a></h5>
 <p>Takes linear (in <code>self.len()</code>) time.</p>
-<h5 id="examples-92"><a href="#examples-92">Examples</a></h5>
+<h5 id="examples-89"><a href="#examples-89">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>a = [<span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>, <span class="string">&#39;d&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;f&#39;</span>];
 a.rotate_right(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(a, [<span class="string">&#39;e&#39;</span>, <span class="string">&#39;f&#39;</span>, <span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>, <span class="string">&#39;d&#39;</span>]);</code></pre></div>
@@ -1823,7 +1781,7 @@ a[<span class="number">1</span>..<span class="number">5</span>].rotate_right(<sp
 <span class="macro">assert_eq!</span>(a, [<span class="string">&#39;a&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>, <span class="string">&#39;d&#39;</span>, <span class="string">&#39;f&#39;</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.fill" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.50.0">1.50.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#3442-3444">source</a></span><h4 class="code-header">pub fn <a href="#method.fill" class="fn">fill</a>(&amp;mut self, value: T)<span class="where fmt-newline">where
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a>,</span></h4></section></summary><div class="docblock"><p>Fills <code>self</code> with elements by cloning <code>value</code>.</p>
-<h5 id="examples-93"><a href="#examples-93">Examples</a></h5>
+<h5 id="examples-90"><a href="#examples-90">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>buf = <span class="macro">vec!</span>[<span class="number">0</span>; <span class="number">10</span>];
 buf.fill(<span class="number">1</span>);
 <span class="macro">assert_eq!</span>(buf, <span class="macro">vec!</span>[<span class="number">1</span>; <span class="number">10</span>]);</code></pre></div>
@@ -1833,7 +1791,7 @@ buf.fill(<span class="number">1</span>);
 <a href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone"><code>Clone</code></a> a given value, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.fill" title="method slice::fill"><code>fill</code></a>. If you want to use the <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::default::Default"><code>Default</code></a>
 trait to generate values, you can pass <a href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html#tymethod.default" title="associated function core::default::Default::default"><code>Default::default</code></a> as the
 argument.</p>
-<h5 id="examples-94"><a href="#examples-94">Examples</a></h5>
+<h5 id="examples-91"><a href="#examples-91">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>buf = <span class="macro">vec!</span>[<span class="number">1</span>; <span class="number">10</span>];
 buf.fill_with(Default::default);
 <span class="macro">assert_eq!</span>(buf, <span class="macro">vec!</span>[<span class="number">0</span>; <span class="number">10</span>]);</code></pre></div>
@@ -1842,7 +1800,7 @@ buf.fill_with(Default::default);
 <p>The length of <code>src</code> must be the same as <code>self</code>.</p>
 <h5 id="panics-32"><a href="#panics-32">Panics</a></h5>
 <p>This function will panic if the two slices have different lengths.</p>
-<h5 id="examples-95"><a href="#examples-95">Examples</a></h5>
+<h5 id="examples-92"><a href="#examples-92">Examples</a></h5>
 <p>Cloning two elements from a slice into another:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>src = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>];
@@ -1880,7 +1838,7 @@ sub-slices from a slice:</p>
 <p>If <code>T</code> does not implement <code>Copy</code>, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.clone_from_slice" title="method slice::clone_from_slice"><code>clone_from_slice</code></a>.</p>
 <h5 id="panics-33"><a href="#panics-33">Panics</a></h5>
 <p>This function will panic if the two slices have different lengths.</p>
-<h5 id="examples-96"><a href="#examples-96">Examples</a></h5>
+<h5 id="examples-93"><a href="#examples-93">Examples</a></h5>
 <p>Copying two elements from a slice into another:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>src = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>];
@@ -1923,7 +1881,7 @@ must be less than or equal to <code>self.len()</code>.</p>
 <h5 id="panics-34"><a href="#panics-34">Panics</a></h5>
 <p>This function will panic if either range exceeds the end of the slice,
 or if the end of <code>src</code> is before the start.</p>
-<h5 id="examples-97"><a href="#examples-97">Examples</a></h5>
+<h5 id="examples-94"><a href="#examples-94">Examples</a></h5>
 <p>Copying four bytes within a slice:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span><span class="kw-2">mut </span>bytes = <span class="kw-2">*</span><span class="string">b&quot;Hello, World!&quot;</span>;
@@ -1973,10 +1931,10 @@ matter, such as a sanitizer attempting to find alignment bugs. Regular code runn
 in a default (debug or release) execution <em>will</em> return a maximal middle part.</p>
 <p>This method has no purpose when either input element <code>T</code> or output element <code>U</code> are
 zero-sized and will return the original slice without splitting anything.</p>
-<h5 id="safety-13"><a href="#safety-13">Safety</a></h5>
+<h5 id="safety-12"><a href="#safety-12">Safety</a></h5>
 <p>This method is essentially a <code>transmute</code> with respect to the elements in the returned
 middle slice, so all the usual caveats pertaining to <code>transmute::&lt;T, U&gt;</code> also apply here.</p>
-<h5 id="examples-98"><a href="#examples-98">Examples</a></h5>
+<h5 id="examples-95"><a href="#examples-95">Examples</a></h5>
 <p>Basic usage:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">unsafe </span>{
@@ -1996,10 +1954,10 @@ matter, such as a sanitizer attempting to find alignment bugs. Regular code runn
 in a default (debug or release) execution <em>will</em> return a maximal middle part.</p>
 <p>This method has no purpose when either input element <code>T</code> or output element <code>U</code> are
 zero-sized and will return the original slice without splitting anything.</p>
-<h5 id="safety-14"><a href="#safety-14">Safety</a></h5>
+<h5 id="safety-13"><a href="#safety-13">Safety</a></h5>
 <p>This method is essentially a <code>transmute</code> with respect to the elements in the returned
 middle slice, so all the usual caveats pertaining to <code>transmute::&lt;T, U&gt;</code> also apply here.</p>
-<h5 id="examples-99"><a href="#examples-99">Examples</a></h5>
+<h5 id="examples-96"><a href="#examples-96">Examples</a></h5>
 <p>Basic usage:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">unsafe </span>{
@@ -2032,7 +1990,7 @@ that from ever happening, as only power-of-two numbers of lanes are
 supported.  It’s possible that, in the future, those restrictions might
 be lifted in a way that would make it possible to see panics from this
 method for something like <code>LANES == 3</code>.</p>
-<h5 id="examples-100"><a href="#examples-100">Examples</a></h5>
+<h5 id="examples-97"><a href="#examples-97">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(portable_simd)]
 </span><span class="kw">use </span>core::simd::SimdFloat;
 
@@ -2094,7 +2052,7 @@ slice yields exactly zero or one element, <code>true</code> is returned.</p>
 <p>Note that if <code>Self::Item</code> is only <code>PartialOrd</code>, but not <code>Ord</code>, the above definition
 implies that this function returns <code>false</code> if any two consecutive items are not
 comparable.</p>
-<h5 id="examples-101"><a href="#examples-101">Examples</a></h5>
+<h5 id="examples-98"><a href="#examples-98">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 </span><span class="kw">let </span>empty: [i32; <span class="number">0</span>] = [];
 
@@ -2114,7 +2072,7 @@ function to determine the ordering of two elements. Apart from that, it’s equi
 <p>Instead of comparing the slice’s elements directly, this function compares the keys of the
 elements, as determined by <code>f</code>. Apart from that, it’s equivalent to <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.is_sorted" title="method slice::is_sorted"><code>is_sorted</code></a>; see its
 documentation for more information.</p>
-<h5 id="examples-102"><a href="#examples-102">Examples</a></h5>
+<h5 id="examples-99"><a href="#examples-99">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 
 </span><span class="macro">assert!</span>([<span class="string">&quot;c&quot;</span>, <span class="string">&quot;bb&quot;</span>, <span class="string">&quot;aaa&quot;</span>].is_sorted_by_key(|s| s.len()));
@@ -2130,7 +2088,7 @@ For example, <code>[7, 15, 3, 5, 4, 12, 6]</code> is partitioned under the predi
 <p>If this slice is not partitioned, the returned result is unspecified and meaningless,
 as this method performs a kind of binary search.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binar [...]
-<h5 id="examples-103"><a href="#examples-103">Examples</a></h5>
+<h5 id="examples-100"><a href="#examples-100">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">6</span>, <span class="number">7</span>];
 <span class="kw">let </span>i = v.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; <span class="number">5</span>);
 
@@ -2159,7 +2117,7 @@ and returns a reference to it.</p>
 range is out of bounds.</p>
 <p>Note that this method only accepts one-sided ranges such as
 <code>2..</code> or <code>..6</code>, but not <code>2..6</code>.</p>
-<h5 id="examples-104"><a href="#examples-104">Examples</a></h5>
+<h5 id="examples-101"><a href="#examples-101">Examples</a></h5>
 <p>Taking the first three elements of a slice:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_take)]
@@ -2196,7 +2154,7 @@ and returns a mutable reference to it.</p>
 range is out of bounds.</p>
 <p>Note that this method only accepts one-sided ranges such as
 <code>2..</code> or <code>..6</code>, but not <code>2..6</code>.</p>
-<h5 id="examples-105"><a href="#examples-105">Examples</a></h5>
+<h5 id="examples-102"><a href="#examples-102">Examples</a></h5>
 <p>Taking the first three elements of a slice:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_take)]
@@ -2229,7 +2187,7 @@ range is out of bounds.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.take_first" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4303">source</a><h4 class="code-header">pub fn <a href="#method.take_first" class="fn">take_first</a>&lt;'a&gt;(self: &amp;mut &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/ [...]
 to it.</p>
 <p>Returns <code>None</code> if the slice is empty.</p>
-<h5 id="examples-106"><a href="#examples-106">Examples</a></h5>
+<h5 id="examples-103"><a href="#examples-103">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_take)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice: <span class="kw-2">&amp;</span>[<span class="kw">_</span>] = <span class="kw-2">&amp;</span>[<span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>];
@@ -2240,7 +2198,7 @@ to it.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.take_first_mut" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4328">source</a><h4 class="code-header">pub fn <a href="#method.take_first_mut" class="fn">take_first_mut</a>&lt;'a&gt;(self: &amp;mut &amp;'a mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>) -&gt; <a class="enum" href="https://do [...]
 reference to it.</p>
 <p>Returns <code>None</code> if the slice is empty.</p>
-<h5 id="examples-107"><a href="#examples-107">Examples</a></h5>
+<h5 id="examples-104"><a href="#examples-104">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_take)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice: <span class="kw-2">&amp;mut </span>[<span class="kw">_</span>] = <span class="kw-2">&amp;mut </span>[<span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>];
@@ -2252,7 +2210,7 @@ reference to it.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.take_last" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4352">source</a><h4 class="code-header">pub fn <a href="#method.take_last" class="fn">take_last</a>&lt;'a&gt;(self: &amp;mut &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nig [...]
 to it.</p>
 <p>Returns <code>None</code> if the slice is empty.</p>
-<h5 id="examples-108"><a href="#examples-108">Examples</a></h5>
+<h5 id="examples-105"><a href="#examples-105">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_take)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice: <span class="kw-2">&amp;</span>[<span class="kw">_</span>] = <span class="kw-2">&amp;</span>[<span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>];
@@ -2263,7 +2221,7 @@ to it.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.take_last_mut" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4377">source</a><h4 class="code-header">pub fn <a href="#method.take_last_mut" class="fn">take_last_mut</a>&lt;'a&gt;(self: &amp;mut &amp;'a mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>) -&gt; <a class="enum" href="https://doc.r [...]
 reference to it.</p>
 <p>Returns <code>None</code> if the slice is empty.</p>
-<h5 id="examples-109"><a href="#examples-109">Examples</a></h5>
+<h5 id="examples-106"><a href="#examples-106">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_take)]
 
 </span><span class="kw">let </span><span class="kw-2">mut </span>slice: <span class="kw-2">&amp;mut </span>[<span class="kw">_</span>] = <span class="kw-2">&amp;mut </span>[<span class="string">&#39;a&#39;</span>, <span class="string">&#39;b&#39;</span>, <span class="string">&#39;c&#39;</span>];
@@ -2277,10 +2235,10 @@ reference to it.</p>
     indices: [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">N</a>]
 ) -&gt; [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut T</a>; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">N</a>]</h4></section><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>get_many_mut</code>)</span></div></span></summary><div class="docblock"><p>Returns mutable references to many indices at once, without  [...]
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get_many_mut" title="method slice::get_many_mut"><code>get_many_mut</code></a>.</p>
-<h5 id="safety-15"><a href="#safety-15">Safety</a></h5>
+<h5 id="safety-14"><a href="#safety-14">Safety</a></h5>
 <p>Calling this method with overlapping or out-of-bounds indices is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting references are not used.</p>
-<h5 id="examples-110"><a href="#examples-110">Examples</a></h5>
+<h5 id="examples-107"><a href="#examples-107">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(get_many_mut)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
@@ -2297,7 +2255,7 @@ even if the resulting references are not used.</p>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut T</a>; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.array.html">N</a>], <a class="struct" href="https://doc.rust-lang.org/nightly/core/slice/struct.GetManyMutError.html" title="struct core::slice::GetManyMutError">GetMa [...]
 <p>Returns an error if any index is out-of-bounds, or if the same index was
 passed more than once.</p>
-<h5 id="examples-111"><a href="#examples-111">Examples</a></h5>
+<h5 id="examples-108"><a href="#examples-108">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(get_many_mut)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;mut </span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
@@ -2306,19 +2264,61 @@ passed more than once.</p>
     <span class="kw-2">*</span>b = <span class="number">612</span>;
 }
 <span class="macro">assert_eq!</span>(v, <span class="kw-2">&amp;</span>[<span class="number">413</span>, <span class="number">2</span>, <span class="number">612</span>]);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.sort_floats-1" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4571">source</a><h4 class="code-header">pub fn <a href="#method.sort_floats-1" class="fn">sort_floats</a>(&amp;mut self)</h4></section><span class="item-info"><div class="stab unstable"><span class="emoji">🔬</span><span>This is a nightly-only experimental API. (<code>sort_floats</c [...]
-<p>This sort is in-place (i.e. does not allocate), <em>O</em>(<em>n</em> * log(<em>n</em>)) worst-case, and uses
-the ordering defined by <a href="https://doc.rust-lang.org/nightly/std/primitive.f32.html#method.total_cmp" title="method f32::total_cmp"><code>f32::total_cmp</code></a>.</p>
-<h5 id="current-implementation-7"><a href="#current-implementation-7">Current implementation</a></h5>
-<p>This uses the same sorting algorithm as <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.sort_unstable_by" title="method slice::sort_unstable_by"><code>sort_unstable_by</code></a>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
+<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
+without checking whether they’re valid.</p>
+<h5 id="safety-15"><a href="#safety-15">Safety</a></h5>
+<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
+<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
+but without allocating and copying temporaries.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.make_ascii_uppercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#72">source</a></span><h4 class="code-header">pub fn <a href="#method.make_ascii_uppercase" class="fn">make_ascii_uppercase</a>(&amp;mut self)</h4></section></summary><div class="docb [...]
+<p>ASCII letters ‘a’ to ‘z’ are mapped to ‘A’ to ‘Z’,
+but non-ASCII letters are unchanged.</p>
+<p>To return a new uppercased value without modifying the existing one, use
+<a href="#method.to_ascii_uppercase"><code>to_ascii_uppercase</code></a>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.make_ascii_lowercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#89">source</a></span><h4 class="code-header">pub fn <a href="#method.make_ascii_lowercase" class="fn">make_ascii_lowercase</a>(&amp;mut self)</h4></section></summary><div class="docb [...]
+<p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
+but non-ASCII letters are unchanged.</p>
+<p>To return a new lowercased value without modifying the existing one, use
+<a href="#method.to_ascii_lowercase"><code>to_ascii_lowercase</code></a>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
+treating it as an ASCII string.</p>
+<h5 id="examples-109"><a href="#examples-109">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
+<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
+<span class="kw">let </span>escaped = s.escape_ascii().to_string();
+<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-110"><a href="#examples-110">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-111"><a href="#examples-111">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
+removed.</p>
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
 <h5 id="examples-112"><a href="#examples-112">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(sort_floats)]
-</span><span class="kw">let </span><span class="kw-2">mut </span>v = [<span class="number">2.6</span>, -<span class="number">5e-8</span>, f32::NAN, <span class="number">8.29</span>, f32::INFINITY, -<span class="number">1.0</span>, <span class="number">0.0</span>, -f32::INFINITY, -<span class="number">0.0</span>];
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
 
-v.sort_floats();
-<span class="kw">let </span>sorted = [-f32::INFINITY, -<span class="number">1.0</span>, -<span class="number">5e-8</span>, -<span class="number">0.0</span>, <span class="number">0.0</span>, <span class="number">2.6</span>, <span class="number">8.29</span>, f32::INFINITY, f32::NAN];
-<span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>v[..<span class="number">8</span>], <span class="kw-2">&amp;</span>sorted[..<span class="number">8</span>]);
-<span class="macro">assert!</span>(v[<span class="number">8</span>].is_nan());</code></pre></div>
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_ascii_uppercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/alloc/slice.rs.html#621">source</a></span><h4 class="code-header">pub fn <a href="#method.to_ascii_uppercase" class="fn">to_ascii_uppercase</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.or [...]
 is mapped to its ASCII upper case equivalent.</p>
 <p>ASCII letters ‘a’ to ‘z’ are mapped to ‘A’ to ‘Z’,
@@ -2488,9 +2488,9 @@ given separator between each.</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = A&gt;,</span></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><summ [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#114">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.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></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/mutable.rs.html#498">source</a><a href="#method.from-1" 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>,</span></h3></section></summary><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_buffer/buffer/mutable.rs.html#782">source</a><a href="#method.from_iter-1" class="anchor">§</a><h4 class="code-header">fn <a href="https:// [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></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/buffer/mutable.rs.html#782">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc. [...]
     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;,</span></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"  [...]
-</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_buffer/buffer/mutable.rs.html#728-730">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" hre [...]
+</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_buffer/buffer/mutable.rs.html#728-730">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="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;,</span></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_it [...]
 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#226">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><section id="impl-Send-for-MutableBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#702">source</a><a href="#impl-Send-for-MutableBuffer" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a> for <a class="struct" href="str [...]
diff --git a/arrow/buffer/struct.NullBuffer.html b/arrow/buffer/struct.NullBuffer.html
index d610619376..08fb980263 100644
--- a/arrow/buffer/struct.NullBuffer.html
+++ b/arrow/buffer/struct.NullBuffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A `BooleanBuffer` used to encode validity for arrow arrays"><title>NullBuffer in arrow::buffer - Rust</title><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 `BooleanBuffer` used to encode validity for arrow arrays"><title>NullBuffer in arrow::buffer - Rust</title><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 [...]
     buffer: <a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a>,
     null_count: <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>A <a href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer"><code>BooleanBuffer</code></a> used to encode validity for arrow arrays</p>
@@ -49,7 +49,7 @@ the child of a FixedSizeListArray based on its parent</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.inner" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/null.rs.html#203">source</a><h4 class="code-header">pub fn <a href="#method.inner" class="fn">inner</a>(&amp;self) -&gt; &amp;<a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Returns the inner <a href="struct [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.into_inner" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/null.rs.html#209">source</a><h4 class="code-header">pub fn <a href="#method.into_inner" class="fn">into_inner</a>(self) -&gt; <a class="struct" href="struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Returns the inner <a href="s [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.buffer" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/null.rs.html#215">source</a><h4 class="code-header">pub fn <a href="#method.buffer" class="fn">buffer</a>(&amp;self) -&gt; &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the underlying <a href="struct.Buffer.html" [...]
-</div></details></div></details></div><h2 id="trait-implementations" class="small-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-NullBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/null.rs.html#29">source</a><a href="#impl-Clone-for-NullBuffer" class="anchor">§</a><h3 class="code-header [...]
+</div></details></div></details></div><h2 id="trait-implementations" class="small-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-NullBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/null.rs.html#29">source</a><a href="#impl-Clone-for-NullBuffer" class="anchor">§</a><h3 class="code-header [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>&gt;,</span></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_it [...]
 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#226">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><section id="impl-Eq-for-NullBuffer" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/null.rs.html#29">source</a><a href="#impl-Eq-for-NullBuffer" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.Eq.html" title="trait core::cmp::Eq">Eq</a> for <a class="struct" href="struct.NullBuffer.html" title [...]
diff --git a/arrow/buffer/struct.OffsetBuffer.html b/arrow/buffer/struct.OffsetBuffer.html
index 506d3500c9..d61e12e56b 100644
--- a/arrow/buffer/struct.OffsetBuffer.html
+++ b/arrow/buffer/struct.OffsetBuffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A non-empty buffer of monotonically increasing, positive integers."><title>OffsetBuffer in arrow::buffer - Rust</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 non-empty buffer of monotonically increasing, positive integers."><title>OffsetBuffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
 <span class="where">where
     O: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a></span>;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A non-empty buffer of monotonically increasing, positive integers.</p>
 <p><a href="struct.OffsetBuffer.html" title="struct arrow::buffer::OffsetBuffer"><code>OffsetBuffer</code></a> are used to represent ranges of offsets. An
@@ -51,7 +51,9 @@ values greater than or equal to zero</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.inner" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/offset.rs.html#138">source</a><h4 class="code-header">pub fn <a href="#method.inner" class="fn">inner</a>(&amp;self) -&gt; &amp;<a class="struct" href="struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;O&gt;</h4></section></summary><div class="docblock"><p>Returns the inner <a href [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.into_inner" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/offset.rs.html#143">source</a><h4 class="code-header">pub fn <a href="#method.into_inner" class="fn">into_inner</a>(self) -&gt; <a class="struct" href="struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;O&gt;</h4></section></summary><div class="docblock"><p>Returns the inner <a [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/offset.rs.html#148">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize< [...]
-</div></details></div></details></div><h2 id="deref-methods-%5BT%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;</span><a href="#deref-methods-%5BT%5D" class="anchor">§</a></h2><div id="deref-methods-%5BT%5D-1" class="impl-items"><details  [...]
+</div></details></div></details></div><h2 id="deref-methods-%5BT%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;</span><a href="#deref-methods-%5BT%5D" class="anchor">§</a></h2><div id="deref-methods-%5BT%5D-1" class="impl-items"><details  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.flatten" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4496">source</a><h4 class="code-header">pub fn <a href="#method.flatten" class="fn">flatten</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section><span class="item-info"><div class="stab unstable"><span clas [...]
 <h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
 <p>This panics if the length of the resulting slice would overflow a <code>usize</code>.</p>
 <p>This is only possible when flattening a slice of arrays of zero-sized
@@ -72,70 +74,23 @@ types, and thus tends to be irrelevant in practice. If
 
 <span class="kw">let </span>empty_slice_of_arrays: <span class="kw-2">&amp;</span>[[u32; <span class="number">10</span>]] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert!</span>(empty_slice_of_arrays.flatten().is_empty());</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
-<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
-without checking whether they’re valid.</p>
-<h5 id="safety-1"><a href="#safety-1">Safety</a></h5>
-<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
-<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
-but without allocating and copying temporaries.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
-treating it as an ASCII string.</p>
-<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
-<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
-<span class="kw">let </span>escaped = s.escape_ascii().to_string();
-<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
-removed.</p>
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_str" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#544">source</a><h4 class="code-header">pub fn <a href="#method.as_str" class="fn">as_str</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section><span class="item-info"><div class="stab unstable"><span cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><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/slice/mod.rs.html#141">source</a></span><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize [...]
-<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
+<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert_eq!</span>(a.len(), <span class="number">3</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><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/slice/mod.rs.html#157">source</a></span><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bo [...]
-<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
+<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert!</span>(!a.is_empty());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first" class="method"><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/slice/mod.rs.html#176">source</a></span><h4 class="code-header">pub fn <a href="#method.first" class="fn">first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html"  [...]
-<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
+<h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">10</span>), v.first());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.first());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#216">source</a></span><h4 class="code-header">pub fn <a href="#method.split_first" class="fn">split_first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/ [...]
-<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
+<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((first, elements)) = x.split_first() {
@@ -143,7 +98,7 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#258">source</a></span><h4 class="code-header">pub fn <a href="#method.split_last" class="fn">split_last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enu [...]
-<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
+<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((last, elements)) = x.split_last() {
@@ -151,14 +106,14 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last" class="method"><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/slice/mod.rs.html#299">source</a></span><h4 class="code-header">pub fn <a href="#method.last" class="fn">last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" tit [...]
-<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
+<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">30</span>), v.last());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.last());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#342">source</a><h4 class="code-header">pub fn <a href="#method.first_chunk" class="fn">first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nig [...]
-<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
+<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -171,7 +126,7 @@ removed.</p>
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[]), w.first_chunk::&lt;<span class="number">0</span>&gt;());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#400">source</a><h4 class="code-header">pub fn <a href="#method.split_first_chunk" class="fn">split_first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
+<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -182,7 +137,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#467">source</a><h4 class="code-header">pub fn <a href="#method.split_last_chunk" class="fn">split_last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.ru [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
+<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -192,7 +147,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#534">source</a><h4 class="code-header">pub fn <a href="#method.last_chunk" class="fn">last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightl [...]
-<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
+<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -212,7 +167,7 @@ position or <code>None</code> if out of bounds.</li>
 <li>If given a range, returns the subslice corresponding to that range,
 or <code>None</code> if out of bounds.</li>
 </ul>
-<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
+<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">40</span>), v.get(<span class="number">1</span>));
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]), v.get(<span class="number">0</span>..<span class="number">2</span>));
@@ -225,10 +180,10 @@ or <code>None</code> if out of bounds.</li>
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;,</span></h4></section></summary><div class="docblock"><p>Returns a reference to an element or subslice, without doing bounds
 checking.</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get" title="method slice::get"><code>get</code></a>.</p>
-<h5 id="safety-2"><a href="#safety-2">Safety</a></h5>
+<h5 id="safety-1"><a href="#safety-1">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used.</p>
-<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
+<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 
 <span class="kw">unsafe </span>{
@@ -242,7 +197,7 @@ is never written to (except inside an <code>UnsafeCell</code>) using this pointe
 derived from it. If you need to mutate the contents of the slice, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.as_mut_ptr" title="method slice::as_mut_ptr"><code>as_mut_ptr</code></a>.</p>
 <p>Modifying the container referenced by this slice may cause its buffer
 to be reallocated, which would also make any pointers to it invalid.</p>
-<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
+<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span>x_ptr = x.as_ptr();
 
@@ -273,7 +228,7 @@ element of this slice:</p>
 <span class="macro">assert!</span>(!a.as_ptr_range().contains(<span class="kw-2">&amp;</span>y));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><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/slice/mod.rs.html#1001">source</a></span><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/slice/iter/struct.Iter.ht [...]
 <p>The iterator yields all items from start to end.</p>
-<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
+<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iterator = x.iter();
 
@@ -286,7 +241,7 @@ element of this slice:</p>
 <code>size</code>, the iterator returns no values.</p>
 <h5 id="panics-3"><a href="#panics-3">Panics</a></h5>
 <p>Panics if <code>size</code> is 0.</p>
-<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
+<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>, <span class="string">&#39;s&#39;</span>, <span class="string">&#39;t&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.windows(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>]);
@@ -321,7 +276,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 slice.</p>
 <h5 id="panics-4"><a href="#panics-4">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
+<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -339,7 +294,7 @@ resulting code better than in the case of <a href="https://doc.rust-lang.org/nig
 chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.rchunks_exact" title="method slice::rchunks_exact"><code>rchunks_exact</code></a> for the same iterator but starting at the end of the slice.</p>
 <h5 id="panics-5"><a href="#panics-5">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
+<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -348,13 +303,13 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 <span class="macro">assert_eq!</span>(iter.remainder(), <span class="kw-2">&amp;</span>[<span class="string">&#39;m&#39;</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_chunks_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#1259">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_chunks_unchecked" class="fn">as_chunks_unchecked</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; &amp;[<a class="pri [...]
 assuming that there’s no remainder.</p>
-<h5 id="safety-3"><a href="#safety-3">Safety</a></h5>
+<h5 id="safety-2"><a href="#safety-2">Safety</a></h5>
 <p>This may only be called when</p>
 <ul>
 <li>The slice splits exactly into <code>N</code>-element chunks (aka <code>self.len() % N == 0</code>).</li>
 <li><code>N != 0</code>.</li>
 </ul>
-<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
+<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice: <span class="kw-2">&amp;</span>[char] = <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>, <span class="string">&#39;!&#39;</span>];
 <span class="kw">let </span>chunks: <span class="kw-2">&amp;</span>[[char; <span class="number">1</span>]] =
@@ -375,7 +330,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-6"><a href="#panics-6">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
+<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(chunks, remainder) = slice.as_chunks();
@@ -396,7 +351,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-7"><a href="#panics-7">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
+<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(remainder, chunks) = slice.as_rchunks();
@@ -411,7 +366,7 @@ retrieved from the <code>remainder</code> function of the iterator.</p>
 <h5 id="panics-8"><a href="#panics-8">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
+<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_chunks();
@@ -426,7 +381,7 @@ starting at the beginning of the slice.</p>
 <h5 id="panics-9"><a href="#panics-9">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
+<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_windows)]
 </span><span class="kw">let </span>slice = [<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_windows();
@@ -443,7 +398,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 of the slice.</p>
 <h5 id="panics-10"><a href="#panics-10">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
+<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -462,7 +417,7 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 slice.</p>
 <h5 id="panics-11"><a href="#panics-11">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
+<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -475,7 +430,7 @@ of elements using the predicate to separate them.</p>
 <p>The predicate is called on two elements following themselves,
 it means the predicate is called on <code>slice[0]</code> and <code>slice[1]</code>
 then on <code>slice[1]</code> and <code>slice[2]</code> and so on.</p>
-<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
+<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_group_by)]
 
 </span><span class="kw">let </span>slice = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">2</span>];
@@ -504,7 +459,7 @@ the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-12"><a href="#panics-12">Panics</a></h5>
 <p>Panics if <code>mid &gt; len</code>.</p>
-<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
+<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
 
 {
@@ -529,11 +484,11 @@ indices from <code>[mid, len)</code> (excluding the index <code>len</code> itsel
 the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.split_at" title="method slice::split_at"><code>split_at</code></a>.</p>
-<h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
+<h5 id="safety-3"><a href="#safety-3">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used. The caller has to ensure that
 <code>0 &lt;= mid &lt;= self.len()</code>.</p>
-<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
+<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_split_at_unchecked)]
 
 </span><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
@@ -561,7 +516,7 @@ the index <code>N</code> itself) and the slice will contain all
 indices from <code>[N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-13"><a href="#panics-13">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
+<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -590,7 +545,7 @@ the index <code>len - N</code> itself) and the array will contain all
 indices from <code>[len - N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-14"><a href="#panics-14">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
+<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -615,7 +570,7 @@ indices from <code>[len - N, len)</code> (excluding the index <code>len</code> i
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split" class="method"><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/slice/mod.rs.html#2222-2224">source</a></span><h4 class="code-header">pub fn <a href="#method.split" class="fn">split</a>&lt;F&gt;(&amp;self, pred: F) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core [...]
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is not contained in the subslices.</p>
-<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
+<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -647,7 +602,7 @@ present between them:</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is contained in the end of the previous
 subslice as a terminator.</p>
-<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
+<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split_inclusive(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -668,7 +623,7 @@ That slice will be the last item returned by the iterator.</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>, starting at the end of the slice and working backwards.
 The matched element is not contained in the subslices.</p>
-<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
+<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">11</span>, <span class="number">22</span>, <span class="number">33</span>, <span class="number">0</span>, <span class="number">44</span>, <span class="number">55</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rsplit(|num| <span class="kw-2">*</span>num == <span class="number">0</span>);
 
@@ -691,7 +646,7 @@ slice will be the first (or last) item returned by the iterator.</p>
 not contained in the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
+<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
 <p>Print the slice split once by numbers divisible by 3 (i.e., <code>[10, 40]</code>,
 <code>[20, 60, 50]</code>):</p>
 
@@ -707,7 +662,7 @@ the slice and works backwards. The matched element is not contained in
 the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
+<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
 <p>Print the slice split once, starting from the end, by numbers divisible
 by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
 
@@ -720,7 +675,7 @@ by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if the slice contains an element with the given value.</p>
 <p>This operation is <em>O</em>(<em>n</em>).</p>
 <p>Note that if you have a sorted slice, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a> may be faster.</p>
-<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
+<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.contains(<span class="kw-2">&amp;</span><span class="number">30</span>));
 <span class="macro">assert!</span>(!v.contains(<span class="kw-2">&amp;</span><span class="number">50</span>));</code></pre></div>
@@ -733,7 +688,7 @@ use <code>iter().any</code>:</p>
 </span><span class="macro">assert!</span>(!v.iter().any(|e| e == <span class="string">&quot;hi&quot;</span>));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.starts_with" class="method"><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/slice/mod.rs.html#2540-2542">source</a></span><h4 class="code-header">pub fn <a href="#method.starts_with" class="fn">starts_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/ni [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a prefix of the slice.</p>
-<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
+<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>]));
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]));
@@ -747,7 +702,7 @@ use <code>iter().any</code>:</p>
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[]));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.ends_with" class="method"><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/slice/mod.rs.html#2570-2572">source</a></span><h4 class="code-header">pub fn <a href="#method.ends_with" class="fn">ends_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/ [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a suffix of the slice.</p>
-<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
+<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">30</span>]));
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]));
@@ -765,7 +720,7 @@ use <code>iter().any</code>:</p>
 <p>If the slice starts with <code>prefix</code>, returns the subslice after the prefix, wrapped in <code>Some</code>.
 If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not start with <code>prefix</code>, returns <code>None</code>.</p>
-<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
+<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">30</span>][..]));
@@ -781,7 +736,7 @@ If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice ends with <code>suffix</code>, returns the subslice before the suffix, wrapped in <code>Some</code>.
 If <code>suffix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not end with <code>suffix</code>, returns <code>None</code>.</p>
-<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
+<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>][..]));
@@ -799,7 +754,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"> [...]
-<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
+<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -856,7 +811,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>par [...]
-<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
+<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -891,7 +846,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>partition_point [...]
-<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
+<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
 <p>Looks up a series of four elements in a slice of pairs sorted by
 their second elements. The first is found, with a uniquely
 determined position; the second and third are not found; the
@@ -916,10 +871,10 @@ matter, such as a sanitizer attempting to find alignment bugs. Regular code runn
 in a default (debug or release) execution <em>will</em> return a maximal middle part.</p>
 <p>This method has no purpose when either input element <code>T</code> or output element <code>U</code> are
 zero-sized and will return the original slice without splitting anything.</p>
-<h5 id="safety-5"><a href="#safety-5">Safety</a></h5>
+<h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
 <p>This method is essentially a <code>transmute</code> with respect to the elements in the returned
 middle slice, so all the usual caveats pertaining to <code>transmute::&lt;T, U&gt;</code> also apply here.</p>
-<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
+<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
 <p>Basic usage:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">unsafe </span>{
@@ -952,7 +907,7 @@ that from ever happening, as only power-of-two numbers of lanes are
 supported.  It’s possible that, in the future, those restrictions might
 be lifted in a way that would make it possible to see panics from this
 method for something like <code>LANES == 3</code>.</p>
-<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(portable_simd)]
 </span><span class="kw">use </span>core::simd::SimdFloat;
 
@@ -987,7 +942,7 @@ slice yields exactly zero or one element, <code>true</code> is returned.</p>
 <p>Note that if <code>Self::Item</code> is only <code>PartialOrd</code>, but not <code>Ord</code>, the above definition
 implies that this function returns <code>false</code> if any two consecutive items are not
 comparable.</p>
-<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 </span><span class="kw">let </span>empty: [i32; <span class="number">0</span>] = [];
 
@@ -1007,7 +962,7 @@ function to determine the ordering of two elements. Apart from that, it’s equi
 <p>Instead of comparing the slice’s elements directly, this function compares the keys of the
 elements, as determined by <code>f</code>. Apart from that, it’s equivalent to <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.is_sorted" title="method slice::is_sorted"><code>is_sorted</code></a>; see its
 documentation for more information.</p>
-<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 
 </span><span class="macro">assert!</span>([<span class="string">&quot;c&quot;</span>, <span class="string">&quot;bb&quot;</span>, <span class="string">&quot;aaa&quot;</span>].is_sorted_by_key(|s| s.len()));
@@ -1023,7 +978,7 @@ For example, <code>[7, 15, 3, 5, 4, 12, 6]</code> is partitioned under the predi
 <p>If this slice is not partitioned, the returned result is unspecified and meaningless,
 as this method performs a kind of binary search.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binar [...]
-<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">6</span>, <span class="number">7</span>];
 <span class="kw">let </span>i = v.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; <span class="number">5</span>);
 
@@ -1045,6 +1000,51 @@ sort order:</p>
 <span class="kw">let </span>idx = s.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; num);
 s.insert(idx, num);
 <span class="macro">assert_eq!</span>(s, [<span class="number">0</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">8</span>, <span class="number">13</span>, <span class="number">21</span>, <span class="number">34</span>, <span class="number">42</span>, <span class="number">55</span>]);</code></p [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
+<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
+without checking whether they’re valid.</p>
+<h5 id="safety-5"><a href="#safety-5">Safety</a></h5>
+<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
+<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
+but without allocating and copying temporaries.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
+treating it as an ASCII string.</p>
+<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
+<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
+<span class="kw">let </span>escaped = s.escape_ascii().to_string();
+<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
+removed.</p>
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_ascii_uppercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/alloc/slice.rs.html#621">source</a></span><h4 class="code-header">pub fn <a href="#method.to_ascii_uppercase" class="fn">to_ascii_uppercase</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.or [...]
 is mapped to its ASCII upper case equivalent.</p>
 <p>ASCII letters ‘a’ to ‘z’ are mapped to ‘A’ to ‘Z’,
diff --git a/arrow/buffer/struct.RunEndBuffer.html b/arrow/buffer/struct.RunEndBuffer.html
index 61b74f82b8..83987a606c 100644
--- a/arrow/buffer/struct.RunEndBuffer.html
+++ b/arrow/buffer/struct.RunEndBuffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A slice-able buffer of monotonically increasing, positive integers used to store run-ends"><title>RunEndBuffer in arrow::buffer - 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 slice-able buffer of monotonically increasing, positive integers used to store run-ends"><title>RunEndBuffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
     E: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span>{
     run_ends: <a class="struct" href="struct.ScalarBuffer.html" title="struct arrow::buffer::ScalarBuffer">ScalarBuffer</a>&lt;E&gt;,
     len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
diff --git a/arrow/buffer/struct.ScalarBuffer.html b/arrow/buffer/struct.ScalarBuffer.html
index 9e4b3ef7f6..52283bc855 100644
--- a/arrow/buffer/struct.ScalarBuffer.html
+++ b/arrow/buffer/struct.ScalarBuffer.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A strongly-typed `Buffer` supporting zero-copy cloning and slicing"><title>ScalarBuffer in arrow::buffer - Rust</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 strongly-typed `Buffer` supporting zero-copy cloning and slicing"><title>ScalarBuffer in arrow::buffer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span>{
     buffer: <a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a>,
     phantom: <a class="struct" href="https://doc.rust-lang.org/nightly/core/marker/struct.PhantomData.html" title="struct core::marker::PhantomData">PhantomData</a>&lt;T&gt;,
@@ -30,7 +30,9 @@ and <code>length</code> in units of <code>T</code></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#76">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, len: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</ [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.inner" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#81">source</a><h4 class="code-header">pub fn <a href="#method.inner" class="fn">inner</a>(&amp;self) -&gt; &amp;<a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the inner <a href="struct.Buffer.html" title= [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.into_inner" class="method"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#86">source</a><h4 class="code-header">pub fn <a href="#method.into_inner" class="fn">into_inner</a>(self) -&gt; <a class="struct" href="struct.Buffer.html" title="struct arrow::buffer::Buffer">Buffer</a></h4></section></summary><div class="docblock"><p>Returns the inner <a href="struct.Buffer.html" t [...]
-</div></details></div></details></div><h2 id="deref-methods-%5BT%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;</span><a href="#deref-methods-%5BT%5D" class="anchor">§</a></h2><div id="deref-methods-%5BT%5D-1" class="impl-items"><details  [...]
+</div></details></div></details></div><h2 id="deref-methods-%5BT%5D" class="small-section-header"><span>Methods from <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html" title="trait core::ops::deref::Deref">Deref</a>&lt;Target = <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;</span><a href="#deref-methods-%5BT%5D" class="anchor">§</a></h2><div id="deref-methods-%5BT%5D-1" class="impl-items"><details  [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.flatten" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#4496">source</a><h4 class="code-header">pub fn <a href="#method.flatten" class="fn">flatten</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a></h4></section><span class="item-info"><div class="stab unstable"><span clas [...]
 <h5 id="panics-1"><a href="#panics-1">Panics</a></h5>
 <p>This panics if the length of the resulting slice would overflow a <code>usize</code>.</p>
 <p>This is only possible when flattening a slice of arrays of zero-sized
@@ -51,70 +53,23 @@ types, and thus tends to be irrelevant in practice. If
 
 <span class="kw">let </span>empty_slice_of_arrays: <span class="kw-2">&amp;</span>[[u32; <span class="number">10</span>]] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert!</span>(empty_slice_of_arrays.flatten().is_empty());</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
-<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
-without checking whether they’re valid.</p>
-<h5 id="safety"><a href="#safety">Safety</a></h5>
-<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
-<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
-but without allocating and copying temporaries.</p>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
-treating it as an ASCII string.</p>
-<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
-<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
-<span class="kw">let </span>escaped = s.escape_ascii().to_string();
-<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
-removed.</p>
-<p>‘Whitespace’ refers to the definition used by
-<code>u8::is_ascii_whitespace</code>.</p>
-<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
-<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
-
-</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
-<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_str" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#544">source</a><h4 class="code-header">pub fn <a href="#method.as_str" class="fn">as_str</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section><span class="item-info"><div class="stab unstable"><span cla [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="method.as_bytes" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/ascii/ascii_char.rs.html#555">source</a><h4 class="code-header">pub fn <a href="#method.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></ [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.len" class="method"><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/slice/mod.rs.html#141">source</a></span><h4 class="code-header">pub fn <a href="#method.len" class="fn">len</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize [...]
-<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
+<h5 id="examples-1"><a href="#examples-1">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert_eq!</span>(a.len(), <span class="number">3</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_empty" class="method"><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/slice/mod.rs.html#157">source</a></span><h4 class="code-header">pub fn <a href="#method.is_empty" class="fn">is_empty</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bo [...]
-<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
+<h5 id="examples-2"><a href="#examples-2">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="macro">assert!</span>(!a.is_empty());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first" class="method"><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/slice/mod.rs.html#176">source</a></span><h4 class="code-header">pub fn <a href="#method.first" class="fn">first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html"  [...]
-<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
+<h5 id="examples-3"><a href="#examples-3">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">10</span>), v.first());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.first());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#216">source</a></span><h4 class="code-header">pub fn <a href="#method.split_first" class="fn">split_first</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/ [...]
-<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
+<h5 id="examples-4"><a href="#examples-4">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((first, elements)) = x.split_first() {
@@ -122,7 +77,7 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.5.0">1.5.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#258">source</a></span><h4 class="code-header">pub fn <a href="#method.split_last" class="fn">split_last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enu [...]
-<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
+<h5 id="examples-5"><a href="#examples-5">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
 
 <span class="kw">if let </span><span class="prelude-val">Some</span>((last, elements)) = x.split_last() {
@@ -130,14 +85,14 @@ removed.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last" class="method"><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/slice/mod.rs.html#299">source</a></span><h4 class="code-header">pub fn <a href="#method.last" class="fn">last</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" tit [...]
-<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
+<h5 id="examples-6"><a href="#examples-6">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">30</span>), v.last());
 
 <span class="kw">let </span>w: <span class="kw-2">&amp;</span>[i32] = <span class="kw-2">&amp;</span>[];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">None</span>, w.last());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#342">source</a><h4 class="code-header">pub fn <a href="#method.first_chunk" class="fn">first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nig [...]
-<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
+<h5 id="examples-7"><a href="#examples-7">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -150,7 +105,7 @@ removed.</p>
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[]), w.first_chunk::&lt;<span class="number">0</span>&gt;());</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_first_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#400">source</a><h4 class="code-header">pub fn <a href="#method.split_first_chunk" class="fn">split_first_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
+<h5 id="examples-8"><a href="#examples-8">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -161,7 +116,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split_last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#467">source</a><h4 class="code-header">pub fn <a href="#method.split_last_chunk" class="fn">split_last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.ru [...]
 or <code>None</code> if it has fewer than <code>N</code> elements.</p>
-<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
+<h5 id="examples-9"><a href="#examples-9">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>];
@@ -171,7 +126,7 @@ or <code>None</code> if it has fewer than <code>N</code> elements.</p>
     <span class="macro">assert_eq!</span>(elements, <span class="kw-2">&amp;</span>[<span class="number">0</span>]);
 }</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.last_chunk" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#534">source</a><h4 class="code-header">pub fn <a href="#method.last_chunk" class="fn">last_chunk</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightl [...]
-<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
+<h5 id="examples-10"><a href="#examples-10">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_first_last_chunk)]
 
 </span><span class="kw">let </span>u = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
@@ -191,7 +146,7 @@ position or <code>None</code> if out of bounds.</li>
 <li>If given a range, returns the subslice corresponding to that range,
 or <code>None</code> if out of bounds.</li>
 </ul>
-<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
+<h5 id="examples-11"><a href="#examples-11">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span><span class="number">40</span>), v.get(<span class="number">1</span>));
 <span class="macro">assert_eq!</span>(<span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]), v.get(<span class="number">0</span>..<span class="number">2</span>));
@@ -204,10 +159,10 @@ or <code>None</code> if out of bounds.</li>
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/slice/index/trait.SliceIndex.html" title="trait core::slice::index::SliceIndex">SliceIndex</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt;,</span></h4></section></summary><div class="docblock"><p>Returns a reference to an element or subslice, without doing bounds
 checking.</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.get" title="method slice::get"><code>get</code></a>.</p>
-<h5 id="safety-1"><a href="#safety-1">Safety</a></h5>
+<h5 id="safety"><a href="#safety">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used.</p>
-<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
+<h5 id="examples-12"><a href="#examples-12">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 
 <span class="kw">unsafe </span>{
@@ -221,7 +176,7 @@ is never written to (except inside an <code>UnsafeCell</code>) using this pointe
 derived from it. If you need to mutate the contents of the slice, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.as_mut_ptr" title="method slice::as_mut_ptr"><code>as_mut_ptr</code></a>.</p>
 <p>Modifying the container referenced by this slice may cause its buffer
 to be reallocated, which would also make any pointers to it invalid.</p>
-<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
+<h5 id="examples-13"><a href="#examples-13">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span>x_ptr = x.as_ptr();
 
@@ -252,7 +207,7 @@ element of this slice:</p>
 <span class="macro">assert!</span>(!a.as_ptr_range().contains(<span class="kw-2">&amp;</span>y));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><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/slice/mod.rs.html#1001">source</a></span><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/slice/iter/struct.Iter.ht [...]
 <p>The iterator yields all items from start to end.</p>
-<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
+<h5 id="examples-14"><a href="#examples-14">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>x = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">4</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iterator = x.iter();
 
@@ -265,7 +220,7 @@ element of this slice:</p>
 <code>size</code>, the iterator returns no values.</p>
 <h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
 <p>Panics if <code>size</code> is 0.</p>
-<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
+<h5 id="examples-15"><a href="#examples-15">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>, <span class="string">&#39;s&#39;</span>, <span class="string">&#39;t&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.windows(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;r&#39;</span>, <span class="string">&#39;u&#39;</span>]);
@@ -300,7 +255,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 slice.</p>
 <h5 id="panics-3"><a href="#panics-3">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
+<h5 id="examples-16"><a href="#examples-16">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -318,7 +273,7 @@ resulting code better than in the case of <a href="https://doc.rust-lang.org/nig
 chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.rchunks_exact" title="method slice::rchunks_exact"><code>rchunks_exact</code></a> for the same iterator but starting at the end of the slice.</p>
 <h5 id="panics-4"><a href="#panics-4">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
+<h5 id="examples-17"><a href="#examples-17">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.chunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>]);
@@ -327,13 +282,13 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 <span class="macro">assert_eq!</span>(iter.remainder(), <span class="kw-2">&amp;</span>[<span class="string">&#39;m&#39;</span>]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_chunks_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/mod.rs.html#1259">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_chunks_unchecked" class="fn">as_chunks_unchecked</a>&lt;const N: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;(&amp;self) -&gt; &amp;[<a class="pri [...]
 assuming that there’s no remainder.</p>
-<h5 id="safety-2"><a href="#safety-2">Safety</a></h5>
+<h5 id="safety-1"><a href="#safety-1">Safety</a></h5>
 <p>This may only be called when</p>
 <ul>
 <li>The slice splits exactly into <code>N</code>-element chunks (aka <code>self.len() % N == 0</code>).</li>
 <li><code>N != 0</code>.</li>
 </ul>
-<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
+<h5 id="examples-18"><a href="#examples-18">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice: <span class="kw-2">&amp;</span>[char] = <span class="kw-2">&amp;</span>[<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>, <span class="string">&#39;!&#39;</span>];
 <span class="kw">let </span>chunks: <span class="kw-2">&amp;</span>[[char; <span class="number">1</span>]] =
@@ -354,7 +309,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-5"><a href="#panics-5">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
+<h5 id="examples-19"><a href="#examples-19">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(chunks, remainder) = slice.as_chunks();
@@ -375,7 +330,7 @@ and a remainder slice with length strictly less than <code>N</code>.</p>
 <h5 id="panics-6"><a href="#panics-6">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
+<h5 id="examples-20"><a href="#examples-20">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_as_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span>(remainder, chunks) = slice.as_rchunks();
@@ -390,7 +345,7 @@ retrieved from the <code>remainder</code> function of the iterator.</p>
 <h5 id="panics-7"><a href="#panics-7">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
+<h5 id="examples-21"><a href="#examples-21">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_chunks)]
 </span><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_chunks();
@@ -405,7 +360,7 @@ starting at the beginning of the slice.</p>
 <h5 id="panics-8"><a href="#panics-8">Panics</a></h5>
 <p>Panics if <code>N</code> is 0. This check will most probably get changed to a compile time
 error before this method gets stabilized.</p>
-<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
+<h5 id="examples-22"><a href="#examples-22">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(array_windows)]
 </span><span class="kw">let </span>slice = [<span class="number">0</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.array_windows();
@@ -422,7 +377,7 @@ slice, then the last chunk will not have length <code>chunk_size</code>.</p>
 of the slice.</p>
 <h5 id="panics-9"><a href="#panics-9">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
+<h5 id="examples-23"><a href="#examples-23">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -441,7 +396,7 @@ chunk, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#m
 slice.</p>
 <h5 id="panics-10"><a href="#panics-10">Panics</a></h5>
 <p>Panics if <code>chunk_size</code> is 0.</p>
-<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
+<h5 id="examples-24"><a href="#examples-24">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="string">&#39;l&#39;</span>, <span class="string">&#39;o&#39;</span>, <span class="string">&#39;r&#39;</span>, <span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rchunks_exact(<span class="number">2</span>);
 <span class="macro">assert_eq!</span>(iter.next().unwrap(), <span class="kw-2">&amp;</span>[<span class="string">&#39;e&#39;</span>, <span class="string">&#39;m&#39;</span>]);
@@ -454,7 +409,7 @@ of elements using the predicate to separate them.</p>
 <p>The predicate is called on two elements following themselves,
 it means the predicate is called on <code>slice[0]</code> and <code>slice[1]</code>
 then on <code>slice[1]</code> and <code>slice[2]</code> and so on.</p>
-<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
+<h5 id="examples-25"><a href="#examples-25">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_group_by)]
 
 </span><span class="kw">let </span>slice = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">2</span>, <span class="number">2</span>, <span class="number">2</span>];
@@ -483,7 +438,7 @@ the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-11"><a href="#panics-11">Panics</a></h5>
 <p>Panics if <code>mid &gt; len</code>.</p>
-<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
+<h5 id="examples-26"><a href="#examples-26">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
 
 {
@@ -508,11 +463,11 @@ indices from <code>[mid, len)</code> (excluding the index <code>len</code> itsel
 the index <code>mid</code> itself) and the second will contain all
 indices from <code>[mid, len)</code> (excluding the index <code>len</code> itself).</p>
 <p>For a safe alternative see <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.split_at" title="method slice::split_at"><code>split_at</code></a>.</p>
-<h5 id="safety-3"><a href="#safety-3">Safety</a></h5>
+<h5 id="safety-2"><a href="#safety-2">Safety</a></h5>
 <p>Calling this method with an out-of-bounds index is <em><a href="https://doc.rust-lang.org/reference/behavior-considered-undefined.html">undefined behavior</a></em>
 even if the resulting reference is not used. The caller has to ensure that
 <code>0 &lt;= mid &lt;= self.len()</code>.</p>
-<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
+<h5 id="examples-27"><a href="#examples-27">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(slice_split_at_unchecked)]
 
 </span><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>];
@@ -540,7 +495,7 @@ the index <code>N</code> itself) and the slice will contain all
 indices from <code>[N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-12"><a href="#panics-12">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
+<h5 id="examples-28"><a href="#examples-28">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -569,7 +524,7 @@ the index <code>len - N</code> itself) and the array will contain all
 indices from <code>[len - N, len)</code> (excluding the index <code>len</code> itself).</p>
 <h5 id="panics-13"><a href="#panics-13">Panics</a></h5>
 <p>Panics if <code>N &gt; len</code>.</p>
-<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
+<h5 id="examples-29"><a href="#examples-29">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(split_array)]
 
 </span><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>, <span class="number">5</span>, <span class="number">6</span>][..];
@@ -594,7 +549,7 @@ indices from <code>[len - N, len)</code> (excluding the index <code>len</code> i
 </div></details><details class="toggle method-toggle" open><summary><section id="method.split" class="method"><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/slice/mod.rs.html#2222-2224">source</a></span><h4 class="code-header">pub fn <a href="#method.split" class="fn">split</a>&lt;F&gt;(&amp;self, pred: F) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core [...]
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is not contained in the subslices.</p>
-<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
+<h5 id="examples-30"><a href="#examples-30">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -626,7 +581,7 @@ present between them:</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>. The matched element is contained in the end of the previous
 subslice as a terminator.</p>
-<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
+<h5 id="examples-31"><a href="#examples-31">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">33</span>, <span class="number">20</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.split_inclusive(|num| num % <span class="number">3 </span>== <span class="number">0</span>);
 
@@ -647,7 +602,7 @@ That slice will be the last item returned by the iterator.</p>
     F: <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.FnMut.html" title="trait core::ops::function::FnMut">FnMut</a>(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a>,</span></h4></section></summary><div class="docblock"><p>Returns an iterator over subslices separated by elements that match
 <code>pred</code>, starting at the end of the slice and working backwards.
 The matched element is not contained in the subslices.</p>
-<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
+<h5 id="examples-32"><a href="#examples-32">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>slice = [<span class="number">11</span>, <span class="number">22</span>, <span class="number">33</span>, <span class="number">0</span>, <span class="number">44</span>, <span class="number">55</span>];
 <span class="kw">let </span><span class="kw-2">mut </span>iter = slice.rsplit(|num| <span class="kw-2">*</span>num == <span class="number">0</span>);
 
@@ -670,7 +625,7 @@ slice will be the first (or last) item returned by the iterator.</p>
 not contained in the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
+<h5 id="examples-33"><a href="#examples-33">Examples</a></h5>
 <p>Print the slice split once by numbers divisible by 3 (i.e., <code>[10, 40]</code>,
 <code>[20, 60, 50]</code>):</p>
 
@@ -686,7 +641,7 @@ the slice and works backwards. The matched element is not contained in
 the subslices.</p>
 <p>The last element returned, if any, will contain the remainder of the
 slice.</p>
-<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
+<h5 id="examples-34"><a href="#examples-34">Examples</a></h5>
 <p>Print the slice split once, starting from the end, by numbers divisible
 by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
 
@@ -699,7 +654,7 @@ by 3 (i.e., <code>[50]</code>, <code>[10, 40, 30, 20]</code>):</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if the slice contains an element with the given value.</p>
 <p>This operation is <em>O</em>(<em>n</em>).</p>
 <p>Note that if you have a sorted slice, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a> may be faster.</p>
-<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
+<h5 id="examples-35"><a href="#examples-35">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.contains(<span class="kw-2">&amp;</span><span class="number">30</span>));
 <span class="macro">assert!</span>(!v.contains(<span class="kw-2">&amp;</span><span class="number">50</span>));</code></pre></div>
@@ -712,7 +667,7 @@ use <code>iter().any</code>:</p>
 </span><span class="macro">assert!</span>(!v.iter().any(|e| e == <span class="string">&quot;hi&quot;</span>));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.starts_with" class="method"><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/slice/mod.rs.html#2540-2542">source</a></span><h4 class="code-header">pub fn <a href="#method.starts_with" class="fn">starts_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/ni [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a prefix of the slice.</p>
-<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
+<h5 id="examples-36"><a href="#examples-36">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>]));
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]));
@@ -726,7 +681,7 @@ use <code>iter().any</code>:</p>
 <span class="macro">assert!</span>(v.starts_with(<span class="kw-2">&amp;</span>[]));</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.ends_with" class="method"><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/slice/mod.rs.html#2570-2572">source</a></span><h4 class="code-header">pub fn <a href="#method.ends_with" class="fn">ends_with</a>(&amp;self, needle: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/ [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html" title="trait core::cmp::PartialEq">PartialEq</a>&lt;T&gt;,</span></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if <code>needle</code> is a suffix of the slice.</p>
-<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
+<h5 id="examples-37"><a href="#examples-37">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">30</span>]));
 <span class="macro">assert!</span>(v.ends_with(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]));
@@ -744,7 +699,7 @@ use <code>iter().any</code>:</p>
 <p>If the slice starts with <code>prefix</code>, returns the subslice after the prefix, wrapped in <code>Some</code>.
 If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not start with <code>prefix</code>, returns <code>None</code>.</p>
-<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
+<h5 id="examples-38"><a href="#examples-38">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_prefix(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">30</span>][..]));
@@ -760,7 +715,7 @@ If <code>prefix</code> is empty, simply returns the original slice.</p>
 <p>If the slice ends with <code>suffix</code>, returns the subslice before the suffix, wrapped in <code>Some</code>.
 If <code>suffix</code> is empty, simply returns the original slice.</p>
 <p>If the slice does not end with <code>suffix</code>, returns <code>None</code>.</p>
-<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
+<h5 id="examples-39"><a href="#examples-39">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = <span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>, <span class="number">30</span>];
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>, <span class="number">40</span>][..]));
 <span class="macro">assert_eq!</span>(v.strip_suffix(<span class="kw-2">&amp;</span>[<span class="number">40</span>, <span class="number">30</span>]), <span class="prelude-val">Some</span>(<span class="kw-2">&amp;</span>[<span class="number">10</span>][..]));
@@ -778,7 +733,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"> [...]
-<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
+<h5 id="examples-40"><a href="#examples-40">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -835,7 +790,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binary_search_by_key</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>par [...]
-<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
+<h5 id="examples-41"><a href="#examples-41">Examples</a></h5>
 <p>Looks up a series of four elements. The first is found, with a
 uniquely determined position; the second and third are not
 found; the fourth could match any position in <code>[1, 4]</code>.</p>
@@ -870,7 +825,7 @@ If the value is not found then <a href="https://doc.rust-lang.org/nightly/core/r
 the index where a matching element could be inserted while maintaining
 sorted order.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.partition_point" title="method slice::partition_point"><code>partition_point [...]
-<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
+<h5 id="examples-42"><a href="#examples-42">Examples</a></h5>
 <p>Looks up a series of four elements in a slice of pairs sorted by
 their second elements. The first is found, with a uniquely
 determined position; the second and third are not found; the
@@ -895,10 +850,10 @@ matter, such as a sanitizer attempting to find alignment bugs. Regular code runn
 in a default (debug or release) execution <em>will</em> return a maximal middle part.</p>
 <p>This method has no purpose when either input element <code>T</code> or output element <code>U</code> are
 zero-sized and will return the original slice without splitting anything.</p>
-<h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
+<h5 id="safety-3"><a href="#safety-3">Safety</a></h5>
 <p>This method is essentially a <code>transmute</code> with respect to the elements in the returned
 middle slice, so all the usual caveats pertaining to <code>transmute::&lt;T, U&gt;</code> also apply here.</p>
-<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
+<h5 id="examples-43"><a href="#examples-43">Examples</a></h5>
 <p>Basic usage:</p>
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">unsafe </span>{
@@ -931,7 +886,7 @@ that from ever happening, as only power-of-two numbers of lanes are
 supported.  It’s possible that, in the future, those restrictions might
 be lifted in a way that would make it possible to see panics from this
 method for something like <code>LANES == 3</code>.</p>
-<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<h5 id="examples-44"><a href="#examples-44">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(portable_simd)]
 </span><span class="kw">use </span>core::simd::SimdFloat;
 
@@ -966,7 +921,7 @@ slice yields exactly zero or one element, <code>true</code> is returned.</p>
 <p>Note that if <code>Self::Item</code> is only <code>PartialOrd</code>, but not <code>Ord</code>, the above definition
 implies that this function returns <code>false</code> if any two consecutive items are not
 comparable.</p>
-<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<h5 id="examples-45"><a href="#examples-45">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 </span><span class="kw">let </span>empty: [i32; <span class="number">0</span>] = [];
 
@@ -986,7 +941,7 @@ function to determine the ordering of two elements. Apart from that, it’s equi
 <p>Instead of comparing the slice’s elements directly, this function compares the keys of the
 elements, as determined by <code>f</code>. Apart from that, it’s equivalent to <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.is_sorted" title="method slice::is_sorted"><code>is_sorted</code></a>; see its
 documentation for more information.</p>
-<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<h5 id="examples-46"><a href="#examples-46">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(is_sorted)]
 
 </span><span class="macro">assert!</span>([<span class="string">&quot;c&quot;</span>, <span class="string">&quot;bb&quot;</span>, <span class="string">&quot;aaa&quot;</span>].is_sorted_by_key(|s| s.len()));
@@ -1002,7 +957,7 @@ For example, <code>[7, 15, 3, 5, 4, 12, 6]</code> is partitioned under the predi
 <p>If this slice is not partitioned, the returned result is unspecified and meaningless,
 as this method performs a kind of binary search.</p>
 <p>See also <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search" title="method slice::binary_search"><code>binary_search</code></a>, <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by" title="method slice::binary_search_by"><code>binary_search_by</code></a>, and <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.binary_search_by_key" title="method slice::binary_search_by_key"><code>binar [...]
-<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<h5 id="examples-47"><a href="#examples-47">Examples</a></h5>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>v = [<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">6</span>, <span class="number">7</span>];
 <span class="kw">let </span>i = v.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; <span class="number">5</span>);
 
@@ -1024,6 +979,51 @@ sort order:</p>
 <span class="kw">let </span>idx = s.partition_point(|<span class="kw-2">&amp;</span>x| x &lt; num);
 s.insert(idx, num);
 <span class="macro">assert_eq!</span>(s, [<span class="number">0</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">5</span>, <span class="number">8</span>, <span class="number">13</span>, <span class="number">21</span>, <span class="number">34</span>, <span class="number">42</span>, <span class="number">55</span>]);</code></p [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.is_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#16">source</a></span><h4 class="code-header">pub fn <a href="#method.is_ascii" class="fn">is_ascii</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#25">source</a><h4 class="code-header">pub fn <a href="#method.as_ascii" class="fn">as_ascii</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="enum" href="https://do [...]
+<a href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii_char::AsciiChar">ASCII characters</a>, otherwise returns <code>None</code>.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.as_ascii_unchecked" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#43">source</a><h4 class="code-header">pub unsafe fn <a href="#method.as_ascii_unchecked" class="fn">as_ascii_unchecked</a>(&amp;self) -&gt; &amp;[<a class="enum" href="https://doc.rust-lang.org/nightly/core/ascii/ascii_char/enum.AsciiChar.html" title="enum core::ascii::ascii [...]
+without checking whether they’re valid.</p>
+<h5 id="safety-4"><a href="#safety-4">Safety</a></h5>
+<p>Every byte in the slice must be in <code>0..=127</code>, or else this is UB.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.eq_ignore_ascii_case" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#57">source</a></span><h4 class="code-header">pub fn <a href="#method.eq_ignore_ascii_case" class="fn">eq_ignore_ascii_case</a>(&amp;self, other: &amp;[<a class="primitive" href="http [...]
+<p>Same as <code>to_ascii_lowercase(a) == to_ascii_lowercase(b)</code>,
+but without allocating and copying temporaries.</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.escape_ascii" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.60.0">1.60.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#109">source</a></span><h4 class="code-header">pub fn <a href="#method.escape_ascii" class="fn">escape_ascii</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/cor [...]
+treating it as an ASCII string.</p>
+<h5 id="examples-48"><a href="#examples-48">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code>
+<span class="kw">let </span>s = <span class="string">b&quot;0\t\r\n&#39;\&quot;\\\x9d&quot;</span>;
+<span class="kw">let </span>escaped = s.escape_ascii().to_string();
+<span class="macro">assert_eq!</span>(escaped, <span class="string">&quot;0\\t\\r\\n\\&#39;\\\&quot;\\\\\\x9d&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_start" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#128">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_start" class="fn">trim_ascii_start</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-49"><a href="#examples-49">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot; \t hello world\n&quot;</span>.trim_ascii_start(), <span class="string">b&quot;hello world\n&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_start(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii_end" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#157">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii_end" class="fn">trim_ascii_end</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]" [...]
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-50"><a href="#examples-50">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii_end(), <span class="string">b&quot;\r hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii_end(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
+</div></details><details class="toggle method-toggle" open><summary><section id="method.trim_ascii" class="method"><a class="src rightside" href="https://doc.rust-lang.org/nightly/src/core/slice/ascii.rs.html#187">source</a><h4 class="code-header">pub fn <a href="#method.trim_ascii" class="fn">trim_ascii</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4>< [...]
+removed.</p>
+<p>‘Whitespace’ refers to the definition used by
+<code>u8::is_ascii_whitespace</code>.</p>
+<h5 id="examples-51"><a href="#examples-51">Examples</a></h5>
+<div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="attr">#![feature(byte_slice_trim_ascii)]
+
+</span><span class="macro">assert_eq!</span>(<span class="string">b&quot;\r hello world\n &quot;</span>.trim_ascii(), <span class="string">b&quot;hello world&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;  &quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);
+<span class="macro">assert_eq!</span>(<span class="string">b&quot;&quot;</span>.trim_ascii(), <span class="string">b&quot;&quot;</span>);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_ascii_uppercase" class="method"><span class="rightside"><span class="since" title="Stable since Rust version 1.23.0">1.23.0</span> · <a class="src" href="https://doc.rust-lang.org/nightly/src/alloc/slice.rs.html#621">source</a></span><h4 class="code-header">pub fn <a href="#method.to_ascii_uppercase" class="fn">to_ascii_uppercase</a>(&amp;self) -&gt; <a class="struct" href="https://doc.rust-lang.or [...]
 is mapped to its ASCII upper case equivalent.</p>
 <p>ASCII letters ‘a’ to ‘z’ are mapped to ‘A’ to ‘Z’,
@@ -1100,11 +1100,11 @@ given separator between each.</p>
     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;,</span></h4></section></summary><div class='docblock'>Creates a value from an iterator. <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter">Read more</a></div></details></div></details><details class="toggle implementors-toggle"  [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Item" class="associatedtype trait-impl"><a href="#associatedtype.Item" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html#associatedtype.Item [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,
-    S: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt; + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section [...]
-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#226">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%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#176">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang. [...]
-    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></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_buffer/buffer/scalar.rs.html#177">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/n [...]
+    S: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[T]</a>&gt; + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section [...]
 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#226">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%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="impl"><a class="src rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#176">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang. [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></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_buffer/buffer/scalar.rs.html#177">source</a><a href="#method.eq-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.o [...]
+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#226">source</a></span><a href="#method.ne-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div><h2 id="synthetic-implementations" class="small-section-header">Auto Trait Implementations<a href="#synthetic-implementations" class="anchor">§</a></h2><div id="synthetic-implementations-list"><section id="impl-RefUnwindSafe-for-ScalarBuffer%3CT%3E" class="impl"><a href="#impl-RefUnwindSafe-for-ScalarBuffer%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="tra [...]
     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>,</span></h3></section><section id="impl-Send-for-ScalarBuffer%3CT%3E" class="impl"><a href="#impl-Send-for-ScalarBuffer%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">Se [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a>,</span></h3></section><section id="impl-UnwindSafe-for-ScalarBuffer%3CT%3E" class="impl"><a href="#impl-UnwindSafe-for-ScalarBuffer%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="trait core::panic::unwind_safe::UnwindSafe">Un [...]
diff --git a/arrow/compute/fn.and.html b/arrow/compute/fn.and.html
index e7265b20f9..9364fa4db7 100644
--- a/arrow/compute/fn.and.html
+++ b/arrow/compute/fn.and.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Performs `AND` operation on two arrays. If either left or right value is null then the result is also null."><title>and in arrow::compute - 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="Performs `AND` operation on two arrays. If either left or right value is null then the result is also null."><title>and in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><l [...]
     left: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>,
     right: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div cl [...]
diff --git a/arrow/compute/fn.and_kleene.html b/arrow/compute/fn.and_kleene.html
index 7ebcd4be1e..8aa53ca3b3 100644
--- a/arrow/compute/fn.and_kleene.html
+++ b/arrow/compute/fn.and_kleene.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Logical ‘and’ boolean values with Kleene logic"><title>and_kleene in arrow::compute - Rust</title><link 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="Logical ‘and’ boolean values with Kleene logic"><title>and_kleene in arrow::compute - Rust</title><link 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 [...]
     left: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>,
     right: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div cl [...]
diff --git a/arrow/compute/fn.binary.html b/arrow/compute/fn.binary.html
index 9f29df6012..7eeb27c828 100644
--- a/arrow/compute/fn.binary.html
+++ b/arrow/compute/fn.binary.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 two arrays of length `len`, calls `op(a[i], b[i])` for `i` in `0..len`, collecting the results in a `PrimitiveArray`. If any index is null in either `a` or `b`, the corresponding index in the result will also be null"><title>binary in arrow::compute - 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="Given two arrays of length `len`, calls `op(a[i], b[i])` for `i` in `0..len`, collecting the results in a `PrimitiveArray`. If any index is null in either `a` or `b`, the corresponding index in the result will also be null"><title>binary in arrow::compute - Rust</title><link rel="preload [...]
     a: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;A&gt;,
     b: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;B&gt;,
     op: F
diff --git a/arrow/compute/fn.binary_mut.html b/arrow/compute/fn.binary_mut.html
index 8e97d2d91e..a0e11034a7 100644
--- a/arrow/compute/fn.binary_mut.html
+++ b/arrow/compute/fn.binary_mut.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 two arrays of length `len`, calls `op(a[i], b[i])` for `i` in `0..len`, mutating the mutable `PrimitiveArray` `a`. If any index is null in either `a` or `b`, the corresponding index in the result will also be null."><title>binary_mut in arrow::compute - Rust</title><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="Given two arrays of length `len`, calls `op(a[i], b[i])` for `i` in `0..len`, mutating the mutable `PrimitiveArray` `a`. If any index is null in either `a` or `b`, the corresponding index in the result will also be null."><title>binary_mut in arrow::compute - Rust</title><link rel="prelo [...]
     a: <a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;,
     b: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;,
     op: F
diff --git a/arrow/compute/fn.bit_and.html b/arrow/compute/fn.bit_and.html
index c672f6a20a..7a7c75bf45 100644
--- a/arrow/compute/fn.bit_and.html
+++ b/arrow/compute/fn.bit_and.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the bitwise and of all non-null input values."><title>bit_and in arrow::compute - Rust</title><link 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="Returns the bitwise and of all non-null input values."><title>bit_and in arrow::compute - Rust</title><link 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 [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;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;<span class="where fmt-ne [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.bit_or.html b/arrow/compute/fn.bit_or.html
index 6d5bb770ea..ca830d2921 100644
--- a/arrow/compute/fn.bit_or.html
+++ b/arrow/compute/fn.bit_or.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the bitwise or of all non-null input values."><title>bit_or in arrow::compute - Rust</title><link 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="Returns the bitwise or of all non-null input values."><title>bit_or in arrow::compute - Rust</title><link 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 [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;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;<span class="where fmt-ne [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.bit_xor.html b/arrow/compute/fn.bit_xor.html
index 0782797248..99c14db2bf 100644
--- a/arrow/compute/fn.bit_xor.html
+++ b/arrow/compute/fn.bit_xor.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the bitwise xor of all non-null input values."><title>bit_xor in arrow::compute - Rust</title><link 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="Returns the bitwise xor of all non-null input values."><title>bit_xor in arrow::compute - Rust</title><link 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 [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;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;<span class="where fmt-ne [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.bool_and.html b/arrow/compute/fn.bool_and.html
index fbaa6cf285..2cc0951447 100644
--- a/arrow/compute/fn.bool_and.html
+++ b/arrow/compute/fn.bool_and.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="Returns true if all non-null input values are true, otherwise false."><title>bool_and in arrow::compute - Rust</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="Returns true if all non-null input values are true, otherwise false."><title>bool_and in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type=" [...]
 <p>Returns <code>None</code> if the array is empty or only contains null values.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/compute/fn.bool_or.html b/arrow/compute/fn.bool_or.html
index 0ed2635e22..f76f23e1ba 100644
--- a/arrow/compute/fn.bool_or.html
+++ b/arrow/compute/fn.bool_or.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="Returns true if any non-null input value is true, otherwise false."><title>bool_or in arrow::compute - Rust</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="Returns true if any non-null input value is true, otherwise false."><title>bool_or in arrow::compute - Rust</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 [...]
 <p>Returns <code>None</code> if the array is empty or only contains null values.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/compute/fn.build_filter.html b/arrow/compute/fn.build_filter.html
index 1d97f9ad01..420748974e 100644
--- a/arrow/compute/fn.build_filter.html
+++ b/arrow/compute/fn.build_filter.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 prepared function optimized to filter multiple arrays. Creating this function requires time, but using it is faster than filter when the same filter needs to be applied to multiple arrays (e.g. a multi-column `RecordBatch`). WARNING: the nulls of `filter` are ignored and the va [...]
+<!DOCTYPE html><html lang="en"><head><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 prepared function optimized to filter multiple arrays. Creating this function requires time, but using it is faster than filter when the same filter needs to be applied to multiple arrays (e.g. a multi-column `RecordBatch`). WARNING: the nulls of `filter` are ignored and the va [...]
     filter: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/function/trait.Fn.html" title="trait core::ops::function::Fn">Fn</a>(&amp;<a class="struct" href="../array/struct.ArrayData.html" title="struct arrow [...]
 Creating this function requires time, but using it is faster than <a href="fn.filter.html" title="fn arrow::compute::filter">filter</a> when the
diff --git a/arrow/compute/fn.can_cast_types.html b/arrow/compute/fn.can_cast_types.html
index 394054f3d2..14c38e8782 100644
--- a/arrow/compute/fn.can_cast_types.html
+++ b/arrow/compute/fn.can_cast_types.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 true if a value of type `from_type` can be cast into a value of `to_type`. Note that such as cast may be lossy."><title>can_cast_types in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efa [...]
+<!DOCTYPE html><html lang="en"><head><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 true if a value of type `from_type` can be cast into a value of `to_type`. Note that such as cast may be lossy."><title>can_cast_types in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efa [...]
 value of <code>to_type</code>. Note that such as cast may be lossy.</p>
 <p>If this function returns true to stay consistent with the <code>cast</code> kernel below.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/compute/fn.cast.html b/arrow/compute/fn.cast.html
index d3a6b19708..0729bccebb 100644
--- a/arrow/compute/fn.cast.html
+++ b/arrow/compute/fn.cast.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Cast `array` to the provided data type and return a new Array with type `to_type`, if possible."><title>cast in arrow::compute - 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="Cast `array` to the provided data type and return a new Array with type `to_type`, if possible."><title>cast in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pr [...]
     array: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>,
     to_type: &amp;<a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
diff --git a/arrow/compute/fn.cast_with_options.html b/arrow/compute/fn.cast_with_options.html
index 4df55930f4..e8226b89dc 100644
--- a/arrow/compute/fn.cast_with_options.html
+++ b/arrow/compute/fn.cast_with_options.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Cast `array` to the provided data type and return a new Array with type `to_type`, if possible. It accepts `CastOptions` to allow consumers to configure cast behavior."><title>cast_with_options in arrow::compute - Rust</title><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="Cast `array` to the provided data type and return a new Array with type `to_type`, if possible. It accepts `CastOptions` to allow consumers to configure cast behavior."><title>cast_with_options in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin hr [...]
     array: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>,
     to_type: &amp;<a class="enum" href="../datatypes/enum.DataType.html" title="enum arrow::datatypes::DataType">DataType</a>,
     cast_options: &amp;<a class="struct" href="struct.CastOptions.html" title="struct arrow::compute::CastOptions">CastOptions</a>&lt;'_&gt;
diff --git a/arrow/compute/fn.concat.html b/arrow/compute/fn.concat.html
index 83892c2281..5d80a54c6c 100644
--- a/arrow/compute/fn.concat.html
+++ b/arrow/compute/fn.concat.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Concatenate multiple Array of the same type into a single ArrayRef."><title>concat in arrow::compute - Rust</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="Concatenate multiple Array of the same type into a single ArrayRef."><title>concat in arrow::compute - Rust</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 [...]
     arrays: &amp;[&amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/compute/fn.concat_batches.html b/arrow/compute/fn.concat_batches.html
index bb80777c87..06c4b0fab9 100644
--- a/arrow/compute/fn.concat_batches.html
+++ b/arrow/compute/fn.concat_batches.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Concatenates `batches` together into a single record batch."><title>concat_batches in arrow::compute - Rust</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="Concatenates `batches` together into a single record batch."><title>concat_batches in arrow::compute - Rust</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 [...]
     schema: &amp;<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>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Global">Global</a>&gt;,
     input_batches: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = &amp;'a <a class="struct" href="../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a>&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a>, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summ [...]
diff --git a/arrow/compute/fn.day.html b/arrow/compute/fn.day.html
index 4c79350e3a..8de6818764 100644
--- a/arrow/compute/fn.day.html
+++ b/arrow/compute/fn.day.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the day of a given temporal primitive array as an array of integers"><title>day in arrow::compute - 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="Extracts the day of a given temporal primitive array as an array of integers"><title>day in arrow::compute - 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 [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.day_dyn.html b/arrow/compute/fn.day_dyn.html
index 8316d22008..12a60e258b 100644
--- a/arrow/compute/fn.day_dyn.html
+++ b/arrow/compute/fn.day_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the day of a given temporal array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>day_dyn in arrow::compute - Rust</title><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="Extracts the day of a given temporal array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>day_dyn in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.f [...]
 If the given array isn’t temporal primitive or dictionary array,
 an <code>Err</code> will be returned.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/compute/fn.doy.html b/arrow/compute/fn.doy.html
index 43fe8e851a..9f7047d856 100644
--- a/arrow/compute/fn.doy.html
+++ b/arrow/compute/fn.doy.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the day of year of a given temporal primitive array as an array of integers The day of year that ranges from 1 to 366"><title>doy in arrow::compute - 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="Extracts the day of year of a given temporal primitive array as an array of integers The day of year that ranges from 1 to 366"><title>doy in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafa [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.doy_dyn.html b/arrow/compute/fn.doy_dyn.html
index fee4083854..b1cfbdf27e 100644
--- a/arrow/compute/fn.doy_dyn.html
+++ b/arrow/compute/fn.doy_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the day of year of a given temporal array as an array of integers The day of year that ranges from 1 to 366. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>doy_dyn in arrow::compute - Rust</title><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="Extracts the day of year of a given temporal array as an array of integers The day of year that ranges from 1 to 366. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>doy_dyn in arrow::compute - Rust</title><link rel="preload" as="font"  [...]
 The day of year that ranges from 1 to 366.
 If the given array isn’t temporal primitive or dictionary array,
 an <code>Err</code> will be returned.</p>
diff --git a/arrow/compute/fn.filter.html b/arrow/compute/fn.filter.html
index 68c735a08c..302eb1449c 100644
--- a/arrow/compute/fn.filter.html
+++ b/arrow/compute/fn.filter.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Filters an Array, returning elements matching the filter (i.e. where the values are true)."><title>filter in arrow::compute - 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="Filters an Array, returning elements matching the filter (i.e. where the values are true)."><title>filter in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
     values: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>,
     predicate: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
diff --git a/arrow/compute/fn.filter_record_batch.html b/arrow/compute/fn.filter_record_batch.html
index 73d25ea9ab..8b41b37e3e 100644
--- a/arrow/compute/fn.filter_record_batch.html
+++ b/arrow/compute/fn.filter_record_batch.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 new RecordBatch with arrays containing only values matching the filter."><title>filter_record_batch in arrow::compute - 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="Returns a new RecordBatch with arrays containing only values matching the filter."><title>filter_record_batch in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="p [...]
     record_batch: &amp;<a class="struct" href="../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a>,
     predicate: &amp;<a class="struct" href="../array/struct.BooleanArray.html" title="struct arrow::array::BooleanArray">BooleanArray</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../record_batch/struct.RecordBatch.html" title="struct arrow::record_batch::RecordBatch">RecordBatch</a>, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a>&gt;</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summ [...]
diff --git a/arrow/compute/fn.hour.html b/arrow/compute/fn.hour.html
index e4b2b37751..8a985a497e 100644
--- a/arrow/compute/fn.hour.html
+++ b/arrow/compute/fn.hour.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the hours of a given temporal primitive array as an array of integers within the range of [0, 23]."><title>hour in arrow::compute - 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="Extracts the hours of a given temporal primitive array as an array of integers within the range of [0, 23]."><title>hour in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2">< [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.hour_dyn.html b/arrow/compute/fn.hour_dyn.html
index b2cb22a0f4..c4efad7c0f 100644
--- a/arrow/compute/fn.hour_dyn.html
+++ b/arrow/compute/fn.hour_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the hours of a given array as an array of integers within the range of [0, 23]. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>hour_dyn in arrow::compute - Rust</title><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="Extracts the hours of a given array as an array of integers within the range of [0, 23]. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>hour_dyn in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigi [...]
 the range of [0, 23]. If the given array isn’t temporal primitive or dictionary array,
 an <code>Err</code> will be returned.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow/compute/fn.interleave.html b/arrow/compute/fn.interleave.html
index 93309a63e2..2c503fdfac 100644
--- a/arrow/compute/fn.interleave.html
+++ b/arrow/compute/fn.interleave.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Takes elements by index from a list of `Array`, creating a new `Array` from those values."><title>interleave in arrow::compute - 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="Takes elements by index from a list of `Array`, creating a new `Array` from those values."><title>interleave in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pr [...]
     values: &amp;[&amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>],
     indices: &amp;[(<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>)]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
diff --git a/arrow/compute/fn.is_not_null.html b/arrow/compute/fn.is_not_null.html
index 6ceac88a50..905f582a7f 100644
--- a/arrow/compute/fn.is_not_null.html
+++ b/arrow/compute/fn.is_not_null.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 non-null BooleanArray with whether each value of the array is not null."><title>is_not_null in arrow::compute - 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="Returns a non-null BooleanArray with whether each value of the array is not null."><title>is_not_null in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload"  [...]
 <h2 id="error"><a href="#error">Error</a></h2>
 <p>This function never errors.</p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/compute/fn.is_null.html b/arrow/compute/fn.is_null.html
index 95ea941e69..c22483c8e9 100644
--- a/arrow/compute/fn.is_null.html
+++ b/arrow/compute/fn.is_null.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 non-null BooleanArray with whether each value of the array is null."><title>is_null in arrow::compute - 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="Returns a non-null BooleanArray with whether each value of the array is null."><title>is_null in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font [...]
 <h2 id="error"><a href="#error">Error</a></h2>
 <p>This function never errors.</p>
 <h2 id="example"><a href="#example">Example</a></h2>
diff --git a/arrow/compute/fn.lexicographical_partition_ranges.html b/arrow/compute/fn.lexicographical_partition_ranges.html
index fc55c0be09..5ff51c1a56 100644
--- a/arrow/compute/fn.lexicographical_partition_ranges.html
+++ b/arrow/compute/fn.lexicographical_partition_ranges.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 a list of already sorted columns, find partition ranges that would partition lexicographically equal values across columns."><title>lexicographical_partition_ranges in arrow::compute - Rust</title><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="Given a list of already sorted columns, find partition ranges that would partition lexicographically equal values across columns."><title>lexicographical_partition_ranges in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/ [...]
     columns: &amp;[<a class="struct" href="struct.SortColumn.html" title="struct arrow::compute::SortColumn">SortColumn</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;impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="struct" href="https://doc.rust-lang.org/nightly/core/ops/range/struct.Range.html" title="struct core::ops::range::Range">Range</a>&lt;<a class="primitive"  [...]
 lexicographically equal values across columns.</p>
diff --git a/arrow/compute/fn.lexsort.html b/arrow/compute/fn.lexsort.html
index 870d495e33..5a5f825b91 100644
--- a/arrow/compute/fn.lexsort.html
+++ b/arrow/compute/fn.lexsort.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Sort a list of `ArrayRef` using `SortOptions` provided for each array."><title>lexsort in arrow::compute - Rust</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="Sort a list of `ArrayRef` using `SortOptions` provided for each array."><title>lexsort in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
     columns: &amp;[<a class="struct" href="struct.SortColumn.html" title="struct arrow::compute::SortColumn">SortColumn</a>],
     limit: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="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="../array/trait.Array.html" title="trait arrow::array::Array">Array< [...]
diff --git a/arrow/compute/fn.lexsort_to_indices.html b/arrow/compute/fn.lexsort_to_indices.html
index 58275a0aaa..e117f88795 100644
--- a/arrow/compute/fn.lexsort_to_indices.html
+++ b/arrow/compute/fn.lexsort_to_indices.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Sort elements lexicographically from a list of `ArrayRef` into an unsigned integer (`UInt32Array`) of indices."><title>lexsort_to_indices in arrow::compute - 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="Sort elements lexicographically from a list of `ArrayRef` into an unsigned integer (`UInt32Array`) of indices."><title>lexsort_to_indices in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac [...]
     columns: &amp;[<a class="struct" href="struct.SortColumn.html" title="struct arrow::compute::SortColumn">SortColumn</a>],
     limit: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;
 ) -&gt; <a 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="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowEr [...]
diff --git a/arrow/compute/fn.max.html b/arrow/compute/fn.max.html
index 732361cc38..af02cbb993 100644
--- a/arrow/compute/fn.max.html
+++ b/arrow/compute/fn.max.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the maximum value in the array, according to the natural order. For floating point arrays any NaN values are considered to be greater than any other non-null value"><title>max in arrow::compute - Rust</title><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="Returns the maximum value in the array, according to the natural order. For floating point arrays any NaN values are considered to be greater than any other non-null value"><title>max in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../ [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;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;<span class="where fmt-ne [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.max_array.html b/arrow/compute/fn.max_array.html
index 2ca5881488..275ee6cd44 100644
--- a/arrow/compute/fn.max_array.html
+++ b/arrow/compute/fn.max_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="Returns the max of values in the array of `ArrowNumericType` type, or dictionary array with value of `ArrowNumericType` type."><title>max_array in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98e [...]
+<!DOCTYPE html><html lang="en"><head><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 the max of values in the array of `ArrowNumericType` type, or dictionary array with value of `ArrowNumericType` type."><title>max_array in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98e [...]
     A: <a class="trait" href="../array/trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&lt;Item = &lt;T as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</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="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></code></pre><details clas [...]
diff --git a/arrow/compute/fn.max_binary.html b/arrow/compute/fn.max_binary.html
index 3b36893ae0..13ae1ab377 100644
--- a/arrow/compute/fn.max_binary.html
+++ b/arrow/compute/fn.max_binary.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the maximum value in the binary array, according to the natural order."><title>max_binary in arrow::compute - 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="Returns the maximum value in the binary array, according to the natural order."><title>max_binary in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as=" [...]
     array: &amp;<a class="struct" href="../array/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;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;<span class="where fmt-newline">where
     T: <a class="trait" href="../array/trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Returns the maximum value in the binary array, according to the natural order.</p>
diff --git a/arrow/compute/fn.max_boolean.html b/arrow/compute/fn.max_boolean.html
index a11c8b9151..ed66ae843d 100644
--- a/arrow/compute/fn.max_boolean.html
+++ b/arrow/compute/fn.max_boolean.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the maximum value in the boolean array"><title>max_boolean in arrow::compute - Rust</title><link 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="Returns the maximum value in the boolean array"><title>max_boolean in arrow::compute - Rust</title><link 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 [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>a = BooleanArray::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="bool-val">true</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="bool-val">false</span>)]);
diff --git a/arrow/compute/fn.max_string.html b/arrow/compute/fn.max_string.html
index 26164e7c86..d441ceb58f 100644
--- a/arrow/compute/fn.max_string.html
+++ b/arrow/compute/fn.max_string.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the maximum value in the string array, according to the natural order."><title>max_string in arrow::compute - 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="Returns the maximum value in the string array, according to the natural order."><title>max_string in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as=" [...]
     array: &amp;<a class="struct" href="../array/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;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;<span class="where fmt-newline">where
     T: <a class="trait" href="../array/trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Returns the maximum value in the string array, according to the natural order.</p>
diff --git a/arrow/compute/fn.microsecond.html b/arrow/compute/fn.microsecond.html
index 0258060a9e..2fa03a179b 100644
--- a/arrow/compute/fn.microsecond.html
+++ b/arrow/compute/fn.microsecond.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the microseconds of a given temporal primitive array as an array of integers"><title>microsecond in arrow::compute - 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="Extracts the microseconds of a given temporal primitive array as an array of integers"><title>microsecond in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.microsecond_dyn.html b/arrow/compute/fn.microsecond_dyn.html
index d1ed6f04f1..db665af5c0 100644
--- a/arrow/compute/fn.microsecond_dyn.html
+++ b/arrow/compute/fn.microsecond_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the microseconds of a given temporal primitive array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>microsecond_dyn in arrow::compute - 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="Extracts the microseconds of a given temporal primitive array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>microsecond_dyn in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" cross [...]
     array: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
 If the given array isn’t temporal primitive or dictionary array,
diff --git a/arrow/compute/fn.millisecond.html b/arrow/compute/fn.millisecond.html
index 6b388a324e..33d0e759ac 100644
--- a/arrow/compute/fn.millisecond.html
+++ b/arrow/compute/fn.millisecond.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the milliseconds of a given temporal primitive array as an array of integers"><title>millisecond in arrow::compute - 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="Extracts the milliseconds of a given temporal primitive array as an array of integers"><title>millisecond in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="prelo [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.millisecond_dyn.html b/arrow/compute/fn.millisecond_dyn.html
index dc3cb8a1a4..3c60c2251f 100644
--- a/arrow/compute/fn.millisecond_dyn.html
+++ b/arrow/compute/fn.millisecond_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the milliseconds of a given temporal primitive array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>millisecond_dyn in arrow::compute - 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="Extracts the milliseconds of a given temporal primitive array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>millisecond_dyn in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" cross [...]
     array: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
 If the given array isn’t temporal primitive or dictionary array,
diff --git a/arrow/compute/fn.min.html b/arrow/compute/fn.min.html
index ab4631247a..e4deba0e22 100644
--- a/arrow/compute/fn.min.html
+++ b/arrow/compute/fn.min.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the minimum value in the array, according to the natural order. For floating point arrays any NaN values are considered to be greater than any other non-null value"><title>min in arrow::compute - Rust</title><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="Returns the minimum value in the array, according to the natural order. For floating point arrays any NaN values are considered to be greater than any other non-null value"><title>min in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../ [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;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;<span class="where fmt-ne [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.min_array.html b/arrow/compute/fn.min_array.html
index cc3b9f2c3c..8182ccd46b 100644
--- a/arrow/compute/fn.min_array.html
+++ b/arrow/compute/fn.min_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="Returns the min of values in the array of `ArrowNumericType` type, or dictionary array with value of `ArrowNumericType` type."><title>min_array in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98e [...]
+<!DOCTYPE html><html lang="en"><head><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 the min of values in the array of `ArrowNumericType` type, or dictionary array with value of `ArrowNumericType` type."><title>min_array in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98e [...]
     A: <a class="trait" href="../array/trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&lt;Item = &lt;T as <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../datatypes/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow::datatypes::ArrowPrimitiveType::Native">Native</a>&gt;,
     T: <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</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="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></code></pre><details clas [...]
diff --git a/arrow/compute/fn.min_binary.html b/arrow/compute/fn.min_binary.html
index 9c734d342d..9bbdee0134 100644
--- a/arrow/compute/fn.min_binary.html
+++ b/arrow/compute/fn.min_binary.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the minimum value in the binary array, according to the natural order."><title>min_binary in arrow::compute - 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="Returns the minimum value in the binary array, according to the natural order."><title>min_binary in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as=" [...]
     array: &amp;<a class="struct" href="../array/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;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;<span class="where fmt-newline">where
     T: <a class="trait" href="../array/trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Returns the minimum value in the binary array, according to the natural order.</p>
diff --git a/arrow/compute/fn.min_boolean.html b/arrow/compute/fn.min_boolean.html
index e020cca231..83d584ce55 100644
--- a/arrow/compute/fn.min_boolean.html
+++ b/arrow/compute/fn.min_boolean.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the minimum value in the boolean array."><title>min_boolean in arrow::compute - Rust</title><link 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="Returns the minimum value in the boolean array."><title>min_boolean in arrow::compute - Rust</title><link 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 [...]
 
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code>
 <span class="kw">let </span>a = BooleanArray::from(<span class="macro">vec!</span>[<span class="prelude-val">Some</span>(<span class="bool-val">true</span>), <span class="prelude-val">None</span>, <span class="prelude-val">Some</span>(<span class="bool-val">false</span>)]);
diff --git a/arrow/compute/fn.min_string.html b/arrow/compute/fn.min_string.html
index 277a00934b..8979626589 100644
--- a/arrow/compute/fn.min_string.html
+++ b/arrow/compute/fn.min_string.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 the minimum value in the string array, according to the natural order."><title>min_string in arrow::compute - 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="Returns the minimum value in the string array, according to the natural order."><title>min_string in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as=" [...]
     array: &amp;<a class="struct" href="../array/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;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;<span class="where fmt-newline">where
     T: <a class="trait" href="../array/trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</span></code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Returns the minimum value in the string array, according to the natural order.</p>
diff --git a/arrow/compute/fn.minute.html b/arrow/compute/fn.minute.html
index 452eac7933..bf9ab2b111 100644
--- a/arrow/compute/fn.minute.html
+++ b/arrow/compute/fn.minute.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the minutes of a given temporal primitive array as an array of integers"><title>minute in arrow::compute - 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="Extracts the minutes of a given temporal primitive array as an array of integers"><title>minute in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="fo [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.minute_dyn.html b/arrow/compute/fn.minute_dyn.html
index 3eaba64fd0..a352c2e936 100644
--- a/arrow/compute/fn.minute_dyn.html
+++ b/arrow/compute/fn.minute_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the minutes of a given temporal array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>minute_dyn in arrow::compute - Rust</title><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="Extracts the minutes of a given temporal array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>minute_dyn in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../s [...]
     array: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
 If the given array isn’t temporal primitive or dictionary array,
diff --git a/arrow/compute/fn.month.html b/arrow/compute/fn.month.html
index 9eb859a31c..9b9ca4cb29 100644
--- a/arrow/compute/fn.month.html
+++ b/arrow/compute/fn.month.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the month of a given temporal primitive array as an array of integers within the range of [1, 12]."><title>month in arrow::compute - 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="Extracts the month of a given temporal primitive array as an array of integers within the range of [1, 12]."><title>month in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"> [...]
     array: &amp;<a class="struct" href="../array/struct.PrimitiveArray.html" title="struct arrow::array::PrimitiveArray">PrimitiveArray</a>&lt;T&gt;
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../array/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;, <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError [...]
     T: <a class="trait" href="../datatypes/trait.ArrowTemporalType.html" title="trait arrow::datatypes::ArrowTemporalType">ArrowTemporalType</a> + <a class="trait" href="../datatypes/trait.ArrowNumericType.html" title="trait arrow::datatypes::ArrowNumericType">ArrowNumericType</a>,
diff --git a/arrow/compute/fn.month_dyn.html b/arrow/compute/fn.month_dyn.html
index e7151413d5..08e8b0b10f 100644
--- a/arrow/compute/fn.month_dyn.html
+++ b/arrow/compute/fn.month_dyn.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Extracts the month of a given temporal array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>month_dyn in arrow::compute - Rust</title><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="Extracts the month of a given temporal array as an array of integers. If the given array isn’t temporal primitive or dictionary array, an `Err` will be returned."><title>month_dyn in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../stat [...]
     array: &amp;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" href="../array/trait.Array.html" title="trait arrow::array::Array">Array</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/alloc/struct.Global.html" title="struct alloc::alloc::Glob [...]
 If the given array isn’t temporal primitive or dictionary array,
diff --git a/arrow/compute/fn.multiply_fixed_point.html b/arrow/compute/fn.multiply_fixed_point.html
index 8c72c3cb62..51c4835f79 100644
--- a/arrow/compute/fn.multiply_fixed_point.html
+++ b/arrow/compute/fn.multiply_fixed_point.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Perform `left * right` operation on two decimal arrays. If either left or right value is null then the result is also null."><title>multiply_fixed_point in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regul [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Perform `left * right` operation on two decimal arrays. If either left or right value is null then the result is also null."><title>multiply_fixed_point in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regul [...]
     left: &amp;<a class="struct" href="../array/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;,
     right: &amp;<a class="struct" href="../array/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;,
     required_scale: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a>
diff --git a/arrow/compute/fn.multiply_fixed_point_checked.html b/arrow/compute/fn.multiply_fixed_point_checked.html
index 4ef888f28a..1828509820 100644
--- a/arrow/compute/fn.multiply_fixed_point_checked.html
+++ b/arrow/compute/fn.multiply_fixed_point_checked.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Perform `left * right` operation on two decimal arrays. If either left or right value is null then the result is also null."><title>multiply_fixed_point_checked in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSeri [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Perform `left * right` operation on two decimal arrays. If either left or right value is null then the result is also null."><title>multiply_fixed_point_checked in arrow::compute - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSeri [...]
... 49112 lines suppressed ...