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/06/30 15:26:56 UTC

[arrow-rs] branch asf-site updated: deploy: 414235e7630d05cccf0b9f5032ebfc0858b8ae5b

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 66636f71a deploy: 414235e7630d05cccf0b9f5032ebfc0858b8ae5b
66636f71a is described below

commit 66636f71af97334cb31338ff8ed08b1975c1b2fb
Author: tustvold <tu...@users.noreply.github.com>
AuthorDate: Fri Jun 30 15:26:49 2023 +0000

    deploy: 414235e7630d05cccf0b9f5032ebfc0858b8ae5b
---
 arrow/array/struct.ArrayData.html                  |  22 ++--
 arrow/array/struct.BooleanArray.html               |   2 +-
 arrow/array/struct.BooleanBufferBuilder.html       |   2 +-
 arrow/array/struct.DictionaryArray.html            |  12 +-
 arrow/array/struct.FixedSizeBinaryArray.html       |   4 +-
 arrow/array/struct.FixedSizeListArray.html         |   4 +-
 arrow/array/struct.GenericByteArray.html           |  20 ++--
 arrow/array/struct.GenericListArray.html           |  10 +-
 arrow/array/struct.MapArray.html                   |   2 +-
 arrow/array/struct.NativeAdapter.html              |   4 +-
 arrow/array/struct.NullArray.html                  |   2 +-
 arrow/array/struct.PrimitiveArray.html             | 122 ++++++++++-----------
 arrow/array/struct.RunArray.html                   |   4 +-
 arrow/array/struct.StructArray.html                |   4 +-
 arrow/array/struct.UnionArray.html                 |   2 +-
 arrow/buffer/struct.BooleanBuffer.html             |   2 +-
 arrow/buffer/struct.Buffer.html                    |   4 +-
 arrow/buffer/struct.MutableBuffer.html             |   4 +-
 arrow/buffer/struct.ScalarBuffer.html              |   6 +-
 arrow/datatypes/enum.DataType.html                 |   4 +-
 arrow/datatypes/struct.Field.html                  |   2 +-
 arrow/datatypes/struct.Fields.html                 |   4 +-
 arrow/datatypes/struct.Schema.html                 |   2 +-
 arrow/datatypes/struct.SchemaBuilder.html          |   2 +-
 arrow/datatypes/struct.i256.html                   |   6 +-
 arrow/datatypes/trait.ArrowNativeType.html         |   2 +-
 arrow/datatypes/trait.ArrowNativeTypeOp.html       |   2 +-
 arrow/error/enum.ArrowError.html                   |   4 +-
 arrow/ffi/struct.FFI_ArrowSchema.html              |   8 +-
 arrow/index.html                                   |   2 +-
 arrow/pyarrow/struct.ArrowException.html           |   2 +-
 arrow/record_batch/struct.RecordBatch.html         |   2 +-
 arrow_arith/index.html                             |   2 +-
 .../arithmetic/trait.ArrowNativeTypeOp.html        |   2 +-
 .../binary_array/type.GenericBinaryArray.html      |   2 +-
 .../array/boolean_array/struct.BooleanArray.html   |   4 +-
 .../array/byte_array/struct.GenericByteArray.html  |   6 +-
 .../dictionary_array/struct.DictionaryArray.html   |  14 +--
 .../struct.TypedDictionaryArray.html               |   6 +-
 .../struct.FixedSizeBinaryArray.html               |   6 +-
 .../struct.FixedSizeListArray.html                 |   4 +-
 arrow_array/array/fn.get_offsets.html              |   2 +-
 arrow_array/array/fn.make_array.html               |   2 +-
 arrow_array/array/index.html                       |   2 +-
 .../array/list_array/struct.GenericListArray.html  |   6 +-
 arrow_array/array/map_array/struct.MapArray.html   |   6 +-
 arrow_array/array/null_array/struct.NullArray.html |   4 +-
 .../primitive_array/struct.NativeAdapter.html      |   2 +-
 .../primitive_array/struct.PrimitiveArray.html     |  60 +++++-----
 arrow_array/array/run_array/struct.RunArray.html   |   4 +-
 .../array/run_array/struct.TypedRunArray.html      |   6 +-
 .../string_array/type.GenericStringArray.html      |   2 +-
 arrow_array/array/struct.BooleanArray.html         |   4 +-
 arrow_array/array/struct.DictionaryArray.html      |  14 +--
 arrow_array/array/struct.FixedSizeBinaryArray.html |   6 +-
 arrow_array/array/struct.FixedSizeListArray.html   |   4 +-
 arrow_array/array/struct.GenericByteArray.html     |   6 +-
 arrow_array/array/struct.GenericListArray.html     |   6 +-
 arrow_array/array/struct.MapArray.html             |   6 +-
 arrow_array/array/struct.NativeAdapter.html        |   2 +-
 arrow_array/array/struct.NullArray.html            |   4 +-
 arrow_array/array/struct.PrimitiveArray.html       |  60 +++++-----
 arrow_array/array/struct.RunArray.html             |   4 +-
 arrow_array/array/struct.StructArray.html          |   4 +-
 arrow_array/array/struct.TypedDictionaryArray.html |   6 +-
 arrow_array/array/struct.TypedRunArray.html        |   6 +-
 arrow_array/array/struct.UnionArray.html           |   4 +-
 .../array/struct_array/struct.StructArray.html     |   4 +-
 arrow_array/array/trait.Array.html                 |  10 +-
 arrow_array/array/type.ArrayRef.html               |   2 +-
 arrow_array/array/type.GenericBinaryArray.html     |   2 +-
 arrow_array/array/type.GenericStringArray.html     |   2 +-
 .../array/union_array/struct.UnionArray.html       |   4 +-
 arrow_array/cast/fn.downcast_array.html            |   2 +-
 arrow_array/index.html                             |   2 +-
 arrow_array/record_batch/struct.RecordBatch.html   |   2 +-
 arrow_array/struct.RecordBatch.html                |   2 +-
 arrow_array/trait.ArrowNativeTypeOp.html           |   2 +-
 arrow_buffer/bigint/struct.ParseI256Error.html     |   2 +-
 arrow_buffer/bigint/struct.i256.html               |   6 +-
 .../buffer/boolean/struct.BooleanBuffer.html       |   2 +-
 arrow_buffer/buffer/immutable/struct.Buffer.html   |   2 +-
 .../buffer/mutable/struct.MutableBuffer.html       |   2 +-
 .../buffer/scalar/struct.ScalarBuffer.html         |  12 +-
 arrow_buffer/buffer/struct.BooleanBuffer.html      |   2 +-
 arrow_buffer/buffer/struct.Buffer.html             |   2 +-
 arrow_buffer/buffer/struct.MutableBuffer.html      |   2 +-
 arrow_buffer/buffer/struct.ScalarBuffer.html       |  12 +-
 .../boolean/struct.BooleanBufferBuilder.html       |   2 +-
 .../builder/struct.BooleanBufferBuilder.html       |   2 +-
 arrow_buffer/index.html                            |   2 +-
 arrow_buffer/native/private/trait.Sealed.html      |   2 +-
 arrow_buffer/native/trait.ArrowNativeType.html     |   2 +-
 arrow_buffer/struct.i256.html                      |   6 +-
 arrow_buffer/trait.ArrowNativeType.html            |   2 +-
 arrow_cast/display/enum.FormatError.html           |   2 +-
 arrow_cast/display/trait.DisplayIndex.html         |   2 +-
 arrow_cast/display/trait.DisplayIndexState.html    |  76 ++++++-------
 arrow_cast/index.html                              |   2 +-
 arrow_cast/parse/trait.Parser.html                 |   2 +-
 arrow_csv/index.html                               |   2 +-
 arrow_data/index.html                              |   2 +-
 arrow_file_to_stream/index.html                    |   2 +-
 arrow_flight/error/enum.FlightError.html           |   2 +-
 arrow_flight/gen/struct.Location.html              |   2 +-
 arrow_flight/index.html                            |   2 +-
 .../sql/metadata/sql_info/enum.SqlInfoValue.html   |   2 +-
 arrow_flight/struct.IpcMessage.html                |   2 +-
 arrow_flight/struct.Location.html                  |   2 +-
 arrow_flight/struct.SchemaAsIpc.html               |   2 +-
 arrow_integration_test/index.html                  |   2 +-
 arrow_integration_test/struct.ArrowJsonField.html  |   2 +-
 .../auth_basic_proto/fn.authenticate.html          |   2 +-
 .../auth_basic_proto/type.Client.html              |   2 +-
 .../fn.consume_flight_location.html                |   4 +-
 .../fn.receive_batch_flight_data.html              |   4 +-
 .../fn.receive_schema_flight_data.html             |   2 +-
 .../integration_test/fn.send_batch.html            |   2 +-
 .../integration_test/fn.upload_data.html           |   4 +-
 .../integration_test/fn.verify_data.html           |   4 +-
 .../integration_test/type.Client.html              |   2 +-
 .../struct.AuthBasicProtoScenarioImpl.html         |  54 ++++-----
 .../flight_server_scenarios/fn.endpoint.html       |   2 +-
 .../integration_test/fn.save_uploaded_chunks.html  |   4 +-
 .../integration_test/fn.send_app_metadata.html     |   2 +-
 .../integration_test/struct.FlightServiceImpl.html |  54 ++++-----
 .../middleware/struct.MiddlewareScenarioImpl.html  |  54 ++++-----
 arrow_integration_testing/index.html               |   2 +-
 arrow_ipc/index.html                               |   2 +-
 arrow_json/index.html                              |   2 +-
 .../primitive_array/trait.ParseJsonNumber.html     |   2 +-
 .../reader/serializer/struct.ListSerializer.html   |   6 +-
 .../reader/serializer/struct.ObjectSerializer.html |   8 +-
 .../reader/serializer/struct.SerializerError.html  |   2 +-
 arrow_json/trait.JsonSerializable.html             |   2 +-
 arrow_json_integration_test/index.html             |   2 +-
 arrow_ord/index.html                               |   2 +-
 arrow_row/fixed/trait.FixedLengthEncoding.html     |   2 +-
 arrow_row/index.html                               |   2 +-
 arrow_schema/datatype/enum.DataType.html           |   8 +-
 arrow_schema/enum.ArrowError.html                  |   2 +-
 arrow_schema/enum.DataType.html                    |   8 +-
 arrow_schema/error/enum.ArrowError.html            |   2 +-
 arrow_schema/ffi/flags/struct.Flags.html           |  14 +--
 arrow_schema/ffi/struct.FFI_ArrowSchema.html       |   6 +-
 arrow_schema/ffi/struct.Flags.html                 |  14 +--
 arrow_schema/field/struct.Field.html               |   2 +-
 arrow_schema/fields/struct.Fields.html             |   2 +-
 arrow_schema/index.html                            |   2 +-
 arrow_schema/schema/struct.Schema.html             |   2 +-
 arrow_schema/schema/struct.SchemaBuilder.html      |   2 +-
 arrow_schema/struct.Field.html                     |   2 +-
 arrow_schema/struct.Fields.html                    |   2 +-
 arrow_schema/struct.Schema.html                    |   2 +-
 arrow_schema/struct.SchemaBuilder.html             |   2 +-
 arrow_select/index.html                            |   2 +-
 arrow_stream_to_file/index.html                    |   2 +-
 arrow_string/index.html                            |   2 +-
 flight_sql_client/index.html                       |   2 +-
 flight_test_integration_client/index.html          |   2 +-
 flight_test_integration_server/index.html          |   2 +-
 .../flight_service_server/trait.FlightService.js   |   2 +-
 implementors/clap_builder/derive/trait.Parser.js   |   2 +-
 implementors/core/clone/trait.Clone.js             |  28 ++---
 implementors/core/cmp/trait.Eq.js                  |  16 +--
 implementors/core/cmp/trait.Ord.js                 |   8 +-
 implementors/core/cmp/trait.PartialEq.js           |  20 ++--
 implementors/core/cmp/trait.PartialOrd.js          |  12 +-
 implementors/core/convert/trait.AsRef.js           |   2 +-
 implementors/core/convert/trait.From.js            |  20 ++--
 implementors/core/convert/trait.TryFrom.js         |   6 +-
 implementors/core/default/trait.Default.js         |  16 +--
 implementors/core/fmt/trait.Debug.js               |  40 +++----
 implementors/core/fmt/trait.Display.js             |   8 +-
 implementors/core/hash/trait.Hash.js               |  10 +-
 .../core/iter/traits/collect/trait.Extend.js       |   4 +-
 .../core/iter/traits/collect/trait.FromIterator.js |   6 +-
 .../core/iter/traits/collect/trait.IntoIterator.js |   6 +-
 .../double_ended/trait.DoubleEndedIterator.js      |   2 +-
 .../core/iter/traits/iterator/trait.Iterator.js    |  10 +-
 implementors/core/marker/trait.Copy.js             |  18 +--
 implementors/core/marker/trait.Send.js             |   2 +-
 implementors/core/marker/trait.StructuralEq.js     |  12 +-
 .../core/marker/trait.StructuralPartialEq.js       |  16 +--
 implementors/core/marker/trait.Sync.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         |   2 +-
 implementors/core/ops/drop/trait.Drop.js           |   2 +-
 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/pyo3/conversion/trait.IntoPy.js       |   2 +-
 implementors/serde/de/trait.Deserialize.js         |   4 +-
 implementors/serde/ser/trait.Serialize.js          |   6 +-
 implementors/std/io/trait.Write.js                 |   2 +-
 .../thrift/protocol/trait.TSerializable.js         |   2 +-
 .../selection/struct.RowSelection.html             |   2 +-
 .../arrow/arrow_reader/struct.RowSelection.html    |   2 +-
 .../record_reader/buffer/trait.ScalarValue.html    |   2 +-
 parquet/basic/enum.ColumnOrder.html                |   2 +-
 parquet/basic/enum.Compression.html                |   2 +-
 parquet/basic/enum.ConvertedType.html              |   2 +-
 parquet/basic/enum.Encoding.html                   |   2 +-
 parquet/basic/enum.LogicalType.html                |   2 +-
 parquet/basic/enum.PageType.html                   |   2 +-
 parquet/basic/enum.Type.html                       |   2 +-
 .../data_type/private/trait.ParquetValueType.html  |  40 +++----
 parquet/data_type/struct.ByteArray.html            |  10 +-
 parquet/data_type/struct.FixedLenByteArray.html    |  16 +--
 parquet/data_type/struct.Int96.html                |   2 +-
 parquet/data_type/trait.AsBytes.html               |   2 +-
 parquet/data_type/trait.SliceAsBytes.html          |   2 +-
 parquet/errors/enum.ParquetError.html              |   2 +-
 parquet/file/reader/trait.ChunkReader.html         |   2 +-
 .../struct.SerializedFileReader.html               |   2 +-
 .../statistics/private/trait.MakeStatistics.html   |   6 +-
 .../file/statistics/struct.ValueStatistics.html    |   2 +-
 parquet/format/enum.LogicalType.html               |   2 +-
 parquet/format/struct.BoundaryOrder.html           |   2 +-
 parquet/format/struct.CompressionCodec.html        |   2 +-
 parquet/format/struct.Encoding.html                |   2 +-
 parquet/format/struct.FieldRepetitionType.html     |   2 +-
 parquet/format/struct.PageType.html                |   2 +-
 parquet/format/struct.Type.html                    |   2 +-
 parquet/index.html                                 |   2 +-
 parquet/record/api/enum.Field.html                 |   2 +-
 parquet/record/api/struct.Row.html                 |   4 +-
 parquet/record/enum.Field.html                     |   2 +-
 parquet/record/struct.Row.html                     |   4 +-
 parquet/schema/types/struct.ColumnPath.html        |   2 +-
 parquet_concat/index.html                          |   2 +-
 parquet_derive/index.html                          |   2 +-
 parquet_derive_test/index.html                     |   2 +-
 parquet_fromcsv/enum.ParquetFromCsvError.html      |   2 +-
 parquet_fromcsv/index.html                         |   2 +-
 parquet_index/index.html                           |   2 +-
 parquet_layout/index.html                          |   2 +-
 parquet_read/index.html                            |   2 +-
 parquet_rewrite/index.html                         |   2 +-
 parquet_rowcount/index.html                        |   2 +-
 parquet_schema/index.html                          |   2 +-
 parquet_show_bloom_filter/index.html               |   2 +-
 search-index.js                                    |  18 +--
 252 files changed, 782 insertions(+), 782 deletions(-)

diff --git a/arrow/array/struct.ArrayData.html b/arrow/array/struct.ArrayData.html
index 77c168067..70c1be6ce 100644
--- a/arrow/array/struct.ArrayData.html
+++ b/arrow/array/struct.ArrayData.html
@@ -173,19 +173,19 @@ without recursing into child <a href="struct.ArrayData.html" title="struct arrow
 to determine buffer equality. This is cheaper than <code>PartialEq::eq</code> but may
 return false when the arrays are logically equal</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.into_builder" class="method"><a class="srclink rightside" href="../../src/arrow_data/data/mod.rs.html#1482">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  [...]
-</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="srclink rightside" href="../../src/arrow_data/data/mod.rs.html#218">source</a><a href="#impl-Clone-for-ArrayData" 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-ArrayData" class="impl"><a class="srclink rightside" href="../../src/arrow_data/data/mod.rs.html#218">source</a><a href="#impl-Clone-for-ArrayData" class="anchor">§</a><h3 class="code-header"> [...]
     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-5" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#580">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:: [...]
-    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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#453">source</a><a href="#method.from" 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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#309">source</a><a href="#method.from-6" 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="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#580">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 [...]
+    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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#453">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#309">source</a><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang [...]
     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-14" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1369">source</a><a href="#method.from-14" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow [...]
-    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-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#269">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
-    T: <a class="trait" href="../datatypes/trait.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-9" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#628">source</a><a href="#method.from-9" 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="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#483">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#317">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang [...]
-    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-20" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#954">source</a><a href="#method.from-20" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
-    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-21" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#296">source</a><a href="#method.from-21" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc. [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-19" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1369">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 [...]
+    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-21" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#269">source</a><a href="#method.from-21" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc. [...]
+    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-8" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#628">source</a><a href="#method.from-8" 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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#483">source</a><a href="#method.from" 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-9" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#317">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang [...]
+    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-5" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#954">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href= [...]
+    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="srclink 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.ru [...]
 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="srclink" 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" 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-ToPyArrow-for-ArrayData" class="impl"><a class="srclink 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 [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow/array/struct.BooleanArray.html b/arrow/array/struct.BooleanArray.html
index f98525415..961f1ac25 100644
--- a/arrow/array/struct.BooleanArray.html
+++ b/arrow/array/struct.BooleanArray.html
@@ -79,7 +79,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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>( [...]
     &amp;self,
     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="srclink" 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" cl [...]
diff --git a/arrow/array/struct.BooleanBufferBuilder.html b/arrow/array/struct.BooleanBufferBuilder.html
index f8af82c08..6d147a659 100644
--- a/arrow/array/struct.BooleanBufferBuilder.html
+++ b/arrow/array/struct.BooleanBufferBuilder.html
@@ -31,7 +31,7 @@ growing it (potentially reallocating it) and writing <code>false</code> in the n
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#212">source</a><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;mut [u8]">ⓘ</a> [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#218">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock"><p>Creates a <a  [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#225">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../buffer/struct.BooleanBuffer.html" title="struct arrow::buffer::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class="docblock" [...]
-</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-Debug-for-BooleanBufferBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anchor" [...]
+</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-Debug-for-BooleanBufferBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anchor" [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/array/struct.DictionaryArray.html b/arrow/array/struct.DictionaryArray.html
index ce8c71754..d4414632e 100644
--- a/arrow/array/struct.DictionaryArray.html
+++ b/arrow/array/struct.DictionaryArray.html
@@ -178,10 +178,10 @@ When using this function on a slice, the index is relative to the slice. <a href
     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.clone" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#260">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header"> [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</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="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#744">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn < [...]
     T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#580">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::arra [...]
-    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="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#628">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#580">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow:: [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowDictionaryKeyType.html" title="trait arrow::datatypes::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,</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="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#628">source</a><a href="#method.from" 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-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>];
@@ -190,10 +190,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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#681">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="stru [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#681">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=" [...]
     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-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>];
@@ -205,7 +205,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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#657">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=" [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#657">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="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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#408">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https:/ [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" cl [...]
diff --git a/arrow/array/struct.FixedSizeBinaryArray.html b/arrow/array/struct.FixedSizeBinaryArray.html
index fd28ab9ab..abde30781 100644
--- a/arrow/array/struct.FixedSizeBinaryArray.html
+++ b/arrow/array/struct.FixedSizeBinaryArray.html
@@ -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-2" class="method trait-impl"><a class="srclink 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="s [...]
+) -&gt; &lt;&amp;'a <a class="struct" href="struct.FixedSizeBinaryArray.html" title="struct arrow::array::FixedSizeBinaryArray">FixedSizeBinaryArray</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow::array::ArrayAccessor::Item">Item</a></h4></section></summary><div class='docblock'>Returns the element at index <code>i</code [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="srclink 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="s [...]
 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="srclink" 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" 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-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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow/array/struct.FixedSizeListArray.html b/arrow/array/struct.FixedSizeListArray.html
index b3e05db84..c603531d9 100644
--- a/arrow/array/struct.FixedSizeListArray.html
+++ b/arrow/array/struct.FixedSizeListArray.html
@@ -89,10 +89,10 @@ 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.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="ht [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209">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 [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">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>( [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>( [...]
     &amp;self,
     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 [...]
diff --git a/arrow/array/struct.GenericByteArray.html b/arrow/array/struct.GenericByteArray.html
index 09aa0204e..d7505865b 100644
--- a/arrow/array/struct.GenericByteArray.html
+++ b/arrow/array/struct.GenericByteArray.html
@@ -152,32 +152,32 @@ 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="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#95">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
     T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</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="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#380">source</a><a href="#method.fmt" 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.from" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#453">source</a><a href="#method.from" 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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#119">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</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="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#453">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#119">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="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="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#165">source</a><a href="#method.from-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#165">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
     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-10" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#483">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#111">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    T: <a class="trait" href="../datatypes/trait.ByteArrayType.html" title="trait arrow::datatypes::ByteArrayType">ByteArrayType</a>,</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="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#483">source</a><a href="#method.from" 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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#111">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="struct.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-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#157">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ni [...]
+    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="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#157">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ni [...]
     OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#151">source</a><a href="#method.from-7" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="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-11" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#133">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
-    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#145">source</a><a href="#method.from-5" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#133">source</a><a href="#method.from-8" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#145">source</a><a href="#method.from-10" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
     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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#127">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#127">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&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-6" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#141">source</a><a href="#method.from-6" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>&gt;, <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-9" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#147">source</a><a href="#method.from-9" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#147">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="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>,
diff --git a/arrow/array/struct.GenericListArray.html b/arrow/array/struct.GenericListArray.html
index 907d33e0b..75896643a 100644
--- a/arrow/array/struct.GenericListArray.html
+++ b/arrow/array/struct.GenericListArray.html
@@ -87,13 +87,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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#70">source</a><a href="#method.clone" 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.fmt" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#466">source</a><a href="#method.fmt" 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-3" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#309">source</a><a href="#method.from-3" 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-5" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#332">source</a><a href="#method.from-5" 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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#317">source</a><a href="#method.from-1" 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-4" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#111">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
+    OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#309">source</a><a href="#method.from-1" 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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#332">source</a><a href="#method.from" 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="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#317">source</a><a href="#method.from-3" 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-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.html#111">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-la [...]
     v: <a class="struct" href="struct.GenericListArray.html" title="struct arrow::array::GenericListArray">GenericListArray</a>&lt;OffsetSize&gt;
 ) -&gt; <a class="struct" href="struct.GenericByteArray.html" title="struct arrow::array::GenericByteArray">GenericByteArray</a>&lt;<a class="struct" href="../datatypes/struct.GenericStringType.html" title="struct arrow::datatypes::GenericStringType">GenericStringType</a>&lt;OffsetSize&gt;&gt;</h4></section></summary><div class='docblock'>Converts to this type from the input type.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="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-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#157">source</a><a href="#method.from-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ni [...]
+    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-4" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.html#157">source</a><a href="#method.from-4" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/ni [...]
     OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow::array::OffsetSizeTrait">OffsetSizeTrait</a>,</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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#438">source</a><a href="#method.eq" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/co [...]
 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="srclink" 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" 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-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.MapArray.html b/arrow/array/struct.MapArray.html
index 8737ca234..f9caed3e1 100644
--- a/arrow/array/struct.MapArray.html
+++ b/arrow/array/struct.MapArray.html
@@ -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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>( [...]
     &amp;self,
     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="srclink" 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" 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-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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow/array/struct.NativeAdapter.html b/arrow/array/struct.NativeAdapter.html
index 533911cf9..5395fcddf 100644
--- a/arrow/array/struct.NativeAdapter.html
+++ b/arrow/array/struct.NativeAdapter.html
@@ -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="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1144">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-hea [...]
     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-11" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1187">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a hr [...]
-    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="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1179">source</a><a href="#method.from" 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-4" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1187">source</a><a href="#method.from-4" 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-12" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1179">source</a><a href="#method.from-12" class="anchor">§</a><h4 class="code-header">fn <a hr [...]
     &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 c0e69225d..9b53b8e0c 100644
--- a/arrow/array/struct.NullArray.html
+++ b/arrow/array/struct.NullArray.html
@@ -26,7 +26,7 @@ Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#106">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc. [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#132">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="fn">g [...]
 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></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-NullArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#42">source</a><a href="#impl-Clone-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.C [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-NullArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#42">source</a><a href="#impl-Clone-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.C [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" 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-NullArray" class="impl"><a href="#impl-RefUnwindSafe-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-la [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow/array/struct.PrimitiveArray.html b/arrow/array/struct.PrimitiveArray.html
index c4e34366d..fec9e31ed 100644
--- a/arrow/array/struct.PrimitiveArray.html
+++ b/arrow/array/struct.PrimitiveArray.html
@@ -249,126 +249,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="srclink 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="h [...]
     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="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1070">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="http [...]
     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-49" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1369">source</a><a href="#method.from-49" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow [...]
-    T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-61" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#954">source</a><a href="#method.from-61" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-56" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1369">source</a><a href="#method.from-56" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: <a class="struct" href="struct.ArrayData.html" title="struct arrow [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowPrimitiveType.html" title="trait arrow::datatypes::ArrowPrimitiveType">ArrowPrimitiveType</a>,</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="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#954">source</a><a href="#method.from-11" class="anchor">§</a><h4 class="code-header">fn <a hre [...]
     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.RunArray.html b/arrow/array/struct.RunArray.html
index 76357b55b..c68c0fe9a 100644
--- a/arrow/array/struct.RunArray.html
+++ b/arrow/array/struct.RunArray.html
@@ -81,8 +81,8 @@ 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">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>( [...]
     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.clone" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#71">source</a><a href="#method.clone" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust- [...]
     R: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</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="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#364">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lan [...]
-    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="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#269">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-l [...]
-    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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#296">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
+    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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#269">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
+    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="srclink 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-l [...]
     T: <a class="trait" href="../datatypes/trait.RunEndIndexType.html" title="trait arrow::datatypes::RunEndIndexType">RunEndIndexType</a>,</span></h3></section></summary><div class="docblock"><p>Constructs a <code>RunArray</code> from an iterator of strings.</p>
 <h4 id="example"><a href="#example">Example:</a></h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{RunArray, PrimitiveArray, StringArray, types::Int16Type};
diff --git a/arrow/array/struct.StructArray.html b/arrow/array/struct.StructArray.html
index 839e5ffe4..fdd9ea4d7 100644
--- a/arrow/array/struct.StructArray.html
+++ b/arrow/array/struct.StructArray.html
@@ -95,9 +95,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.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href="ht [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209">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 [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">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>( [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225">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>( [...]
     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>&gt;, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::A [...]
-) -&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="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#280">source</a><a href="#impl-From%3CArrayData%3 [...]
+) -&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="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#280">source</a><a href="#impl-From%3CArrayData%3 [...]
 <p>Note: A schema can currently have duplicate field names, in which case
 the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
diff --git a/arrow/array/struct.UnionArray.html b/arrow/array/struct.UnionArray.html
index 445050c4a..eca489f8e 100644
--- a/arrow/array/struct.UnionArray.html
+++ b/arrow/array/struct.UnionArray.html
@@ -133,7 +133,7 @@ Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#417">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#451">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="fn"> [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-UnionArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#109">source</a><a href="#impl-Clone-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/tra [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-UnionArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#109">source</a><a href="#impl-Clone-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/tra [...]
     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-1" class="method trait-impl"><a class="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id-1" class="anchor">§</a><h4 class="code-header">f [...]
     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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/buffer/struct.BooleanBuffer.html b/arrow/buffer/struct.BooleanBuffer.html
index 07b99e23e..3c7db831d 100644
--- a/arrow/buffer/struct.BooleanBuffer.html
+++ b/arrow/buffer/struct.BooleanBuffer.html
@@ -46,7 +46,7 @@ return false when the arrays are logically equal</p>
 ) -&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. [...]
+) -&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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-BooleanBuffer" class="impl"><a class="srclink 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.BooleanBu [...]
diff --git a/arrow/buffer/struct.Buffer.html b/arrow/buffer/struct.Buffer.html
index c100ca897..27c681878 100644
--- a/arrow/buffer/struct.Buffer.html
+++ b/arrow/buffer/struct.Buffer.html
@@ -1157,8 +1157,8 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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="srclink 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 [...]
-    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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#120">source</a><a href="#method.from" 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="srclink 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 [...]
+    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="srclink 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.rus [...]
     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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/immutable.rs.html#331">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>(p: T) -&gt; <a class="struct" href="struct.Buffer.html" title="struct arrow::bu [...]
diff --git a/arrow/buffer/struct.MutableBuffer.html b/arrow/buffer/struct.MutableBuffer.html
index 71cb2c46d..101290f99 100644
--- a/arrow/buffer/struct.MutableBuffer.html
+++ b/arrow/buffer/struct.MutableBuffer.html
@@ -2484,8 +2484,8 @@ but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
 </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-Debug-for-MutableBuffer" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#53">source</a><a href="#impl-Debug-for-MutableBuffer" class="anchor">§</a><h3 class="code-header">i [...]
     A: <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.extend" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#492">source</a><a href="#method.extend" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.ru [...]
-    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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#114">source</a><a href="#method.from" 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/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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#114">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rus [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#708-710">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html#tymethod.from_iter" class="fn">from_iter</a>&lt;I&gt;(iter: I) -&gt; <a class="struct" [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="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="srclink" 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" cl [...]
diff --git a/arrow/buffer/struct.ScalarBuffer.html b/arrow/buffer/struct.ScalarBuffer.html
index 879f013ae..32f8e1bd4 100644
--- a/arrow/buffer/struct.ScalarBuffer.html
+++ b/arrow/buffer/struct.ScalarBuffer.html
@@ -1093,9 +1093,9 @@ but non-ASCII letters are unchanged.</p>
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html" title="trait core::clone::Clone">Clone</a> + <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.clone" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buf [...]
     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.fmt" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#52">source</a><a href="#method.fmt" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang. [...]
     T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Target" class="associatedtype trait-impl"><a href="#associatedtype.Target" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html#associatedtype.Target" class="as [...]
-    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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#120">source</a><a href="#method.from" 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-2" class="method trait-impl"><a class="srclink 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.rus [...]
-    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="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#141">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rus [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</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="srclink 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.rus [...]
+    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="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#114">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rus [...]
+    T: <a class="trait" href="../datatypes/trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType">ArrowNativeType</a>,</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="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#141">source</a><a href="#method.from" 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_iter" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#150">source</a><a href="#method.from_iter" class="anchor">§</a><h4 class="code-header">fn <a href="https://d [...]
     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 [...]
diff --git a/arrow/datatypes/enum.DataType.html b/arrow/datatypes/enum.DataType.html
index d9754b99a..9f78222ce 100644
--- a/arrow/datatypes/enum.DataType.html
+++ b/arrow/datatypes/enum.DataType.html
@@ -238,8 +238,8 @@ operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.h
     __serializer: __S
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;&lt;__S as <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>&gt;::<a class="associatedtype" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html#associatedtype.Ok" title="type serde::ser::Serializer::Ok">Ok</a>, &lt;__S as <a class="trait" href="h [...]
     __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ToPyArrow-for-DataType" cl [...]
-</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-2" class="associatedtype trait-impl"><a href="#associatedtype.Error-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
+</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'>The  [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/datatypes/struct.Field.html b/arrow/datatypes/struct.Field.html
index d648d11bc..d8fe478e2 100644
--- a/arrow/datatypes/struct.Field.html
+++ b/arrow/datatypes/struct.Field.html
@@ -157,7 +157,7 @@ operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.h
     &amp;self,
     __serializer: __S
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;&lt;__S as <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>&gt;::<a class="associatedtype" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html#associatedtype.Ok" title="type serde::ser::Serializer::Ok">Ok</a>, &lt;__S as <a class="trait" href="h [...]
-    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ToPyArrow-for-Field" class [...]
+    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ToPyArrow-for-Field" class [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/datatypes/struct.Fields.html b/arrow/datatypes/struct.Fields.html
index 07505d0e8..c043f693c 100644
--- a/arrow/datatypes/struct.Fields.html
+++ b/arrow/datatypes/struct.Fields.html
@@ -1078,8 +1078,8 @@ but non-ASCII letters are unchanged.</p>
 </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-Fields" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/fields.rs.html#41">source</a><a href="#impl-Clone-for-Fields" class="anchor">§</a><h3 class="code-header">impl <a class="trait" h [...]
     __deserializer: __D
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.Fields.html" title="struct arrow::datatypes::Fields">Fields</a>, &lt;__D as <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;&gt;::<a class="associatedtype" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserial [...]
-    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
-    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="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="struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;&gt;,</span></h4></section></summary><div class='docblock'>Creates a va [...]
+    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+    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="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="struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;&gt;,</span></h4></section></summary><div class='docblock'>Creates a va [...]
     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="struct" href="struct.Field.html" title="struct arrow::datatypes::Field">Field</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_iter" [...]
     __H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,</span></h4></section></summary><div class='docblock'>Feeds this value into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#tymethod.hash">Read more</a></div></details><details class="toggle m [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
diff --git a/arrow/datatypes/struct.Schema.html b/arrow/datatypes/struct.Schema.html
index 12785d590..23d641edd 100644
--- a/arrow/datatypes/struct.Schema.html
+++ b/arrow/datatypes/struct.Schema.html
@@ -85,7 +85,7 @@ sufficient, and should not be overridden without very good reason.</div></detail
     &amp;self,
     __serializer: __S
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;&lt;__S as <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>&gt;::<a class="associatedtype" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html#associatedtype.Ok" title="type serde::ser::Serializer::Ok">Ok</a>, &lt;__S as <a class="trait" href="h [...]
-    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ToPyArrow-for-Schema" clas [...]
+    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ToPyArrow-for-Schema" clas [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/datatypes/struct.SchemaBuilder.html b/arrow/datatypes/struct.SchemaBuilder.html
index e5ed4a7a1..f91ba1649 100644
--- a/arrow/datatypes/struct.SchemaBuilder.html
+++ b/arrow/datatypes/struct.SchemaBuilder.html
@@ -9,7 +9,7 @@
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#73">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(self) -&gt; <a class="struct" href="struct.Schema.html" title="struct arrow::datatypes::Schema">Schema</a></h4></section></summary><div class="docblock"><p>Consume this <a href="struct.SchemaBuilder.html" title="stru [...]
 </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-Debug-for-SchemaBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#28">source</a><a href="#impl-Debug-for-SchemaBuilder" class="anchor">§</a><h3 class="code-h [...]
     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="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="struct.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;&gt;,</span></h4></section></summary><div class='docblock'>Extends a co [...]
-    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="struct" href="struct.Field.html" title="struct arrow::datatypes::Field">Field</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#tyme [...]
+    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="struct" href="struct.Field.html" title="struct arrow::datatypes::Field">Field</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#tyme [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/datatypes/struct.i256.html b/arrow/datatypes/struct.i256.html
index bd07280b1..1917fe13d 100644
--- a/arrow/datatypes/struct.i256.html
+++ b/arrow/datatypes/struct.i256.html
@@ -41,17 +41,17 @@ in truncation/overflow</p>
 -1 if the number is negative</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_negative" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#594">source</a><h4 class="code-header">pub const fn <a href="#method.is_negative" class="fn">is_negative</a>(self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if this <a h [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_positive" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#599">source</a><h4 class="code-header">pub const fn <a href="#method.is_positive" class="fn">is_positive</a>(self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if this <a h [...]
-</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-Add%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#677">source</a><a href="#impl-Add%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-he [...]
+</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-Add%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#677">source</a><a href="#impl-Add%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-he [...]
     __H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,</span></h4></section></summary><div class='docblock'>Feeds this value into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#tymethod.hash">Read more</a></div></details><details class="toggle m [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
-    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
+    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the minimum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.min">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.clamp" class="method trait-impl"><span class="rightside"><span class= [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">PartialOrd</a>&lt;Self&gt;,</span></h4></section></summary><div class='docblock'>Restrict a value to a certain interval. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.clamp">Read more</a></div></d [...]
 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="srclink" 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" 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-PartialOrd%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#155">source</a><a href="#impl-PartialOrd%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" ti [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Rem%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#681">source</a><a href="#impl-Rem%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/o [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Rem%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#681">source</a><a href="#impl-Rem%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/o [...]
 represented by an <code>i64</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_u64" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#817">source</a><a href="#method.to_u64" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#tymethod.to_u64" class="fn">to_u64</a>(&amp;self) -&gt; <a c [...]
 represented by a <code>u64</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_isize-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/num-traits/0.2/src/num_traits/cast.rs.html#23">source</a><a href="#method.to_isize-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#method.to_isize" class="fn">to_is [...]
 represented by an <code>isize</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_i8" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/num-traits/0.2/src/num_traits/cast.rs.html#30">source</a><a href="#method.to_i8" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#method.to_i8" class="fn">to_i8</a>(&amp; [...]
diff --git a/arrow/datatypes/trait.ArrowNativeType.html b/arrow/datatypes/trait.ArrowNativeType.html
index fa9d1a174..27917e39d 100644
--- a/arrow/datatypes/trait.ArrowNativeType.html
+++ b/arrow/datatypes/trait.ArrowNativeType.html
@@ -42,4 +42,4 @@ in truncation/overflow</p>
 <p>Returns <code>None</code> if <a href="trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType"><code>Self</code></a> is not <code>i64</code></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.from_i128" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/native.rs.html#98">source</a><h4 class="code-header">fn <a href="#method.from_i128" class="fn">from_i128</a>(_: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::op [...]
 <p>Returns <code>None</code> if <a href="trait.ArrowNativeType.html" title="trait arrow::datatypes::ArrowNativeType"><code>Self</code></a> is not <code>i128</code></p>
-</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-ArrowNativeType-for-f32" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/native.rs.html#186">source</a><a href="#impl-ArrowNativeType-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeType.html" [...]
\ No newline at end of file
+</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-ArrowNativeType-for-f64" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/native.rs.html#187">source</a><a href="#impl-ArrowNativeType-for-f64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeType.html" [...]
\ No newline at end of file
diff --git a/arrow/datatypes/trait.ArrowNativeTypeOp.html b/arrow/datatypes/trait.ArrowNativeTypeOp.html
index c4ba2cde7..1070f7140 100644
--- a/arrow/datatypes/trait.ArrowNativeTypeOp.html
+++ b/arrow/datatypes/trait.ArrowNativeTypeOp.html
@@ -63,4 +63,4 @@ point values are compared as per IEEE 754’s totalOrder predicate see <a href="
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_le" class="method"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#113">source</a><h4 class="code-header">fn <a href="#method.is_le" class="fn">is_le</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Less than equals operation</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_gt" class="method"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#119">source</a><h4 class="code-header">fn <a href="#method.is_gt" class="fn">is_gt</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Greater than operation</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_ge" class="method"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#125">source</a><h4 class="code-header">fn <a href="#method.is_ge" class="fn">is_ge</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Greater than equals operation</p>
-</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-ArrowNativeTypeOp-for-f32" class="impl"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#381">source</a><a href="#impl-ArrowNativeTypeOp-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeTyp [...]
\ No newline at end of file
+</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-ArrowNativeTypeOp-for-u16" class="impl"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#270">source</a><a href="#impl-ArrowNativeTypeOp-for-u16" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeTyp [...]
\ No newline at end of file
diff --git a/arrow/error/enum.ArrowError.html b/arrow/error/enum.ArrowError.html
index 971c53053..a86b55913 100644
--- a/arrow/error/enum.ArrowError.html
+++ b/arrow/error/enum.ArrowError.html
@@ -21,8 +21,8 @@
 </div><section id="variant.DictionaryKeyOverflowError" class="variant"><a href="#variant.DictionaryKeyOverflowError" class="anchor">§</a><h3 class="code-header">DictionaryKeyOverflowError</h3></section><section id="variant.RunEndIndexOverflowError" class="variant"><a href="#variant.RunEndIndexOverflowError" class="anchor">§</a><h3 class="code-header">RunEndIndexOverflowError</h3></section></div><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations [...]
     error: <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/error/trait.Error.html" title="trait core::error::Error">Error</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" [...]
 ) -&gt; <a class="enum" href="enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class="docblock"><p>Wraps an external error in an <code>ArrowError</code>.</p>
-</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-Debug-for-ArrowError" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/error.rs.html#25">source</a><a href="#impl-Debug-for-ArrowError" class="anchor">§</a><h3 class="code-header"> [...]
-    W: <a class="trait" href="https://doc.rust-lang.org/nightly/std/io/trait.Write.html" title="trait std::io::Write">Write</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="srclink rightside" href="../../src/arrow_schema/error.rs.html#67">source</a><a href="#method.from" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/ [...]
+</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-Debug-for-ArrowError" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/error.rs.html#25">source</a><a href="#impl-Debug-for-ArrowError" class="anchor">§</a><h3 class="code-header"> [...]
+    W: <a class="trait" href="https://doc.rust-lang.org/nightly/std/io/trait.Write.html" title="trait std::io::Write">Write</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="srclink rightside" href="../../src/arrow_schema/error.rs.html#67">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/c [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/ffi/struct.FFI_ArrowSchema.html b/arrow/ffi/struct.FFI_ArrowSchema.html
index 585aaaa99..4d546d764 100644
--- a/arrow/ffi/struct.FFI_ArrowSchema.html
+++ b/arrow/ffi/struct.FFI_ArrowSchema.html
@@ -29,11 +29,11 @@ See <a href="https://arrow.apache.org/docs/format/CDataInterface.html#structure-
 </div></details><details class="toggle method-toggle" open><summary><section id="method.name" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#249">source</a><h4 class="code-header">pub fn <a href="#method.name" class="fn">name</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section></summary><div class="docblock"><p>returns the name of this schema.</p>
 </div></details><section id="method.flags" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#257">source</a><h4 class="code-header">pub fn <a href="#method.flags" class="fn">flags</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;<a class="struct" href="struct.Flags.html" title="struct arrow::ffi::Flags">Flags</a>&gt;</h4></section><section id="metho [...]
     &amp;self
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="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="https://doc.rus [...]
+) -&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/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="https://doc.rus [...]
     value: &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.Field.html" title="struct arrow::datatypes::Field">Field</a>&gt;
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a>, &lt;<a class="struct" href="struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::c [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-4" class="associatedtype trait-impl"><a href="#associatedtype.Error-4" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-9" class="associatedtype trait-impl"><a href="#associatedtype.Error-9" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a>, &lt;<a class="struct" href="struct.FFI_ArrowSchema.html" title="struct arrow::ffi::FFI_ArrowSchema">FFI_ArrowSchema</a> as <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html" title="trait core::c [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Error-6" class="associatedtype trait-impl"><a href="#associatedtype.Error-6" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
+</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
     T: '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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/index.html b/arrow/index.html
index 9aac5db9f..6f344d53f 100644
--- a/arrow/index.html
+++ b/arrow/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="A complete, safe, native Rust implementation of Apache Arrow, a cross-language development platform for in-memory data."><title>arrow - 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 complete, safe, native Rust implementation of Apache Arrow, a cross-language development platform for in-memory data."><title>arrow - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel [...]
 development platform for in-memory data.</p>
 <p>Please see the <a href="https://crates.io/crates/arrow">arrow crates.io</a>
 page for feature flags and tips to improve performance.</p>
diff --git a/arrow/pyarrow/struct.ArrowException.html b/arrow/pyarrow/struct.ArrowException.html
index 3dd3f033e..d8703c8c0 100644
--- a/arrow/pyarrow/struct.ArrowException.html
+++ b/arrow/pyarrow/struct.ArrowException.html
@@ -381,7 +381,7 @@ if the type <code>T</code> is known at compile time.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.py_super" class="method"><h4 class="code-header">pub fn <a href="#method.py_super" class="fn">py_super</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;&amp;PySuper, PyErr&gt;</h4></section></summary><div class="docblock"><p>Return a proxy object that delegates method calls to a parent or sibling  [...]
 <p>This is equivalent to the Python expression <code>super()</code></p>
 </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-AsPyPointer-for-ArrowException" class="impl"><a class="srclink rightside" href="../../src/arrow/pyarrow.rs.html#43">source</a><a href="#impl-AsPyPointer-for-ArrowException" class="anchor">§</a><h3 class="code-header">i [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-AsRef%3CPyAny%3E-for-ArrowException" class="impl"><a class="srclink rightside" href="../../src/arrow/pyarrow.rs.html#43">source</a><a href="#impl-AsRef%3CPyAny%3E-for-ArrowException" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;PyAny&gt; for <a [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-AsRef%3CPyAny%3E-for-ArrowException" class="impl"><a class="srclink rightside" href="../../src/arrow/pyarrow.rs.html#43">source</a><a href="#impl-AsRef%3CPyAny%3E-for-ArrowException" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;PyAny&gt; for <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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow/record_batch/struct.RecordBatch.html b/arrow/record_batch/struct.RecordBatch.html
index 6267ef016..7d347d9b6 100644
--- a/arrow/record_batch/struct.RecordBatch.html
+++ b/arrow/record_batch/struct.RecordBatch.html
@@ -119,7 +119,7 @@ testing.</p>
   (<span class="string">&quot;b&quot;</span>, b, <span class="bool-val">true</span>),
 ]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method"><a class="srclink rightside" href="../../src/arrow_array/record_batch.rs.html#434">source</a><h4 class="code-header">pub fn <a href="#method.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Re [...]
-</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-RecordBatch" class="impl"><a class="srclink rightside" href="../../src/arrow_array/record_batch.rs.html#65">source</a><a href="#impl-Clone-for-RecordBatch" class="anchor">§</a><h3 class="code- [...]
+</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-RecordBatch" class="impl"><a class="srclink rightside" href="../../src/arrow_array/record_batch.rs.html#65">source</a><a href="#impl-Clone-for-RecordBatch" class="anchor">§</a><h3 class="code- [...]
 <h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
 <p>Panics if the name is not in the schema.</p>
 </div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/index/trait.Index.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" hr [...]
diff --git a/arrow_arith/index.html b/arrow_arith/index.html
index b50048344..61b009265 100644
--- a/arrow_arith/index.html
+++ b/arrow_arith/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="Arrow arithmetic and aggregation kernels"><title>arrow_arith - Rust</title><link rel="preload" 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="Arrow arithmetic and aggregation kernels"><title>arrow_arith - Rust</title><link rel="preload" 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/ [...]
 </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="aggregate/index.html" title="mod arrow_arith::aggregate">aggregate</a></div><div class="desc docblock-short">Defines aggregations over Arrow arrays.</div></li><li><div class="item-name"><a class="mod" href="arithmetic/index.html" title="mod arrow_arith::arithmetic">arithmetic</a></div><div class="desc docblock-short">Defin [...]
\ No newline at end of file
diff --git a/arrow_array/arithmetic/trait.ArrowNativeTypeOp.html b/arrow_array/arithmetic/trait.ArrowNativeTypeOp.html
index c2a6252ee..d63cf0e9d 100644
--- a/arrow_array/arithmetic/trait.ArrowNativeTypeOp.html
+++ b/arrow_array/arithmetic/trait.ArrowNativeTypeOp.html
@@ -63,4 +63,4 @@ point values are compared as per IEEE 754’s totalOrder predicate see <a href="
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_le" class="method"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#113-115">source</a><h4 class="code-header">fn <a href="#method.is_le" class="fn">is_le</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Less than equals operation</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_gt" class="method"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#119-121">source</a><h4 class="code-header">fn <a href="#method.is_gt" class="fn">is_gt</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Greater than operation</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_ge" class="method"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#125-127">source</a><h4 class="code-header">fn <a href="#method.is_ge" class="fn">is_ge</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Greater than equals operation</p>
-</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-ArrowNativeTypeOp-for-f32" class="impl"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#381">source</a><a href="#impl-ArrowNativeTypeOp-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeTyp [...]
\ No newline at end of file
+</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-ArrowNativeTypeOp-for-u16" class="impl"><a class="srclink rightside" href="../../src/arrow_array/arithmetic.rs.html#270">source</a><a href="#impl-ArrowNativeTypeOp-for-u16" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeTyp [...]
\ No newline at end of file
diff --git a/arrow_array/array/binary_array/type.GenericBinaryArray.html b/arrow_array/array/binary_array/type.GenericBinaryArray.html
index 68bf0972a..aca4a6734 100644
--- a/arrow_array/array/binary_array/type.GenericBinaryArray.html
+++ b/arrow_array/array/binary_array/type.GenericBinaryArray.html
@@ -16,6 +16,6 @@
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Retur [...]
 <h5 id="safety"><a href="#safety">Safety</a></h5>
 <p>caller must ensure that the indexes in the iterator are less than the <code>array.len()</code></p>
-</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-From%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericBinaryArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/binary_array.rs.h [...]
+</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-From%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericBinaryArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/binary_array.rs.h [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_array/array/boolean_array/struct.BooleanArray.html b/arrow_array/array/boolean_array/struct.BooleanArray.html
index d9ce8a0f0..3d0b0e3f6 100644
--- a/arrow_array/array/boolean_array/struct.BooleanArray.html
+++ b/arrow_array/array/boolean_array/struct.BooleanArray.html
@@ -70,14 +70,14 @@ each element of the provided arrays</p>
 <p>This function panics if left and right are not the same length</p>
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BooleanArray-1" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#384-389">source</a><a href="#impl-BooleanArray-1" class="anchor">§</a><h3 class="code-header">impl&lt;'a&gt; <a class="struct" href="struct.BooleanArray.html" title="struct arrow_array::array::boolean_array::BooleanArray">BooleanArray</a></h3></section></summary><div [...]
 </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-Array-for-BooleanArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#251-299">source</a><a href="#impl-Array-for-BooleanArray" class="anchor">§</a [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#256-258">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#256-258">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; Ar [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#284-286">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" hr [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/boolean_array.rs.html#296-298">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
 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="srclink" 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" 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-BooleanArray" class="impl"><a href="#impl-RefUnwindSafe-for-BooleanArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.r [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/byte_array/struct.GenericByteArray.html b/arrow_array/array/byte_array/struct.GenericByteArray.html
index 9f3aeae27..4e9bbcc39 100644
--- a/arrow_array/array/byte_array/struct.GenericByteArray.html
+++ b/arrow_array/array/byte_array/struct.GenericByteArray.html
@@ -120,16 +120,16 @@ please use the function <a href="#method.value_length"><code>value_length</code>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self, ArrowError&gt;</h4></section></summary><div class="docblock"><p>Fallibly creates a <a href="../string_array/type.GenericStringArray.html" title="type arrow_array::array::string_array::GenericStringArray"><code>GenericStringArray</code></a> from a <a href="../binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_arr [...]
 an error if <a href="../binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinaryArray"><code>GenericBinaryArray</code></a> contains invalid UTF-8 data</p>
 </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-Array-for-GenericByteArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/byte_array.rs.html#389-438">source</a><a href="#impl-Array-for-GenericByteArray%3CT%3E"  [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/byte_array.rs.html#394-396">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a cl [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/byte_array.rs.html#394-396">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; Array [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/byte_array.rs.html#422-424">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href= [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/byte_array.rs.html#435-437">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" cl [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
     Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;T::<a class="associatedtype" href="../../types/trait.ByteArrayType.html#associatedtype.Native" title="type arrow_array::types::ByteArrayType::Native">Native</a>&gt; + '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=" [...]
-    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;T::<a class="associatedtype" href="../../types/trait.ByteArrayType.html#associatedtype.Native" title="type arrow_array::types::ByteArrayType::Native">Native</a>&gt;,</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="srclink [...]
+    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;T::<a class="associatedtype" href="../../types/trait.ByteArrayType.html#associatedtype.Native" title="type arrow_array::types::ByteArrayType::Native">Native</a>&gt;,</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="srclink [...]
 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="srclink" 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" 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%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericStringArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#419-423">source</a><a href="#impl-PartialEq%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-Generic [...]
 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="srclink" 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 [...]
diff --git a/arrow_array/array/dictionary_array/struct.DictionaryArray.html b/arrow_array/array/dictionary_array/struct.DictionaryArray.html
index b123c9aa6..61948b819 100644
--- a/arrow_array/array/dictionary_array/struct.DictionaryArray.html
+++ b/arrow_array/array/dictionary_array/struct.DictionaryArray.html
@@ -162,16 +162,16 @@ or this function may panic.</p>
 <p>For each value in <a href="struct.DictionaryArray.html#method.values" title="method arrow_array::array::dictionary_array::DictionaryArray::values"><code>Self::values</code></a> the corresponding bit will be set in the
 returned mask if it is referenced by a key in this <a href="struct.DictionaryArray.html" title="struct arrow_array::array::dictionary_array::DictionaryArray"><code>DictionaryArray</code></a></p>
 </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-Array-for-DictionaryArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#695-741">source</a><a href="#impl-Array-for-DictionaryArray%3CT% [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#700-702">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#700-702">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#728-730">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#736-740">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_si [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#580-624">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="../../../arrow_data/data/struct.ArrayData [...]
-<h4 id="example-1"><a href="#example-1">Example:</a></h4>
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#580-624">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: ArrayData) -&gt; Self</h4></section></summary><div class='doc [...]
+<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>];
@@ -180,8 +180,8 @@ 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" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#681-692">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: <a class="trait" href="ht [...]
-<h4 id="example-2"><a href="#example-2">Example:</a></h4>
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#681-692">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: <a class="trait" href [...]
+<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>];
@@ -193,7 +193,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-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#657-663">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: <a class="trait" href [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#657-663">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: <a class="trait" href="ht [...]
 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="srclink" 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" 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-DictionaryArray%3CK%3E" class="impl"><a href="#impl-RefUnwindSafe-for-DictionaryArray%3CK%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K&gt; !<a cla [...]
     &lt;K as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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 i [...]
diff --git a/arrow_array/array/dictionary_array/struct.TypedDictionaryArray.html b/arrow_array/array/dictionary_array/struct.TypedDictionaryArray.html
index d3e09285e..d968790aa 100644
--- a/arrow_array/array/dictionary_array/struct.TypedDictionaryArray.html
+++ b/arrow_array/array/dictionary_array/struct.TypedDictionaryArray.html
@@ -20,7 +20,7 @@
 </div><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#797-807">source</a><a href="#impl-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#804-806">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of  [...]
 </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-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#809-853">source</a><a href="#impl-Array-for-TypedDic [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#814-816">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#814-816">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#842-844">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/dictionary_array.rs.html#850-852">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_si [...]
@@ -31,9 +31,9 @@ When using this function on a slice, the index is relative to the slice. <a href
     K: <a class="trait" href="../../types/trait.ArrowDictionaryKeyType.html" title="trait arrow_array::types::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core:: [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core:: [...]
     K: <a class="trait" href="../../types/trait.ArrowDictionaryKeyType.html" title="trait arrow_array::types::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    Self: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</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" class="as [...]
+    Self: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</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" class [...]
     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-Sync-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Sync-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> for <a [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</span></h3></section><section id="impl-Unpin-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Unpin-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a> f [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/fixed_size_binary_array/struct.FixedSizeBinaryArray.html b/arrow_array/array/fixed_size_binary_array/struct.FixedSizeBinaryArray.html
index 2770a8390..243db4b4b 100644
--- a/arrow_array/array/fixed_size_binary_array/struct.FixedSizeBinaryArray.html
+++ b/arrow_array/array/fixed_size_binary_array/struct.FixedSizeBinaryArray.html
@@ -111,15 +111,15 @@ created.</p>
 <p>Returns error if argument has length zero, or sizes of nested slices don’t match.</p>
 </div></details><section id="method.value_offset_at" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#450-452">source</a><h4 class="code-header">fn <a href="#method.value_offset_at" class="fn">value_offset_at</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4> [...]
 </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-Array-for-FixedSizeBinaryArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#561-609">source</a><a href="#impl-Array-for-FixedSizeBinary [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#566-568">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#566-568">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#594-596">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#606-608">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_me [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#499-535">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="../fixed_size_list_array/struct.F [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#499-535">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="../fixed_size_list_array/struct.F [...]
 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="srclink" 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" 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-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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/fixed_size_list_array/struct.FixedSizeListArray.html b/arrow_array/array/fixed_size_list_array/struct.FixedSizeListArray.html
index 804049bc8..6543ac388 100644
--- a/arrow_array/array/fixed_size_list_array/struct.FixedSizeListArray.html
+++ b/arrow_array/array/fixed_size_list_array/struct.FixedSizeListArray.html
@@ -82,14 +82,14 @@
 <span class="macro">println!</span>(<span class="string">&quot;{:?}&quot;</span>, list_array);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#283-285">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="type" href="../../iterator/type.FixedSizeListIter.html" title="type arrow_array::iterator::FixedSizeListIter">FixedSizeListIter</a>&lt;'_&gt;</h4></section></summary>< [...]
 </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-Array-for-FixedSizeListArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#322-374">source</a><a href="#impl-Array-for-FixedSizeListArray" [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#327-329">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self)  [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#327-329">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self)  [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#355-357">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class=" [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_list_array.rs.html#367-373">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memo [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/fixed_size_binary_array.rs.html#499-535">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" t [...]
 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="srclink" 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" 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-FixedSizeListArray" class="impl"><a href="#impl-RefUnwindSafe-for-FixedSizeListArray" class="anchor">§</a><h3 class="code-header">impl !<a class="trait" href=" [...]
diff --git a/arrow_array/array/fn.get_offsets.html b/arrow_array/array/fn.get_offsets.html
index 32dc6e537..e6b688595 100644
--- a/arrow_array/array/fn.get_offsets.html
+++ b/arrow_array/array/fn.get_offsets.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Helper function that gets offset from an `ArrayData`"><title>get_offsets in arrow_array::array - Rust</title><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="Helper function that gets offset from an `ArrayData`"><title>get_offsets in arrow_array::array - Rust</title><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 [...]
 <h2 id="safety"><a href="#safety">Safety</a></h2>
 <ul>
 <li>ArrayData must contain a valid [<code>OffsetBuffer</code>] as its first buffer</li>
diff --git a/arrow_array/array/fn.make_array.html b/arrow_array/array/fn.make_array.html
index 02892e13d..fe183cd58 100644
--- a/arrow_array/array/fn.make_array.html
+++ b/arrow_array/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::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="Constructs an array using the input `data`. Returns a reference-counted `Array` instance."><title>make_array in arrow_array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel [...]
 Returns a reference-counted <code>Array</code> instance.</p>
 </div></details></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_array/array/index.html b/arrow_array/array/index.html
index 3fa322b5a..6645942cb 100644
--- a/arrow_array/array/index.html
+++ b/arrow_array/array/index.html
@@ -1,4 +1,4 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The concrete array definitions"><title>arrow_array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.fil [...]
-</div></details><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name" id="reexport.ArrowPrimitiveType"><code>pub use crate::types::<a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>;</code></div></li></ul><h2 id="modules" class="small-section-header"><a href="#modules">Modules</a></h2><ul class="item-table"><li><div cl [...]
+</div></details><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name" id="reexport.ArrowPrimitiveType"><code>pub use crate::types::<a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>;</code></div></li></ul><h2 id="modules" class="small-section-header"><a href="#modules">Modules</a></h2><ul class="item-table"><li><div cl [...]
 Returns a reference-counted <code>Array</code> instance.</div></li><li><div class="item-name"><a class="fn" href="fn.new_empty_array.html" title="fn arrow_array::array::new_empty_array">new_empty_array</a></div><div class="desc docblock-short">Creates a new empty array</div></li><li><div class="item-name"><a class="fn" href="fn.new_null_array.html" title="fn arrow_array::array::new_null_array">new_null_array</a></div><div class="desc docblock-short">Creates a new array of <code>data_type [...]
 entirely of <code>NULL</code> values</div></li><li><div class="item-name"><a class="fn" href="fn.print_long_array.html" title="fn arrow_array::array::print_long_array">print_long_array</a><span title="Restricted Visibility">&nbsp;🔒</span> </div><div class="desc docblock-short">Helper function for printing potentially long arrays.</div></li></ul><h2 id="types" class="small-section-header"><a href="#types">Type Definitions</a></h2><ul class="item-table"><li><div class="item-name"><a class= [...]
\ No newline at end of file
diff --git a/arrow_array/array/list_array/struct.GenericListArray.html b/arrow_array/array/list_array/struct.GenericListArray.html
index 05a5dcc59..600afa532 100644
--- a/arrow_array/array/list_array/struct.GenericListArray.html
+++ b/arrow_array/array/list_array/struct.GenericListArray.html
@@ -62,15 +62,15 @@ allowing for zero-copy cloning</p>
 ];
 <span class="kw">let </span>list_array = ListArray::from_iter_primitive::&lt;Int32Type, <span class="kw">_</span>, <span class="kw">_</span>&gt;(data);
 <span class="macro">println!</span>(<span class="string">&quot;{:?}&quot;</span>, list_array);</code></pre></div>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericListArray%3COffsetSize%3E-1" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/list_array.rs.html#350-395">source</a><a href="#impl-GenericListArray%3COffsetSize%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow_array::array::list_array::OffsetSizeTrait">Off [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/list_array.rs.html#402-404">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a cl [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericListArray%3COffsetSize%3E-1" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/list_array.rs.html#350-395">source</a><a href="#impl-GenericListArray%3COffsetSize%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize: <a class="trait" href="trait.OffsetSizeTrait.html" title="trait arrow_array::array::list_array::OffsetSizeTrait">Off [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/list_array.rs.html#402-404">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; Array [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/list_array.rs.html#430-432">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href= [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/list_array.rs.html#443-450">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" cl [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
 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="srclink" 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" 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-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-RefUnwindSafe-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">i [...]
     OffsetSize: <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-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-UnwindSafe-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; !<a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="t [...]
diff --git a/arrow_array/array/map_array/struct.MapArray.html b/arrow_array/array/map_array/struct.MapArray.html
index a8472effb..782379afd 100644
--- a/arrow_array/array/map_array/struct.MapArray.html
+++ b/arrow_array/array/map_array/struct.MapArray.html
@@ -60,20 +60,20 @@ allowing for zero-copy cloning</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#216-219">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#222-229">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usi [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#232-234">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="type" href="../../iterator/type.MapArrayIter.html" title="type arrow_array::iterator::MapArrayIter">MapArrayIter</a>&lt;'_&gt;</h4></section></summary><div class="docblock"><p>con [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-MapArray-1" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#257-345">source</a><a href="#impl-MapArray-1" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="struct.MapArray.html" title="struct arrow_array::array::map_array::MapArray">MapArray</a></h3></section></summary><div class="impl-items"><section id="metho [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-MapArray-1" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#257-345">source</a><a href="#impl-MapArray-1" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="struct.MapArray.html" title="struct arrow_array::array::map_array::MapArray">MapArray</a></h3></section></summary><div class="impl-items"><section id="metho [...]
     keys: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,
     values: &amp;dyn <a class="trait" href="../trait.Array.html" title="trait arrow_array::array::Array">Array</a>,
     entry_offsets: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u32.html">u32</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self, ArrowError&gt;</h4></section></summary><div class="docblock"><p>Creates map array from provided keys, values and entry_offsets.</p>
 </div></details></div></details></div><h2 id="trait-implementations" class="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-Array-for-MapArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#347-401">source</a><a href="#impl-Array-for-MapArray" class="anchor">§</a><h3 class=" [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#352-354">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a cla [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#352-354">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayD [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#380-382">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href=" [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/map_array.rs.html#393-400">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" cla [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
 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="srclink" 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" 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-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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/null_array/struct.NullArray.html b/arrow_array/array/null_array/struct.NullArray.html
index 48329014d..65533847f 100644
--- a/arrow_array/array/null_array/struct.NullArray.html
+++ b/arrow_array/array/null_array/struct.NullArray.html
@@ -21,12 +21,12 @@ All elements of a <code>NullArray</code> are always invalid.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#124-126">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a [...]
 The null count of a <code>NullArray</code> always equals its length.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#74-76">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::a [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#78-80">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a clas [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#78-80">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayDa [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#106-108">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href= [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#132-134">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" cl [...]
 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></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-NullArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#42">source</a><a href="#impl-Clone-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trai [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-NullArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/null_array.rs.html#42">source</a><a href="#impl-Clone-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trai [...]
 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="srclink" 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" 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-NullArray" class="impl"><a href="#impl-RefUnwindSafe-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-la [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/primitive_array/struct.NativeAdapter.html b/arrow_array/array/primitive_array/struct.NativeAdapter.html
index 5ff5d43b9..861d6dc66 100644
--- a/arrow_array/array/primitive_array/struct.NativeAdapter.html
+++ b/arrow_array/array/primitive_array/struct.NativeAdapter.html
@@ -7,7 +7,7 @@ this struct. So once implementing <code>From</code> or <code>Into</code> trait f
 the type can be collected to <code>PrimitiveArray</code>.</p>
 </div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.native" class="structfield small-section-header"><a href="#structfield.native" class="anchor field">§</a><code>native: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;T::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native"  [...]
 </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="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1144">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code- [...]
-    T::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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 class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="srclink rightside" hre [...]
+    T::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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 class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="srclink rightside" hre [...]
     &lt;T as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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">Ref [...]
     &lt;T as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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 i [...]
     &lt;T as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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">UnwindSaf [...]
diff --git a/arrow_array/array/primitive_array/struct.PrimitiveArray.html b/arrow_array/array/primitive_array/struct.PrimitiveArray.html
index a59d813de..be3b4bcc9 100644
--- a/arrow_array/array/primitive_array/struct.PrimitiveArray.html
+++ b/arrow_array/array/primitive_array/struct.PrimitiveArray.html
@@ -211,69 +211,69 @@ will be casted to Null</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.precision" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1431-1455">source</a><h4 class="code-header">pub fn <a href="#method.precision" class="fn">precision</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a></h4></section></summary><div class="docblock"><p>Returns the decimal precis [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.scale" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1458-1482">source</a><h4 class="code-header">pub fn <a href="#method.scale" class="fn">scale</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a></h4></section></summary><div class="docblock"><p>Returns the decimal scale of this array</p>
 </div></details></div></details></div><h2 id="trait-implementations" class="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-Array-for-PrimitiveArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#964-1012">source</a><a href="#impl-Array-for-PrimitiveArray%3CT%3E [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#969-971">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt;  [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#969-971">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt;  [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#997-999">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum"  [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1009-1011">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_s [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-49" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1369-1384">source</a><a href="#method.from-49" 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="../../../arrow_data/data/struct.Ar [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-56" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1369-1384">source</a><a href="#method.from-56" 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: ArrayData) -&gt; Self</h4></section></summary><div class=' [...]
     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="../../types/struct.DurationMicrosecondType.html" title="struct arrow_array::types::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../typ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#impl-From%3CVec%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#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="../../types/struct.DurationMillisecondType.html" title="struct arrow_array::types::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../typ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-From%3CVec%3C%3 [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-From%3CVec%3C%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="../../types/struct.DurationNanosecondType.html" title="struct arrow_array::types::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec%3C%3CDuratio [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec%3C%3CDuratio [...]
     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="../../types/struct.IntervalMonthDayNanoType.html" title="struct arrow_array::types::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From%3CVec%3C%3CI [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From%3CVec%3C%3CI [...]
     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="../../types/struct.IntervalYearMonthType.html" title="struct arrow_array::types::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/tra [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From%3CVec%3C%3CT [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From%3CVec%3C%3CT [...]
     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="../../types/struct.Time32MillisecondType.html" title="struct arrow_array::types::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/tra [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3C%3CTime32Secon [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3C%3CTime32Secon [...]
     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="../../types/struct.Time64MicrosecondType.html" title="struct arrow_array::types::Time64MicrosecondType">Time64MicrosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/tra [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#impl-From%3CVec%3C%3CTim [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#impl-From%3CVec%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;&lt;<a class="struct" href="../../types/struct.TimestampMicrosecondType.html" title="struct arrow_array::types::TimestampMicrosecondType">TimestampMicrosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#impl-From%3CVec% [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#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="../../types/struct.TimestampMillisecondType.html" title="struct arrow_array::types::TimestampMillisecondType">TimestampMillisecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#impl-From%3CVec%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#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="../../types/struct.TimestampNanosecondType.html" title="struct arrow_array::types::TimestampNanosecondType">TimestampNanosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../typ [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVec%3C%3CTimes [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVec%3C%3CTimes [...]
     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="../../types/struct.Decimal128Type.html" title="struct arrow_array::types::Decimal128Type">Decimal128Type</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait ar [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDecimal256Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDecimal256Type%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1301">source</a><a href="#impl-From%3CVec%3COption [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDecimal256Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDecimal256Type%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1301">source</a><a href="#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="../../types/struct.Decimal256Type.html" title="struct arrow_array::types::Decimal256Type">Decimal256Type</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait ar [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1314">source</a><a href="#impl-F [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1314">source</a><a href="#impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../types/struct.DurationMicrosecondType.html" title="struct arrow_array::types::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiv [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#impl-F [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../types/struct.DurationMillisecondType.html" title="struct arrow_array::types::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiv [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-Fro [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-Fro [...]
     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="../../types/struct.DurationNanosecondType.html" title="struct arrow_array::types::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveTy [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec% [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#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="../../types/struct.DurationSecondType.html" title="struct arrow_array::types::DurationSecondType">DurationSecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" tit [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CFloat16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CFloat16Type%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1297">source</a><a href="#impl-From%3CVec%3COption%3C%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CFloat16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CFloat16Type%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1297">source</a><a href="#impl-From%3CVec%3COption%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;<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="../../types/struct.IntervalDayTimeType.html" title="struct arrow_array::types::IntervalDayTimeType">IntervalDayTimeType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html"  [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalMonthDayNanoType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalMonthDayNanoType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1311">source</a><a href="#impl [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalMonthDayNanoType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalMonthDayNanoType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1311">source</a><a href="#impl [...]
     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="../../types/struct.IntervalMonthDayNanoType.html" title="struct arrow_array::types::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../../types/trait.ArrowPrimi [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From% [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#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="../../types/struct.IntervalYearMonthType.html" title="struct arrow_array::types::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From% [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#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="../../types/struct.Time32MillisecondType.html" title="struct arrow_array::types::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3COp [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3COp [...]
     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="../../types/struct.Time32SecondType.html" title="struct arrow_array::types::Time32SecondType">Time32SecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="tr [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64MicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64MicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1307">source</a><a href="#impl-From% [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64MicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64MicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1307">source</a><a href="#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="../../types/struct.Time64MicrosecondType.html" title="struct arrow_array::types::Time64MicrosecondType">Time64MicrosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#impl-From%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#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="../../types/struct.Time64NanosecondType.html" title="struct arrow_array::types::Time64NanosecondType">Time64NanosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.htm [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1318">source</a><a href="#impl [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1318">source</a><a href="#impl [...]
     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="../../types/struct.TimestampMicrosecondType.html" title="struct arrow_array::types::TimestampMicrosecondType">TimestampMicrosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimi [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#impl [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#impl [...]
     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="../../types/struct.TimestampMillisecondType.html" title="struct arrow_array::types::TimestampMillisecondType">TimestampMillisecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimi [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#impl-F [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#impl-F [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&lt;<a class="struct" href="../../types/struct.TimestampNanosecondType.html" title="struct arrow_array::types::TimestampNanosecondType">TimestampNanosecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiv [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVe [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVe [...]
     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="../../types/struct.TimestampSecondType.html" title="struct arrow_array::types::TimestampSecondType">TimestampSecondType</a> as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html"  [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CUInt16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CUInt16Type%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1294">source</a><a href="#impl-From%3CVec%3COption%3C%3CUI [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CUInt16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CUInt16Type%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/primitive_array.rs.html#1294">source</a><a href="#impl-From%3CVec%3COption%3C%3CUI [...]
 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="srclink" 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" 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-PrimitiveArray%3CT%3E" class="impl"><a href="#impl-RefUnwindSafe-for-PrimitiveArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class= [...]
     &lt;T as <a class="trait" href="../../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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">Ref [...]
diff --git a/arrow_array/array/run_array/struct.RunArray.html b/arrow_array/array/run_array/struct.RunArray.html
index 2ab42fd8b..771d5e98d 100644
--- a/arrow_array/array/run_array/struct.RunArray.html
+++ b/arrow_array/array/run_array/struct.RunArray.html
@@ -67,14 +67,14 @@ scaled well for larger inputs.
 See <a href="https://github.com/apache/arrow-rs/pull/3622#issuecomment-1407753727">https://github.com/apache/arrow-rs/pull/3622#issuecomment-1407753727</a> for more details.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#258-264">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usi [...]
 </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-Array-for-RunArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#315-361">source</a><a href="#impl-Array-for-RunArray%3CT%3E" class="anchor">§< [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#320-322">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a cla [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#320-322">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayD [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#348-350">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href=" [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#356-360">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" cla [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
 <h4 id="example"><a href="#example">Example:</a></h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{RunArray, PrimitiveArray, StringArray, types::Int16Type};
 
diff --git a/arrow_array/array/run_array/struct.TypedRunArray.html b/arrow_array/array/run_array/struct.TypedRunArray.html
index ddad847b1..292a82a58 100644
--- a/arrow_array/array/run_array/struct.TypedRunArray.html
+++ b/arrow_array/array/run_array/struct.TypedRunArray.html
@@ -21,7 +21,7 @@
 </div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#525-527">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of this <a [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.run_array" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#530-532">source</a><h4 class="code-header">pub fn <a href="#method.run_array" class="fn">run_array</a>(&amp;self) -&gt; &amp;'a <a class="struct" href="struct.RunArray.html" title="struct arrow_array::array::run_array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div class="docbloc [...]
 </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-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#535-579">source</a><a href="#impl-Array-for-TypedRunArray%3C'a,+R, [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#540-542">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a cla [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#540-542">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayD [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#568-570">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href=" [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/run_array.rs.html#576-578">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" cla [...]
@@ -32,11 +32,11 @@ When using this function on a slice, the index is relative to the slice. <a href
     R: <a class="trait" href="../../types/trait.RunEndIndexType.html" title="trait arrow_array::types::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core:: [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core:: [...]
     R: <a class="trait" href="../../types/trait.RunEndIndexType.html" title="trait arrow_array::types::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core:: [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="../trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="../trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core:: [...]
     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-Sync-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Sync-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> for <a class="struct [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</span></h3></section><section id="impl-Unpin-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Unpin-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a> for <a class="s [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/string_array/type.GenericStringArray.html b/arrow_array/array/string_array/type.GenericStringArray.html
index 4dfc0b9d8..4ee97036b 100644
--- a/arrow_array/array/string_array/type.GenericStringArray.html
+++ b/arrow_array/array/string_array/type.GenericStringArray.html
@@ -22,6 +22,6 @@ please use the function <a href="#method.value_length"><code>value_length</code>
     v: <a class="type" href="../binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinaryArray">GenericBinaryArray</a>&lt;OffsetSize&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;Self, ArrowError&gt;</h4></section></summary><div class="docblock"><p>Fallibly creates a <a href="type.GenericStringArray.html" title="type arrow_array::array::string_array::GenericStringArray"><code>GenericStringArray</code></a> from a <a href="../binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinar [...]
 an error if <a href="../binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinaryArray"><code>GenericBinaryArray</code></a> contains invalid UTF-8 data</p>
-</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-From%3CGenericByteArray%3CGenericBinaryType%3COffsetSize%3E%3E%3E-for-GenericStringArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/string_array.rs.h [...]
+</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-From%3CGenericByteArray%3CGenericBinaryType%3COffsetSize%3E%3E%3E-for-GenericStringArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/string_array.rs.h [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_array/array/struct.BooleanArray.html b/arrow_array/array/struct.BooleanArray.html
index 3364679f3..c8d4e4d69 100644
--- a/arrow_array/array/struct.BooleanArray.html
+++ b/arrow_array/array/struct.BooleanArray.html
@@ -70,14 +70,14 @@ each element of the provided arrays</p>
 <p>This function panics if left and right are not the same length</p>
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BooleanArray-1" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/boolean_array.rs.html#384-389">source</a><a href="#impl-BooleanArray-1" class="anchor">§</a><h3 class="code-header">impl&lt;'a&gt; <a class="struct" href="boolean_array/struct.BooleanArray.html" title="struct arrow_array::array::boolean_array::BooleanArray">BooleanArray</a></h3></section></s [...]
 </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-Array-for-BooleanArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/boolean_array.rs.html#251-299">source</a><a href="#impl-Array-for-BooleanArray" class="anchor">§</a><h [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/boolean_array.rs.html#256-258">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="s [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/boolean_array.rs.html#256-258">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</ [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/boolean_array.rs.html#284-286">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/boolean_array.rs.html#296-298">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
 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="srclink" 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" 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-BooleanArray" class="impl"><a href="#impl-RefUnwindSafe-for-BooleanArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.r [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/struct.DictionaryArray.html b/arrow_array/array/struct.DictionaryArray.html
index 246004397..c48f0bca7 100644
--- a/arrow_array/array/struct.DictionaryArray.html
+++ b/arrow_array/array/struct.DictionaryArray.html
@@ -162,16 +162,16 @@ or this function may panic.</p>
 <p>For each value in <a href="dictionary_array/struct.DictionaryArray.html#method.values" title="method arrow_array::array::dictionary_array::DictionaryArray::values"><code>Self::values</code></a> the corresponding bit will be set in the
 returned mask if it is referenced by a key in this <a href="dictionary_array/struct.DictionaryArray.html" title="struct arrow_array::array::dictionary_array::DictionaryArray"><code>DictionaryArray</code></a></p>
 </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-Array-for-DictionaryArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#695-741">source</a><a href="#impl-Array-for-DictionaryArray%3CT%3E" [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#700-702">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#700-702">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayDat [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#728-730">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="ht [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#736-740">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" cl [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#580-624">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="../../arrow_data/data/struct.ArrayData.html" [...]
-<h4 id="example-1"><a href="#example-1">Example:</a></h4>
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#580-624">source</a><a href="#method.from-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html#tymethod.from" class="fn">from</a>(data: ArrayData) -&gt; Self</h4></section></summary><div class='docblo [...]
+<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>];
@@ -180,8 +180,8 @@ 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" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#681-692">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: <a class="trait" href="https [...]
-<h4 id="example-2"><a href="#example-2">Example:</a></h4>
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#681-692">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: <a class="trait" href="h [...]
+<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>];
@@ -193,7 +193,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-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#657-663">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: <a class="trait" href="h [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#657-663">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: <a class="trait" href="https [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" 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-DictionaryArray%3CK%3E" class="impl"><a href="#impl-RefUnwindSafe-for-DictionaryArray%3CK%3E" class="anchor">§</a><h3 class="code-header">impl&lt;K&gt; !<a cla [...]
     &lt;K as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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="imp [...]
diff --git a/arrow_array/array/struct.FixedSizeBinaryArray.html b/arrow_array/array/struct.FixedSizeBinaryArray.html
index fe5a6f78e..d77a335e4 100644
--- a/arrow_array/array/struct.FixedSizeBinaryArray.html
+++ b/arrow_array/array/struct.FixedSizeBinaryArray.html
@@ -111,15 +111,15 @@ created.</p>
 <p>Returns error if argument has length zero, or sizes of nested slices don’t match.</p>
 </div></details><section id="method.value_offset_at" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#450-452">source</a><h4 class="code-header">fn <a href="#method.value_offset_at" class="fn">value_offset_at</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></h4></s [...]
 </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-Array-for-FixedSizeBinaryArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#561-609">source</a><a href="#impl-Array-for-FixedSizeBinaryArr [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#566-568">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; < [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#566-568">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; A [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#594-596">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" h [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#606-608">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_s [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#499-535">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="fixed_size_list_array/struct.FixedSi [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#499-535">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="fixed_size_list_array/struct.FixedSi [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" 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-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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/struct.FixedSizeListArray.html b/arrow_array/array/struct.FixedSizeListArray.html
index 85c24dde3..1d3444342 100644
--- a/arrow_array/array/struct.FixedSizeListArray.html
+++ b/arrow_array/array/struct.FixedSizeListArray.html
@@ -82,14 +82,14 @@
 <span class="macro">println!</span>(<span class="string">&quot;{:?}&quot;</span>, list_array);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_list_array.rs.html#283-285">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="type" href="../iterator/type.FixedSizeListIter.html" title="type arrow_array::iterator::FixedSizeListIter">FixedSizeListIter</a>&lt;'_&gt;</h4></section></summary><div cl [...]
 </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-Array-for-FixedSizeListArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_list_array.rs.html#322-374">source</a><a href="#impl-Array-for-FixedSizeListArray" cl [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_list_array.rs.html#327-329">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a  [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_list_array.rs.html#327-329">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; Arr [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_list_array.rs.html#355-357">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" hre [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_list_array.rs.html#367-373">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_siz [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-3" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/fixed_size_binary_array.rs.html#499-535">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="fixed_size_list_array/struct.FixedSi [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" 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-FixedSizeListArray" class="impl"><a href="#impl-RefUnwindSafe-for-FixedSizeListArray" class="anchor">§</a><h3 class="code-header">impl !<a class="trait" href=" [...]
diff --git a/arrow_array/array/struct.GenericByteArray.html b/arrow_array/array/struct.GenericByteArray.html
index 4efd96070..8e52a5f00 100644
--- a/arrow_array/array/struct.GenericByteArray.html
+++ b/arrow_array/array/struct.GenericByteArray.html
@@ -120,16 +120,16 @@ please use the function <a href="#method.value_length"><code>value_length</code>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self, ArrowError&gt;</h4></section></summary><div class="docblock"><p>Fallibly creates a <a href="string_array/type.GenericStringArray.html" title="type arrow_array::array::string_array::GenericStringArray"><code>GenericStringArray</code></a> from a <a href="binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::Ge [...]
 an error if <a href="binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinaryArray"><code>GenericBinaryArray</code></a> contains invalid UTF-8 data</p>
 </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-Array-for-GenericByteArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#389-438">source</a><a href="#impl-Array-for-GenericByteArray%3CT%3E" cla [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#394-396">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="stru [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#394-396">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4> [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#422-424">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:// [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/byte_array.rs.html#435-437">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="f [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
     Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;T::<a class="associatedtype" href="../types/trait.ByteArrayType.html#associatedtype.Native" title="type arrow_array::types::ByteArrayType::Native">Native</a>&gt; + '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 [...]
-    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;T::<a class="associatedtype" href="../types/trait.ByteArrayType.html#associatedtype.Native" title="type arrow_array::types::ByteArrayType::Native">Native</a>&gt;,</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="srclink ri [...]
+    Ptr: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html" title="trait core::convert::AsRef">AsRef</a>&lt;T::<a class="associatedtype" href="../types/trait.ByteArrayType.html#associatedtype.Native" title="type arrow_array::types::ByteArrayType::Native">Native</a>&gt;,</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="srclink ri [...]
 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="srclink" 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" 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%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericStringArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#419-423">source</a><a href="#impl-PartialEq%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericStr [...]
 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="srclink" 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 [...]
diff --git a/arrow_array/array/struct.GenericListArray.html b/arrow_array/array/struct.GenericListArray.html
index 22f9cec3d..6e20f6fc7 100644
--- a/arrow_array/array/struct.GenericListArray.html
+++ b/arrow_array/array/struct.GenericListArray.html
@@ -62,15 +62,15 @@ allowing for zero-copy cloning</p>
 ];
 <span class="kw">let </span>list_array = ListArray::from_iter_primitive::&lt;Int32Type, <span class="kw">_</span>, <span class="kw">_</span>&gt;(data);
 <span class="macro">println!</span>(<span class="string">&quot;{:?}&quot;</span>, list_array);</code></pre></div>
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericListArray%3COffsetSize%3E-1" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#350-395">source</a><a href="#impl-GenericListArray%3COffsetSize%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize: <a class="trait" href="list_array/trait.OffsetSizeTrait.html" title="trait arrow_array::array::list_array::OffsetSizeTr [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#402-404">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="stru [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-GenericListArray%3COffsetSize%3E-1" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#350-395">source</a><a href="#impl-GenericListArray%3COffsetSize%3E-1" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize: <a class="trait" href="list_array/trait.OffsetSizeTrait.html" title="trait arrow_array::array::list_array::OffsetSizeTr [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#402-404">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4> [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#430-432">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:// [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/list_array.rs.html#443-450">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="f [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
 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="srclink" 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" 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-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-RefUnwindSafe-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">i [...]
     OffsetSize: <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-GenericListArray%3COffsetSize%3E" class="impl"><a href="#impl-UnwindSafe-for-GenericListArray%3COffsetSize%3E" class="anchor">§</a><h3 class="code-header">impl&lt;OffsetSize&gt; !<a class="trait" href="https://doc.rust-lang.org/nightly/core/panic/unwind_safe/trait.UnwindSafe.html" title="t [...]
diff --git a/arrow_array/array/struct.MapArray.html b/arrow_array/array/struct.MapArray.html
index f991e4a36..1ac2253fe 100644
--- a/arrow_array/array/struct.MapArray.html
+++ b/arrow_array/array/struct.MapArray.html
@@ -60,20 +60,20 @@ allowing for zero-copy cloning</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.value_length" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#216-219">source</a><h4 class="code-header">pub fn <a href="#method.value_length" class="fn">value_length</a>(&amp;self, i: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/pr [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#222-229">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize. [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#232-234">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; <a class="type" href="../iterator/type.MapArrayIter.html" title="type arrow_array::iterator::MapArrayIter">MapArrayIter</a>&lt;'_&gt;</h4></section></summary><div class="docblock"><p>construct [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-MapArray-1" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#257-345">source</a><a href="#impl-MapArray-1" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="map_array/struct.MapArray.html" title="struct arrow_array::array::map_array::MapArray">MapArray</a></h3></section></summary><div class="impl-items"><section id [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-MapArray-1" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#257-345">source</a><a href="#impl-MapArray-1" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="map_array/struct.MapArray.html" title="struct arrow_array::array::map_array::MapArray">MapArray</a></h3></section></summary><div class="impl-items"><section id [...]
     keys: impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = &amp;'a <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;,
     values: &amp;dyn <a class="trait" href="trait.Array.html" title="trait arrow_array::array::Array">Array</a>,
     entry_offsets: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u32.html">u32</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self, ArrowError&gt;</h4></section></summary><div class="docblock"><p>Creates map array from provided keys, values and entry_offsets.</p>
 </div></details></div></details></div><h2 id="trait-implementations" class="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-Array-for-MapArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#347-401">source</a><a href="#impl-Array-for-MapArray" class="anchor">§</a><h3 class="cod [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#352-354">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struc [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#352-354">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4>< [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#380-382">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://d [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/map_array.rs.html#393-400">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="fn [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
 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="srclink" 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" 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-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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/struct.NativeAdapter.html b/arrow_array/array/struct.NativeAdapter.html
index 0dcaf89ed..ed94ee9de 100644
--- a/arrow_array/array/struct.NativeAdapter.html
+++ b/arrow_array/array/struct.NativeAdapter.html
@@ -7,7 +7,7 @@ this struct. So once implementing <code>From</code> or <code>Into</code> trait f
 the type can be collected to <code>PrimitiveArray</code>.</p>
 </div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.native" class="structfield small-section-header"><a href="#structfield.native" class="anchor field">§</a><code>native: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;T::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" tit [...]
 </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="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1144">source</a><a href="#impl-Debug-for-NativeAdapter%3CT%3E" class="anchor">§</a><h3 class="code-hea [...]
-    T::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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 class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="srclink rightside" href=" [...]
+    T::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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 class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.fmt" class="method trait-impl"><a class="srclink rightside" href=" [...]
     &lt;T as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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">RefUnwind [...]
     &lt;T as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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="imp [...]
     &lt;T as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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</a>, [...]
diff --git a/arrow_array/array/struct.NullArray.html b/arrow_array/array/struct.NullArray.html
index 28fb0c176..e95a0c326 100644
--- a/arrow_array/array/struct.NullArray.html
+++ b/arrow_array/array/struct.NullArray.html
@@ -21,12 +21,12 @@ All elements of a <code>NullArray</code> are always invalid.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#124-126">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4> [...]
 The null count of a <code>NullArray</code> always equals its length.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#74-76">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any::An [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#78-80">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#78-80">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4></ [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#106-108">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:// [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#132-134">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="f [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-NullArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#42">source</a><a href="#impl-Clone-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.C [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-NullArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/null_array.rs.html#42">source</a><a href="#impl-Clone-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/trait.C [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" 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-NullArray" class="impl"><a href="#impl-RefUnwindSafe-for-NullArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-la [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/struct.PrimitiveArray.html b/arrow_array/array/struct.PrimitiveArray.html
index f9f997c73..b726eec2b 100644
--- a/arrow_array/array/struct.PrimitiveArray.html
+++ b/arrow_array/array/struct.PrimitiveArray.html
@@ -211,69 +211,69 @@ will be casted to Null</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.precision" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1431-1455">source</a><h4 class="code-header">pub fn <a href="#method.precision" class="fn">precision</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a></h4></section></summary><div class="docblock"><p>Returns the decimal precision [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.scale" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1458-1482">source</a><h4 class="code-header">pub fn <a href="#method.scale" class="fn">scale</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i8.html">i8</a></h4></section></summary><div class="docblock"><p>Returns the decimal scale of this array</p>
 </div></details></div></details></div><h2 id="trait-implementations" class="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-Array-for-PrimitiveArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#964-1012">source</a><a href="#impl-Array-for-PrimitiveArray%3CT%3E" c [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#969-971">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class= [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#969-971">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#997-999">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="htt [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1009-1011">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" c [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
-</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-49" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1369-1384">source</a><a href="#method.from-49" 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="../../arrow_data/data/struct.ArrayDat [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+</div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-56" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1369-1384">source</a><a href="#method.from-56" 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: ArrayData) -&gt; Self</h4></section></summary><div class='doc [...]
     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="../types/struct.DurationMicrosecondType.html" title="struct arrow_array::types::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#impl-From%3CVec%3C%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#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="../types/struct.DurationMillisecondType.html" title="struct arrow_array::types::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-From%3CVec%3C%3CDu [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-From%3CVec%3C%3CDu [...]
     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="../types/struct.DurationNanosecondType.html" title="struct arrow_array::types::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.Arr [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec%3C%3CDurationSe [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec%3C%3CDurationSe [...]
     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="../types/struct.IntervalMonthDayNanoType.html" title="struct arrow_array::types::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/tra [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From%3CVec%3C%3CInte [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From%3CVec%3C%3CInte [...]
     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="../types/struct.IntervalYearMonthType.html" title="struct arrow_array::types::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowP [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From%3CVec%3C%3CTime [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From%3CVec%3C%3CTime [...]
     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="../types/struct.Time32MillisecondType.html" title="struct arrow_array::types::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowP [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3C%3CTime32SecondTy [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3C%3CTime32SecondTy [...]
     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="../types/struct.Time64MicrosecondType.html" title="struct arrow_array::types::Time64MicrosecondType">Time64MicrosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowP [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#impl-From%3CVec%3C%3CTime64 [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#impl-From%3CVec%3C%3CTime64 [...]
     data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;&lt;<a class="struct" href="../types/struct.TimestampMicrosecondType.html" title="struct arrow_array::types::TimestampMicrosecondType">TimestampMicrosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/tra [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#impl-From%3CVec%3C% [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#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="../types/struct.TimestampMillisecondType.html" title="struct arrow_array::types::TimestampMillisecondType">TimestampMillisecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/tra [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#impl-From%3CVec%3C%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#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="../types/struct.TimestampNanosecondType.html" title="struct arrow_array::types::TimestampNanosecondType">TimestampNanosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVec%3C%3CTimestam [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVec%3C%3CTimestam [...]
     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="../types/struct.Decimal128Type.html" title="struct arrow_array::types::Decimal128Type">Decimal128Type</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_ar [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDecimal256Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDecimal256Type%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1301">source</a><a href="#impl-From%3CVec%3COption%3C [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDecimal256Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDecimal256Type%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1301">source</a><a href="#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="../types/struct.Decimal256Type.html" title="struct arrow_array::types::Decimal256Type">Decimal256Type</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_ar [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1314">source</a><a href="#impl-From [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1314">source</a><a href="#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="../types/struct.DurationMicrosecondType.html" title="struct arrow_array::types::DurationMicrosecondType">DurationMicrosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#impl-From [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1313">source</a><a href="#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="../types/struct.DurationMillisecondType.html" title="struct arrow_array::types::DurationMillisecondType">DurationMillisecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-From%3 [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1315">source</a><a href="#impl-From%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;<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="../types/struct.DurationNanosecondType.html" title="struct arrow_array::types::DurationNanosecondType">DurationNanosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.htm [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec%3CO [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CDurationSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CDurationSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1312">source</a><a href="#impl-From%3CVec%3CO [...]
     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="../types/struct.DurationSecondType.html" title="struct arrow_array::types::DurationSecondType">DurationSecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="tr [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CFloat16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CFloat16Type%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1297">source</a><a href="#impl-From%3CVec%3COption%3C%3CFlo [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CFloat16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CFloat16Type%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1297">source</a><a href="#impl-From%3CVec%3COption%3C%3CFlo [...]
     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="../types/struct.IntervalDayTimeType.html" title="struct arrow_array::types::IntervalDayTimeType">IntervalDayTimeType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title= [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalMonthDayNanoType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalMonthDayNanoType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1311">source</a><a href="#impl-Fr [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalMonthDayNanoType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalMonthDayNanoType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1311">source</a><a href="#impl-Fr [...]
     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="../types/struct.IntervalMonthDayNanoType.html" title="struct arrow_array::types::IntervalMonthDayNanoType">IntervalMonthDayNanoType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveTy [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From%3CV [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CIntervalYearMonthType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CIntervalYearMonthType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1309">source</a><a href="#impl-From%3CV [...]
     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="../types/struct.IntervalYearMonthType.html" title="struct arrow_array::types::IntervalYearMonthType">IntervalYearMonthType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html"  [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From%3CV [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32MillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32MillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1306">source</a><a href="#impl-From%3CV [...]
     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="../types/struct.Time32MillisecondType.html" title="struct arrow_array::types::Time32MillisecondType">Time32MillisecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html"  [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3COptio [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime32SecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime32SecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1305">source</a><a href="#impl-From%3CVec%3COptio [...]
     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="../types/struct.Time32SecondType.html" title="struct arrow_array::types::Time32SecondType">Time32SecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait ar [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64MicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64MicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1307">source</a><a href="#impl-From%3CV [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64MicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64MicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1307">source</a><a href="#impl-From%3CV [...]
     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="../types/struct.Time64MicrosecondType.html" title="struct arrow_array::types::Time64MicrosecondType">Time64MicrosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html"  [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#impl-From%3CVec [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTime64NanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTime64NanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1308">source</a><a href="#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="../types/struct.Time64NanosecondType.html" title="struct arrow_array::types::Time64NanosecondType">Time64NanosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" tit [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1318">source</a><a href="#impl-Fr [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMicrosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMicrosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1318">source</a><a href="#impl-Fr [...]
     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="../types/struct.TimestampMicrosecondType.html" title="struct arrow_array::types::TimestampMicrosecondType">TimestampMicrosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveTy [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#impl-Fr [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampMillisecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampMillisecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1317">source</a><a href="#impl-Fr [...]
     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="../types/struct.TimestampMillisecondType.html" title="struct arrow_array::types::TimestampMillisecondType">TimestampMillisecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveTy [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#impl-From [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampNanosecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampNanosecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1319">source</a><a href="#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="../types/struct.TimestampNanosecondType.html" title="struct arrow_array::types::TimestampNanosecondType">TimestampNanosecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType. [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVec%3 [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CTimestampSecondType+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CTimestampSecondType%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1316">source</a><a href="#impl-From%3CVec%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;<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="../types/struct.TimestampSecondType.html" title="struct arrow_array::types::TimestampSecondType">TimestampSecondType</a> as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title= [...]
-) -&gt; Self</h4></section></summary><div class='docblock'>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%3CUInt16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CUInt16Type%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1294">source</a><a href="#impl-From%3CVec%3COption%3C%3CUInt1 [...]
+) -&gt; Self</h4></section></summary><div class='docblock'>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%3CUInt16Type+as+ArrowPrimitiveType%3E::Native%3E,+Global%3E%3E-for-PrimitiveArray%3CUInt16Type%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/primitive_array.rs.html#1294">source</a><a href="#impl-From%3CVec%3COption%3C%3CUInt1 [...]
 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="srclink" 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" 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-PrimitiveArray%3CT%3E" class="impl"><a href="#impl-RefUnwindSafe-for-PrimitiveArray%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T&gt; <a class= [...]
     &lt;T as <a class="trait" href="../types/trait.ArrowPrimitiveType.html" title="trait arrow_array::types::ArrowPrimitiveType">ArrowPrimitiveType</a>&gt;::<a class="associatedtype" href="../types/trait.ArrowPrimitiveType.html#associatedtype.Native" title="type arrow_array::types::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">RefUnwind [...]
diff --git a/arrow_array/array/struct.RunArray.html b/arrow_array/array/struct.RunArray.html
index cfbf06d82..aeb331781 100644
--- a/arrow_array/array/struct.RunArray.html
+++ b/arrow_array/array/struct.RunArray.html
@@ -67,14 +67,14 @@ scaled well for larger inputs.
 See <a href="https://github.com/apache/arrow-rs/pull/3622#issuecomment-1407753727">https://github.com/apache/arrow-rs/pull/3622#issuecomment-1407753727</a> for more details.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#258-264">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize. [...]
 </div></details></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-Array-for-RunArray%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#315-361">source</a><a href="#impl-Array-for-RunArray%3CT%3E" class="anchor">§</a> [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#320-322">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struc [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#320-322">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4>< [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#348-350">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://d [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#356-360">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="fn [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
 <h4 id="example"><a href="#example">Example:</a></h4>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">use </span>arrow_array::{RunArray, PrimitiveArray, StringArray, types::Int16Type};
 
diff --git a/arrow_array/array/struct.StructArray.html b/arrow_array/array/struct.StructArray.html
index 7c4322b77..1826b4a69 100644
--- a/arrow_array/array/struct.StructArray.html
+++ b/arrow_array/array/struct.StructArray.html
@@ -86,14 +86,14 @@ the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#263-277">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. [...]
 </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-Array-for-StructArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#327-380">source</a><a href="#impl-Array-for-StructArray" class="anchor">§</a><h3 c [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#332-334">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="st [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#332-334">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#360-362">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https: [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/struct_array.rs.html#372-379">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class= [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive" href [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#209-211">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; [...]
-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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
+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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#225-227">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< [...]
 <p>Note: A schema can currently have duplicate field names, in which case
 the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
diff --git a/arrow_array/array/struct.TypedDictionaryArray.html b/arrow_array/array/struct.TypedDictionaryArray.html
index 64e061d71..1bad2c0ca 100644
--- a/arrow_array/array/struct.TypedDictionaryArray.html
+++ b/arrow_array/array/struct.TypedDictionaryArray.html
@@ -20,7 +20,7 @@
 </div><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#797-807">source</a><a href="#impl-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#804-806">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of thi [...]
 </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-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#809-853">source</a><a href="#impl-Array-for-TypedDictio [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#814-816">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#814-816">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayDat [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#842-844">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="ht [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#850-852">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" cl [...]
@@ -31,9 +31,9 @@ When using this function on a slice, the index is relative to the slice. <a href
     K: <a class="trait" href="../types/trait.ArrowDictionaryKeyType.html" title="trait arrow_array::types::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::defaul [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::defaul [...]
     K: <a class="trait" href="../types/trait.ArrowDictionaryKeyType.html" title="trait arrow_array::types::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>,
-    Self: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</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" class="assoc [...]
+    Self: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</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" class="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-Sync-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Sync-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> for <a [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</span></h3></section><section id="impl-Unpin-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a href="#impl-Unpin-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a> f [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/struct.TypedRunArray.html b/arrow_array/array/struct.TypedRunArray.html
index fdefdd1ed..c2f2ce4ea 100644
--- a/arrow_array/array/struct.TypedRunArray.html
+++ b/arrow_array/array/struct.TypedRunArray.html
@@ -21,7 +21,7 @@
 </div></details><details class="toggle method-toggle" open><summary><section id="method.values" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#525-527">source</a><h4 class="code-header">pub fn <a href="#method.values" class="fn">values</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a></h4></section></summary><div class="docblock"><p>Returns the values of this <a hr [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.run_array" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#530-532">source</a><h4 class="code-header">pub fn <a href="#method.run_array" class="fn">run_array</a>(&amp;self) -&gt; &amp;'a <a class="struct" href="run_array/struct.RunArray.html" title="struct arrow_array::array::run_array::RunArray">RunArray</a>&lt;R&gt;</h4></section></summary><div 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-Array-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#535-579">source</a><a href="#impl-Array-for-TypedRunArray%3C'a,+R,+V% [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#540-542">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struc [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#540-542">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4>< [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#568-570">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://d [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/run_array.rs.html#576-578">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class="fn [...]
@@ -32,11 +32,11 @@ When using this function on a slice, the index is relative to the slice. <a href
     R: <a class="trait" href="../types/trait.RunEndIndexType.html" title="trait arrow_array::types::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::defaul [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::defaul [...]
     R: <a class="trait" href="../types/trait.RunEndIndexType.html" title="trait arrow_array::types::RunEndIndexType">RunEndIndexType</a>,
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core::marker::Send">Send</a>,
     <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a>: <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>,
-    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::defaul [...]
+    &lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;'a V</a> as <a class="trait" href="trait.ArrayAccessor.html" title="trait arrow_array::array::ArrayAccessor">ArrayAccessor</a>&gt;::<a class="associatedtype" href="trait.ArrayAccessor.html#associatedtype.Item" title="type arrow_array::array::ArrayAccessor::Item">Item</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/default/trait.Default.html" title="trait core::defaul [...]
     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-Sync-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Sync-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a> for <a class="struct [...]
     V: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html" title="trait core::marker::Sync">Sync</a>,</span></h3></section><section id="impl-Unpin-for-TypedRunArray%3C'a,+R,+V%3E" class="impl"><a href="#impl-Unpin-for-TypedRunArray%3C'a,+R,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, R, V&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Unpin.html" title="trait core::marker::Unpin">Unpin</a> for <a class="s [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_array/array/struct.UnionArray.html b/arrow_array/array/struct.UnionArray.html
index 98b50daef..0471c7e07 100644
--- a/arrow_array/array/struct.UnionArray.html
+++ b/arrow_array/array/struct.UnionArray.html
@@ -129,12 +129,12 @@ To check validity correctly you must check the underlying vector.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#435-437">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4 [...]
 To get null count correctly you must check the underlying vector.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#385-387">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core::any: [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#389-391">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="str [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#389-391">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4 [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#417-419">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https:/ [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#451-463">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.get_array_memory_size" class=" [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
-includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-UnionArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#109">source</a><a href="#impl-Clone-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/tra [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-UnionArray" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/union_array.rs.html#109">source</a><a href="#impl-Clone-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/tra [...]
     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-1" class="method trait-impl"><a class="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id-1" class="anchor">§</a><h4 class="code-header">f [...]
     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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_array/array/struct_array/struct.StructArray.html b/arrow_array/array/struct_array/struct.StructArray.html
index 162b3f4ba..dae48ec22 100644
--- a/arrow_array/array/struct_array/struct.StructArray.html
+++ b/arrow_array/array/struct_array/struct.StructArray.html
@@ -86,14 +86,14 @@ the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../../src/arrow_array/array/struct_array.rs.html#263-277">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.usi [...]
 </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-Array-for-StructArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/struct_array.rs.html#327-380">source</a><a href="#impl-Array-for-StructArray" class="anchor">§</a><h [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/struct_array.rs.html#332-334">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a  [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/struct_array.rs.html#332-334">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; Arr [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/struct_array.rs.html#360-362">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" hre [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/struct_array.rs.html#372-379">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size"  [...]
 This value will always be greater than returned by <code>get_buffer_memory_size()</code> and
 includes the overhead of the data structures that contain the pointers to the various buffers.</div></details><details class="toggle method-toggle" open><summary><section id="method.is_null" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#192-194">source</a><a href="#method.is_null" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.is_null" class="fn">is_null</a>(&amp;self, index: <a class="primitive [...]
 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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#209-211">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< [...]
-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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
+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="srclink rightside" href="../../../src/arrow_array/array/mod.rs.html#225-227">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">nu [...]
 <p>Note: A schema can currently have duplicate field names, in which case
 the first field will always be selected.
 This issue will be addressed in <a href="https://issues.apache.org/jira/browse/ARROW-11178">ARROW-11178</a></p>
diff --git a/arrow_array/array/trait.Array.html b/arrow_array/array/trait.Array.html
index 981e0c12a..5479d7f7e 100644
--- a/arrow_array/array/trait.Array.html
+++ b/arrow_array/array/trait.Array.html
@@ -1,8 +1,8 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An array in the arrow columnar format"><title>Array in arrow_array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
 <details class="toggle type-contents-toggle"><summary class="hideme"><span>Show 14 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>;
-<span class="item-spacer"></span>    fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../../arrow_data/data/struct.ArrayData.html" title="struct arrow_data::data::ArrayData">ArrayData</a>;
-<span class="item-spacer"></span>    fn <a href="#tymethod.into_data" class="fn">into_data</a>(self) -&gt; <a class="struct" href="../../arrow_data/data/struct.ArrayData.html" title="struct arrow_data::data::ArrayData">ArrayData</a>;
+<span class="item-spacer"></span>    fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData;
+<span class="item-spacer"></span>    fn <a href="#tymethod.into_data" class="fn">into_data</a>(self) -&gt; ArrayData;
 <span class="item-spacer"></span>    fn <a href="#tymethod.data_type" class="fn">data_type</a>(&amp;self) -&gt; &amp;DataType;
 <span class="item-spacer"></span>    fn <a href="#tymethod.slice" class="fn">slice</a>(&amp;self, offset: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>) -&gt; <a class="type" href="type.ArrayRef.html" title="type arrow_array::array::ArrayRef">ArrayRef</a>;
 <span class="item-spacer"></span>    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>;
@@ -32,8 +32,8 @@ downcasted to a specific implementation.</p>
     .as_any()
     .downcast_ref::&lt;Int32Array&gt;()
     .expect(<span class="string">&quot;Failed to downcast&quot;</span>);</code></pre></div>
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.to_data" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#97">source</a><h4 class="code-header">fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" href="../../arrow_data/data/struct.ArrayData.html" title="struct arrow_data::data::ArrayData">ArrayData</a></h4></section></summary><div class="docblock"><p>Returns the underly [...]
-</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.into_data" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#102">source</a><h4 class="code-header">fn <a href="#tymethod.into_data" class="fn">into_data</a>(self) -&gt; <a class="struct" href="../../arrow_data/data/struct.ArrayData.html" title="struct arrow_data::data::ArrayData">ArrayData</a></h4></section></summary><div class="docblock"><p>Returns the under [...]
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.to_data" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#97">source</a><h4 class="code-header">fn <a href="#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4></section></summary><div class="docblock"><p>Returns the underlying data of this array</p>
+</div></details><details class="toggle method-toggle" open><summary><section id="tymethod.into_data" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#102">source</a><h4 class="code-header">fn <a href="#tymethod.into_data" class="fn">into_data</a>(self) -&gt; ArrayData</h4></section></summary><div class="docblock"><p>Returns the underlying data of this array</p>
 <p>Unlike <a href="trait.Array.html#tymethod.to_data" title="method arrow_array::array::Array::to_data"><code>Array::to_data</code></a> this consumes self, allowing it avoid unnecessary clones</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="tymethod.data_type" class="method"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#116">source</a><h4 class="code-header">fn <a href="#tymethod.data_type" class="fn">data_type</a>(&amp;self) -&gt; &amp;DataType</h4></section></summary><div class="docblock"><p>Returns a reference to the <a href="arrow_schema::DataType"><code>DataType</code></a> of this array.</p>
 <h5 id="example-1"><a href="#example-1">Example:</a></h5>
@@ -115,5 +115,5 @@ When using this function on a slice, the index is relative to the slice.</p>
 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="srclink" 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 [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#383-387">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 [...]
 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="srclink" 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" cl [...]
-sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Sealed-for-dyn+Array+%2B+'_" class="impl"><a class="srclink rightside" href="../../src/arrow_array/cast.rs.html#829">source</a><a href="#impl-Sealed-for-dyn+Array+%2B+'_" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../cast/private/trait.Sealed.html" title="trait arrow_array::cast::private::Sealed">Sealed</a> for dyn <a class="trait" href="trait.A [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Sealed-for-dyn+Array+%2B+'_" class="impl"><a class="srclink rightside" href="../../src/arrow_array/cast.rs.html#829">source</a><a href="#impl-Sealed-for-dyn+Array+%2B+'_" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="../cast/private/trait.Sealed.html" title="trait arrow_array::cast::private::Sealed">Sealed</a> for dyn <a class="trait" href="trait.A [...]
 </div><section id="impl-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/dictionary_array.rs.html#809-853">source</a><a href="#impl-Array-for-TypedDictionaryArray%3C'a,+K,+V%3E" class="anchor">§</a><h3 class="code-header">impl&lt;'a, K: <a class="trait" href="../types/trait.ArrowDictionaryKeyType.html" title="trait arrow_array::types::ArrowDictionaryKeyType">ArrowDictionaryKeyType</a>, V: <a class="trait" href="http [...]
\ No newline at end of file
diff --git a/arrow_array/array/type.ArrayRef.html b/arrow_array/array/type.ArrayRef.html
index 228821a39..9ad5cd455 100644
--- a/arrow_array/array/type.ArrayRef.html
+++ b/arrow_array/array/type.ArrayRef.html
@@ -1,7 +1,7 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A reference-counted reference to a generic `Array`"><title>ArrayRef in arrow_array::array - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cr [...]
 </div></details><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-Array-for-ArrayRef" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#243-299">source</a><a href="#impl-Array-for-ArrayRef" class="anchor">§</a><h3 class="code-header">impl <a class="tra [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#244-246">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core [...]
-downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#248-250">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a class="struct" hre [...]
+downcasted to a specific implementation. <a href="trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#248-250">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; ArrayData</h4></secti [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#276-278">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href="https://doc.rus [...]
 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="srclink rightside" href="../../src/arrow_array/array/mod.rs.html#284-286">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; [...]
diff --git a/arrow_array/array/type.GenericBinaryArray.html b/arrow_array/array/type.GenericBinaryArray.html
index 2a9e30668..add1705db 100644
--- a/arrow_array/array/type.GenericBinaryArray.html
+++ b/arrow_array/array/type.GenericBinaryArray.html
@@ -16,6 +16,6 @@
 ) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;Item = <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;&amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]&gt;&gt; + 'a</h4></section></summary><div class="docblock"><p>Retur [...]
 <h5 id="safety"><a href="#safety">Safety</a></h5>
 <p>caller must ensure that the indexes in the iterator are less than the <code>array.len()</code></p>
-</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-From%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericBinaryArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.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-From%3CGenericByteArray%3CGenericStringType%3COffsetSize%3E%3E%3E-for-GenericBinaryArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/binary_array.rs.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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_array/array/type.GenericStringArray.html b/arrow_array/array/type.GenericStringArray.html
index 5274969a8..df069fadc 100644
--- a/arrow_array/array/type.GenericStringArray.html
+++ b/arrow_array/array/type.GenericStringArray.html
@@ -22,6 +22,6 @@ please use the function <a href="#method.value_length"><code>value_length</code>
     v: <a class="type" href="binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinaryArray">GenericBinaryArray</a>&lt;OffsetSize&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;Self, ArrowError&gt;</h4></section></summary><div class="docblock"><p>Fallibly creates a <a href="string_array/type.GenericStringArray.html" title="type arrow_array::array::string_array::GenericStringArray"><code>GenericStringArray</code></a> from a <a href="binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::Ge [...]
 an error if <a href="binary_array/type.GenericBinaryArray.html" title="type arrow_array::array::binary_array::GenericBinaryArray"><code>GenericBinaryArray</code></a> contains invalid UTF-8 data</p>
-</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-From%3CGenericByteArray%3CGenericBinaryType%3COffsetSize%3E%3E%3E-for-GenericStringArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.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-From%3CGenericByteArray%3CGenericBinaryType%3COffsetSize%3E%3E%3E-for-GenericStringArray%3COffsetSize%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_array/array/string_array.rs.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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details></div></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_array/array/union_array/struct.UnionArray.html b/arrow_array/array/union_array/struct.UnionArray.html
index 668109630..775d95310 100644
--- a/arrow_array/array/union_array/struct.UnionArray.html
+++ b/arrow_array/array/union_array/struct.UnionArray.html
@@ -129,12 +129,12 @@ To check validity correctly you must check the underlying vector.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.null_count" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#435-437">source</a><a href="#method.null_count" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#method.null_count" class="fn">null_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</ [...]
 To get null count correctly you must check the underlying vector.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_any" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#385-387">source</a><a href="#method.as_any" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.as_any" class="fn">as_any</a>(&amp;self) -&gt; &amp;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/any/trait.Any.html" title="trait core [...]
-downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#389-391">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; <a c [...]
+downcasted to a specific implementation. <a href="../trait.Array.html#tymethod.as_any">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.to_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#389-391">source</a><a href="#method.to_data" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.to_data" class="fn">to_data</a>(&amp;self) -&gt; Arra [...]
 Note that the underlying data can be shared by many arrays.
 This defaults to <code>0</code>. <a href="../trait.Array.html#tymethod.offset">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.nulls" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#417-419">source</a><a href="#method.nulls" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.nulls" class="fn">nulls</a>(&amp;self) -&gt; <a class="enum" href [...]
 The buffers store bytes in the Arrow memory format, and include the data as well as the validity map.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#451-463">source</a><a href="#method.get_array_memory_size" class="anchor">§</a><h4 class="code-header">fn <a href="../trait.Array.html#tymethod.get_array_memory_size" c [...]
 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></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-UnionArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#109">source</a><a href="#impl-Clone-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/ [...]
+includes the overhead of the data structures that contain the pointers to the various buffers.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Clone-for-UnionArray" class="impl"><a class="srclink rightside" href="../../../src/arrow_array/array/union_array.rs.html#109">source</a><a href="#impl-Clone-for-UnionArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/clone/ [...]
     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-1" class="method trait-impl"><a class="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id-1" class="anchor">§</a><h4 class="code-header">f [...]
     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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_array/cast/fn.downcast_array.html b/arrow_array/cast/fn.downcast_array.html
index b3a966f71..b6516be13 100644
--- a/arrow_array/cast/fn.downcast_array.html
+++ b/arrow_array/cast/fn.downcast_array.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Downcasts a `dyn Array` to a concrete type"><title>downcast_array in arrow_array::cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" cross [...]
-    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="../../arrow_data/data/struct.ArrayData.html" title="struct arrow_data::data::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>
+    T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.From.html" title="trait core::convert::From">From</a>&lt;ArrayData&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 {
     col1: Int32Array,
diff --git a/arrow_array/index.html b/arrow_array/index.html
index cdec19148..288ca961d 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="The central type in Apache Arrow are arrays, which are a known-length sequence of values all having the same type. This crate provides concrete implementations of each type, as well as an `Array` trait that can be used for type-erasure."><title>arrow_array - Rust</title><link rel="preloa [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="The central type in Apache Arrow are arrays, which are a known-length sequence of values all having the same type. This crate provides concrete implementations of each type, as well as an `Array` trait that can be used for type-erasure."><title>arrow_array - Rust</title><link rel="preloa [...]
 all having the same type. This crate provides concrete implementations of each type, as
 well as an <a href="array/trait.Array.html" title="trait arrow_array::array::Array"><code>Array</code></a> trait that can be used for type-erasure.</p>
 <h2 id="building-an-array"><a href="#building-an-array">Building an Array</a></h2>
diff --git a/arrow_array/record_batch/struct.RecordBatch.html b/arrow_array/record_batch/struct.RecordBatch.html
index 801df9c47..af09d138d 100644
--- a/arrow_array/record_batch/struct.RecordBatch.html
+++ b/arrow_array/record_batch/struct.RecordBatch.html
@@ -125,7 +125,7 @@ testing.</p>
   (<span class="string">&quot;b&quot;</span>, b, <span class="bool-val">true</span>),
 ]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method"><a class="srclink rightside" href="../../src/arrow_array/record_batch.rs.html#434-439">source</a><h4 class="code-header">pub fn <a href="#method.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock">< [...]
-</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-RecordBatch" class="impl"><a class="srclink rightside" href="../../src/arrow_array/record_batch.rs.html#65">source</a><a href="#impl-Clone-for-RecordBatch" class="anchor">§</a><h3 class="code- [...]
+</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-RecordBatch" class="impl"><a class="srclink rightside" href="../../src/arrow_array/record_batch.rs.html#65">source</a><a href="#impl-Clone-for-RecordBatch" class="anchor">§</a><h3 class="code- [...]
 <h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
 <p>Panics if the name is not in the schema.</p>
 </div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/index/trait.Index.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" hr [...]
diff --git a/arrow_array/struct.RecordBatch.html b/arrow_array/struct.RecordBatch.html
index 1d4e9f059..65abd09ad 100644
--- a/arrow_array/struct.RecordBatch.html
+++ b/arrow_array/struct.RecordBatch.html
@@ -125,7 +125,7 @@ testing.</p>
   (<span class="string">&quot;b&quot;</span>, b, <span class="bool-val">true</span>),
 ]);</code></pre></div>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.get_array_memory_size" class="method"><a class="srclink rightside" href="../src/arrow_array/record_batch.rs.html#434-439">source</a><h4 class="code-header">pub fn <a href="#method.get_array_memory_size" class="fn">get_array_memory_size</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>R [...]
-</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-RecordBatch" class="impl"><a class="srclink rightside" href="../src/arrow_array/record_batch.rs.html#65">source</a><a href="#impl-Clone-for-RecordBatch" class="anchor">§</a><h3 class="code-hea [...]
+</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-RecordBatch" class="impl"><a class="srclink rightside" href="../src/arrow_array/record_batch.rs.html#65">source</a><a href="#impl-Clone-for-RecordBatch" class="anchor">§</a><h3 class="code-hea [...]
 <h5 id="panics-2"><a href="#panics-2">Panics</a></h5>
 <p>Panics if the name is not in the schema.</p>
 </div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/index/trait.Index.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;dyn <a class="trait" hr [...]
diff --git a/arrow_array/trait.ArrowNativeTypeOp.html b/arrow_array/trait.ArrowNativeTypeOp.html
index 2924cafee..5517f1b11 100644
--- a/arrow_array/trait.ArrowNativeTypeOp.html
+++ b/arrow_array/trait.ArrowNativeTypeOp.html
@@ -63,4 +63,4 @@ point values are compared as per IEEE 754’s totalOrder predicate see <a href="
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_le" class="method"><a class="srclink rightside" href="../src/arrow_array/arithmetic.rs.html#113-115">source</a><h4 class="code-header">fn <a href="#method.is_le" class="fn">is_le</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Less than equals operation</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_gt" class="method"><a class="srclink rightside" href="../src/arrow_array/arithmetic.rs.html#119-121">source</a><h4 class="code-header">fn <a href="#method.is_gt" class="fn">is_gt</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Greater than operation</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_ge" class="method"><a class="srclink rightside" href="../src/arrow_array/arithmetic.rs.html#125-127">source</a><h4 class="code-header">fn <a href="#method.is_ge" class="fn">is_ge</a>(self, rhs: Self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Greater than equals operation</p>
-</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-ArrowNativeTypeOp-for-f32" class="impl"><a class="srclink rightside" href="../src/arrow_array/arithmetic.rs.html#381">source</a><a href="#impl-ArrowNativeTypeOp-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="arithmetic/trait.ArrowN [...]
\ No newline at end of file
+</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-ArrowNativeTypeOp-for-u16" class="impl"><a class="srclink rightside" href="../src/arrow_array/arithmetic.rs.html#270">source</a><a href="#impl-ArrowNativeTypeOp-for-u16" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="arithmetic/trait.ArrowN [...]
\ No newline at end of file
diff --git a/arrow_buffer/bigint/struct.ParseI256Error.html b/arrow_buffer/bigint/struct.ParseI256Error.html
index 772b5f80d..14fe28d2d 100644
--- a/arrow_buffer/bigint/struct.ParseI256Error.html
+++ b/arrow_buffer/bigint/struct.ParseI256Error.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="An opaque error similar to `std::num::ParseIntError`"><title>ParseI256Error in arrow_buffer::bigint - Rust</title><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="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-ParseI256Error" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#26">source</a><a href="#impl-Debug-for-ParseI256Error" class="anchor">§</a><h3 class="code-header">impl <a class [...]
+</div></details><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-ParseI256Error" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#26">source</a><a href="#impl-Debug-for-ParseI256Error" class="anchor">§</a><h3 class="code-header">impl <a class [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_buffer/bigint/struct.i256.html b/arrow_buffer/bigint/struct.i256.html
index 64ac2a327..24aa2b9b4 100644
--- a/arrow_buffer/bigint/struct.i256.html
+++ b/arrow_buffer/bigint/struct.i256.html
@@ -46,16 +46,16 @@ This basically implements [Long division]: <code>&lt;https://en.wikipedia.org/wi
 -1 if the number is negative</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_negative" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#594-596">source</a><h4 class="code-header">pub const fn <a href="#method.is_negative" class="fn">is_negative</a>(self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if this  [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_positive" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#599-601">source</a><h4 class="code-header">pub const fn <a href="#method.is_positive" class="fn">is_positive</a>(self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if this  [...]
-</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-Add%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#677">source</a><a href="#impl-Add%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-he [...]
+</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-Add%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#677">source</a><a href="#impl-Add%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-he [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
-    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
+    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the minimum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.min">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.clamp" class="method trait-impl"><span class="rightside"><span class= [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">PartialOrd</a>&lt;Self&gt;,</span></h4></section></summary><div class='docblock'>Restrict a value to a certain interval. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.clamp">Read more</a></div></d [...]
 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="srclink" 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" 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-PartialOrd%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#155-159">source</a><a href="#impl-PartialOrd%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Rem%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#681">source</a><a href="#impl-Rem%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/o [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Rem%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#681">source</a><a href="#impl-Rem%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/o [...]
 represented by an <code>i64</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_u64" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/bigint.rs.html#817-829">source</a><a href="#method.to_u64" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#tymethod.to_u64" class="fn">to_u64</a>(&amp;self) -&gt;  [...]
 represented by a <code>u64</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_isize" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/num-traits/0.2/src/num_traits/cast.rs.html#23">source</a><a href="#method.to_isize" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#method.to_isize" class="fn">to_isize< [...]
 represented by an <code>isize</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_i8" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/num-traits/0.2/src/num_traits/cast.rs.html#30">source</a><a href="#method.to_i8" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#method.to_i8" class="fn">to_i8</a>(&amp; [...]
diff --git a/arrow_buffer/buffer/boolean/struct.BooleanBuffer.html b/arrow_buffer/buffer/boolean/struct.BooleanBuffer.html
index 09ecb9c28..0c7efe0f3 100644
--- a/arrow_buffer/buffer/boolean/struct.BooleanBuffer.html
+++ b/arrow_buffer/buffer/boolean/struct.BooleanBuffer.html
@@ -36,7 +36,7 @@ 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="srclink rightside" href="../../../src/arrow_buffer/buffer/boolean.rs.html#193-195">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_buffer::util::bit_iterator::BitIterator">BitIterator</a>&lt;'_&gt; <a href="#" class="tooltip" d [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_indices" class="method"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/boolean.rs.html#198-200">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_buffer::util::bit_iterator::BitIndexIterator">BitIndexIterator</a>&lt; [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_slices" class="method"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/boolean.rs.html#203-205">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_buffer::util::bit_iterator::BitSliceIterator">BitSliceIterator</a>&lt;'_& [...]
-</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="srclink rightside" href="../../../src/arrow_buffer/buffer/boolean.rs.html#220-237">source</a><a href="#impl-BitAnd%3C%26BooleanB [...]
+</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="srclink rightside" href="../../../src/arrow_buffer/buffer/boolean.rs.html#220-237">source</a><a href="#impl-BitAnd%3C%26BooleanB [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-BooleanBuffer" class="impl"><a class="srclink 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.Boolea [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_buffer/buffer/immutable/struct.Buffer.html b/arrow_buffer/buffer/immutable/struct.Buffer.html
index 116e14970..4df3245c7 100644
--- a/arrow_buffer/buffer/immutable/struct.Buffer.html
+++ b/arrow_buffer/buffer/immutable/struct.Buffer.html
@@ -1161,7 +1161,7 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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="srclink 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 cl [...]
+</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="srclink 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 cl [...]
 allocated memory region.</p>
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/immutable.rs.html#331-338">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>(p: T) -&gt; Self</h4></section></summary><div class='docblock'>Converts  [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/immutable.rs.html#343-348">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; Self<spa [...]
diff --git a/arrow_buffer/buffer/mutable/struct.MutableBuffer.html b/arrow_buffer/buffer/mutable/struct.MutableBuffer.html
index 2efbd98d8..0c631cd72 100644
--- a/arrow_buffer/buffer/mutable/struct.MutableBuffer.html
+++ b/arrow_buffer/buffer/mutable/struct.MutableBuffer.html
@@ -2478,7 +2478,7 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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-Debug-for-MutableBuffer" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/mutable.rs.html#53">source</a><a href="#impl-Debug-for-MutableBuffer" class="anchor">§</a><h3 class="code-header [...]
+</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-Debug-for-MutableBuffer" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/mutable.rs.html#53">source</a><a href="#impl-Debug-for-MutableBuffer" class="anchor">§</a><h3 class="code-header [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/mutable.rs.html#708-758">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; Self<span clas [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="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="srclink" 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" cl [...]
diff --git a/arrow_buffer/buffer/scalar/struct.ScalarBuffer.html b/arrow_buffer/buffer/scalar/struct.ScalarBuffer.html
index d6baf9632..fdb814f59 100644
--- a/arrow_buffer/buffer/scalar/struct.ScalarBuffer.html
+++ b/arrow_buffer/buffer/scalar/struct.ScalarBuffer.html
@@ -1087,14 +1087,14 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#106-111">source</a><a href="#impl-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E"  [...]
+</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-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#106-111">source</a><a href="#impl-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E"  [...]
+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="srclink" 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 [...]
+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="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#176-180">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../../native/t [...]
+by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-3" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
+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;+N%5D" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#170-174">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT;+N%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../../na [...]
 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="srclink" 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" 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="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#176-180">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../../native/t [...]
+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-Vec%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#182-186">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-Vec%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../../na [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
-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;+N%5D" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#170-174">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT;+N%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../../na [...]
-by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-3" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
-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-Vec%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/buffer/scalar.rs.html#182-186">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-Vec%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../../na [...]
-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="srclink" 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 [...]
 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_buffer/buffer/struct.BooleanBuffer.html b/arrow_buffer/buffer/struct.BooleanBuffer.html
index 451741066..f71962820 100644
--- a/arrow_buffer/buffer/struct.BooleanBuffer.html
+++ b/arrow_buffer/buffer/struct.BooleanBuffer.html
@@ -36,7 +36,7 @@ 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="srclink rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#193-195">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_buffer::util::bit_iterator::BitIterator">BitIterator</a>&lt;'_&gt; <a href="#" class="tooltip" data-no [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_indices" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#198-200">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_buffer::util::bit_iterator::BitIndexIterator">BitIndexIterator</a>&lt;'_&gt; [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_slices" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#203-205">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_buffer::util::bit_iterator::BitSliceIterator">BitSliceIterator</a>&lt;'_&gt; <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-BitAnd%3C%26BooleanBuffer%3E-for-%26BooleanBuffer" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#220-237">source</a><a href="#impl-BitAnd%3C%26BooleanBuff [...]
+</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="srclink rightside" href="../../src/arrow_buffer/buffer/boolean.rs.html#220-237">source</a><a href="#impl-BitAnd%3C%26BooleanBuff [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-BooleanBuffer" class="impl"><a class="srclink 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="boolean/struct.B [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_buffer/buffer/struct.Buffer.html b/arrow_buffer/buffer/struct.Buffer.html
index 0b96997b2..8408c6bfd 100644
--- a/arrow_buffer/buffer/struct.Buffer.html
+++ b/arrow_buffer/buffer/struct.Buffer.html
@@ -1161,7 +1161,7 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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="srclink 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 [...]
+</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="srclink 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 [...]
 allocated memory region.</p>
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/immutable.rs.html#331-338">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>(p: T) -&gt; Self</h4></section></summary><div class='docblock'>Converts to  [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/immutable.rs.html#343-348">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; Self<span c [...]
diff --git a/arrow_buffer/buffer/struct.MutableBuffer.html b/arrow_buffer/buffer/struct.MutableBuffer.html
index 5e95b3605..d6d121ddc 100644
--- a/arrow_buffer/buffer/struct.MutableBuffer.html
+++ b/arrow_buffer/buffer/struct.MutableBuffer.html
@@ -2478,7 +2478,7 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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-Debug-for-MutableBuffer" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#53">source</a><a href="#impl-Debug-for-MutableBuffer" class="anchor">§</a><h3 class="code-header">i [...]
+</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-Debug-for-MutableBuffer" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#53">source</a><a href="#impl-Debug-for-MutableBuffer" class="anchor">§</a><h3 class="code-header">i [...]
 </div><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.from_iter" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/mutable.rs.html#708-758">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; Self<span class=" [...]
     I: <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html" title="trait core::iter::traits::collect::IntoIterator">IntoIterator</a>&lt;Item = <a class="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="srclink" 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" cl [...]
diff --git a/arrow_buffer/buffer/struct.ScalarBuffer.html b/arrow_buffer/buffer/struct.ScalarBuffer.html
index 76322c5cb..29a9025ba 100644
--- a/arrow_buffer/buffer/struct.ScalarBuffer.html
+++ b/arrow_buffer/buffer/struct.ScalarBuffer.html
@@ -1087,14 +1087,14 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#106-111">source</a><a href="#impl-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E" cla [...]
+</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-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#106-111">source</a><a href="#impl-AsRef%3C%5BT%5D%3E-for-ScalarBuffer%3CT%3E" cla [...]
+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="srclink" 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 [...]
+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="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#176-180">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../native/trait.A [...]
+by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-3" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
+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;+N%5D" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#170-174">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT;+N%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../native/t [...]
 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="srclink" 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" 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="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#176-180">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../native/trait.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-PartialEq%3CScalarBuffer%3CT%3E%3E-for-Vec%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#182-186">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-Vec%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../native/t [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
-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;+N%5D" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#170-174">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-%5BT;+N%5D" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../native/t [...]
-by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-3" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-3" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
-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-Vec%3CT%3E" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/buffer/scalar.rs.html#182-186">source</a><a href="#impl-PartialEq%3CScalarBuffer%3CT%3E%3E-for-Vec%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="../native/t [...]
-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="srclink" 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 [...]
 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_buffer/builder/boolean/struct.BooleanBufferBuilder.html b/arrow_buffer/builder/boolean/struct.BooleanBufferBuilder.html
index 1b240730a..30b6468ca 100644
--- a/arrow_buffer/builder/boolean/struct.BooleanBufferBuilder.html
+++ b/arrow_buffer/builder/boolean/struct.BooleanBufferBuilder.html
@@ -28,7 +28,7 @@ growing it (potentially reallocating it) and writing <code>false</code> in the n
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><a class="srclink rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#212-214">source</a><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;mut [u8] [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="srclink rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#218-222">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../../buffer/boolean/struct.BooleanBuffer.html" title="struct arrow_buffer::buffer::boolean::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="srclink rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#225-227">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../../buffer/boolean/struct.BooleanBuffer.html" title="struct arrow_buffer::buffer::boolean::BooleanBuffer">BooleanBuffer</a></h4></secti [...]
-</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-Debug-for-BooleanBufferBuilder" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anch [...]
+</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-Debug-for-BooleanBufferBuilder" class="impl"><a class="srclink rightside" href="../../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anch [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_buffer/builder/struct.BooleanBufferBuilder.html b/arrow_buffer/builder/struct.BooleanBufferBuilder.html
index 223c921c3..6f9dbeda2 100644
--- a/arrow_buffer/builder/struct.BooleanBufferBuilder.html
+++ b/arrow_buffer/builder/struct.BooleanBufferBuilder.html
@@ -28,7 +28,7 @@ growing it (potentially reallocating it) and writing <code>false</code> in the n
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_slice_mut" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#212-214">source</a><h4 class="code-header">pub fn <a href="#method.as_slice_mut" class="fn">as_slice_mut</a>(&amp;mut self) -&gt; &amp;mut [<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;mut [u8]">ⓘ [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#218-222">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(&amp;mut self) -&gt; <a class="struct" href="../buffer/boolean/struct.BooleanBuffer.html" title="struct arrow_buffer::buffer::boolean::BooleanBuffer">BooleanBuffer</a></h4></section></summary><div class [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish_cloned" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#225-227">source</a><h4 class="code-header">pub fn <a href="#method.finish_cloned" class="fn">finish_cloned</a>(&amp;self) -&gt; <a class="struct" href="../buffer/boolean/struct.BooleanBuffer.html" title="struct arrow_buffer::buffer::boolean::BooleanBuffer">BooleanBuffer</a></h4></section></s [...]
-</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-Debug-for-BooleanBufferBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anchor" [...]
+</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-Debug-for-BooleanBufferBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/builder/boolean.rs.html#22">source</a><a href="#impl-Debug-for-BooleanBufferBuilder" class="anchor" [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_buffer/index.html b/arrow_buffer/index.html
index 9204c5038..979802d8c 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="Low-level buffer abstractions for Apache Arrow Rust"><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="../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="Low-level buffer abstractions for Apache Arrow Rust"><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="../s [...]
 </div></details><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name"><code>pub use <a class="mod" href="buffer/index.html" title="mod arrow_buffer::buffer">buffer</a>::*;</code></div></li><li><div class="item-name"><code>pub use <a class="mod" href="builder/index.html" title="mod arrow_buffer::builder">builder</a>::*;</code></div></li></ul><h2 id="modules" class="small-section-header"><a href="#modules"> [...]
 how to de-allocate itself, <a href="bytes/struct.Bytes.html" title="struct arrow_buffer::bytes::Bytes"><code>Bytes</code></a>.
 Note that this is a low-level functionality of this crate.</div></li><li><div class="item-name"><a class="mod" href="native/index.html" title="mod arrow_buffer::native">native</a><span title="Restricted Visibility">&nbsp;🔒</span> </div></li><li><div class="item-name"><a class="mod" href="util/index.html" title="mod arrow_buffer::util">util</a><span title="Restricted Visibility">&nbsp;🔒</span> </div></li></ul><h2 id="structs" class="small-section-header"><a href="#structs">Structs</a></h2 [...]
diff --git a/arrow_buffer/native/private/trait.Sealed.html b/arrow_buffer/native/private/trait.Sealed.html
index 22fb4c240..ef0140fde 100644
--- a/arrow_buffer/native/private/trait.Sealed.html
+++ b/arrow_buffer/native/private/trait.Sealed.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 `Sealed` trait in crate `arrow_buffer`."><title>Sealed in arrow_buffer::native::private - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload [...]
\ 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 `Sealed` trait in crate `arrow_buffer`."><title>Sealed in arrow_buffer::native::private - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload [...]
\ No newline at end of file
diff --git a/arrow_buffer/native/trait.ArrowNativeType.html b/arrow_buffer/native/trait.ArrowNativeType.html
index 12dddb54f..61edb77e1 100644
--- a/arrow_buffer/native/trait.ArrowNativeType.html
+++ b/arrow_buffer/native/trait.ArrowNativeType.html
@@ -42,4 +42,4 @@ in truncation/overflow</p>
 <p>Returns <code>None</code> if <a href="trait.ArrowNativeType.html" title="trait arrow_buffer::native::ArrowNativeType"><code>Self</code></a> is not <code>i64</code></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.from_i128" class="method"><a class="srclink rightside" href="../../src/arrow_buffer/native.rs.html#98-100">source</a><h4 class="code-header">fn <a href="#method.from_i128" class="fn">from_i128</a>(_: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core [...]
 <p>Returns <code>None</code> if <a href="trait.ArrowNativeType.html" title="trait arrow_buffer::native::ArrowNativeType"><code>Self</code></a> is not <code>i128</code></p>
-</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-ArrowNativeType-for-f32" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/native.rs.html#186">source</a><a href="#impl-ArrowNativeType-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeType.html" [...]
\ No newline at end of file
+</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-ArrowNativeType-for-f64" class="impl"><a class="srclink rightside" href="../../src/arrow_buffer/native.rs.html#187">source</a><a href="#impl-ArrowNativeType-for-f64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ArrowNativeType.html" [...]
\ No newline at end of file
diff --git a/arrow_buffer/struct.i256.html b/arrow_buffer/struct.i256.html
index 7600c76fc..8b0b53002 100644
--- a/arrow_buffer/struct.i256.html
+++ b/arrow_buffer/struct.i256.html
@@ -46,16 +46,16 @@ This basically implements [Long division]: <code>&lt;https://en.wikipedia.org/wi
 -1 if the number is negative</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_negative" class="method"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#594-596">source</a><h4 class="code-header">pub const fn <a href="#method.is_negative" class="fn">is_negative</a>(self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if this <a  [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.is_positive" class="method"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#599-601">source</a><h4 class="code-header">pub const fn <a href="#method.is_positive" class="fn">is_positive</a>(self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.bool.html">bool</a></h4></section></summary><div class="docblock"><p>Returns <code>true</code> if this <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-Add%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#677">source</a><a href="#impl-Add%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-heade [...]
+</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-Add%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#677">source</a><a href="#impl-Add%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-heade [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
-    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
+    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the minimum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.min">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.clamp" class="method trait-impl"><span class="rightside"><span class= [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">PartialOrd</a>&lt;Self&gt;,</span></h4></section></summary><div class='docblock'>Restrict a value to a certain interval. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.clamp">Read more</a></div></d [...]
 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="srclink" 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" 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-PartialOrd%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#155-159">source</a><a href="#impl-PartialOrd%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" t [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Rem%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#681">source</a><a href="#impl-Rem%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/ [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Rem%3Ci256%3E-for-i256" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#681">source</a><a href="#impl-Rem%3Ci256%3E-for-i256" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/ops/ [...]
 represented by an <code>i64</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_u64" class="method trait-impl"><a class="srclink rightside" href="../src/arrow_buffer/bigint.rs.html#817-829">source</a><a href="#method.to_u64" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#tymethod.to_u64" class="fn">to_u64</a>(&amp;self) -&gt; <a  [...]
 represented by a <code>u64</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_isize" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/num-traits/0.2/src/num_traits/cast.rs.html#23">source</a><a href="#method.to_isize" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#method.to_isize" class="fn">to_isize< [...]
 represented by an <code>isize</code>, then <code>None</code> is returned.</div></details><details class="toggle method-toggle" open><summary><section id="method.to_i8" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/num-traits/0.2/src/num_traits/cast.rs.html#30">source</a><a href="#method.to_i8" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/num-traits/0.2/num_traits/cast/trait.ToPrimitive.html#method.to_i8" class="fn">to_i8</a>(&amp; [...]
diff --git a/arrow_buffer/trait.ArrowNativeType.html b/arrow_buffer/trait.ArrowNativeType.html
index e764fa005..5bad2a1cf 100644
--- a/arrow_buffer/trait.ArrowNativeType.html
+++ b/arrow_buffer/trait.ArrowNativeType.html
@@ -42,4 +42,4 @@ in truncation/overflow</p>
 <p>Returns <code>None</code> if <a href="native/trait.ArrowNativeType.html" title="trait arrow_buffer::native::ArrowNativeType"><code>Self</code></a> is not <code>i64</code></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.from_i128" class="method"><a class="srclink rightside" href="../src/arrow_buffer/native.rs.html#98-100">source</a><h4 class="code-header">fn <a href="#method.from_i128" class="fn">from_i128</a>(_: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i128.html">i128</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::o [...]
 <p>Returns <code>None</code> if <a href="native/trait.ArrowNativeType.html" title="trait arrow_buffer::native::ArrowNativeType"><code>Self</code></a> is not <code>i128</code></p>
-</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-ArrowNativeType-for-f32" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/native.rs.html#186">source</a><a href="#impl-ArrowNativeType-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="native/trait.ArrowNativeType.h [...]
\ No newline at end of file
+</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-ArrowNativeType-for-f64" class="impl"><a class="srclink rightside" href="../src/arrow_buffer/native.rs.html#187">source</a><a href="#impl-ArrowNativeType-for-f64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="native/trait.ArrowNativeType.h [...]
\ No newline at end of file
diff --git a/arrow_cast/display/enum.FormatError.html b/arrow_cast/display/enum.FormatError.html
index 1708759ec..dd96c5313 100644
--- a/arrow_cast/display/enum.FormatError.html
+++ b/arrow_cast/display/enum.FormatError.html
@@ -2,7 +2,7 @@
     Format(<a class="struct" href="https://doc.rust-lang.org/nightly/core/fmt/struct.Error.html" title="struct core::fmt::Error">Error</a>),
     Arrow(ArrowError),
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Either an [<code>ArrowError</code>] or <a href="https://doc.rust-lang.org/nightly/core/fmt/struct.Error.html" title="struct core::fmt::Error"><code>std::fmt::Error</code></a></p>
-</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.Format" class="variant"><a href="#variant.Format" class="anchor">§</a><h3 class="code-header">Format(<a class="struct" href="https://doc.rust-lang.org/nightly/core/fmt/struct.Error.html" title="struct core::fmt::Error">Error</a>)</h3></section><section id="variant.Arrow" class="variant"><a href="#variant.Arrow" class="anch [...]
+</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.Format" class="variant"><a href="#variant.Format" class="anchor">§</a><h3 class="code-header">Format(<a class="struct" href="https://doc.rust-lang.org/nightly/core/fmt/struct.Error.html" title="struct core::fmt::Error">Error</a>)</h3></section><section id="variant.Arrow" class="variant"><a href="#variant.Arrow" class="anch [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_cast/display/trait.DisplayIndex.html b/arrow_cast/display/trait.DisplayIndex.html
index 5ffd355e4..d341c4a00 100644
--- a/arrow_cast/display/trait.DisplayIndex.html
+++ b/arrow_cast/display/trait.DisplayIndex.html
@@ -2,4 +2,4 @@
     // Required method
     fn <a href="#tymethod.write" class="fn">write</a>(&amp;self, idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rus [...]
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p><a href="https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html" title="trait core::fmt::Display"><code>Display</code></a> but accepting an index</p>
-</div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.write" class="method"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#308">source</a><h4 class="code-header">fn <a href="#tymethod.write" class="fn">write</a>(&amp;self, idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, f: &amp;mut  [...]
\ No newline at end of file
+</div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.write" class="method"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#308">source</a><h4 class="code-header">fn <a href="#tymethod.write" class="fn">write</a>(&amp;self, idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>, f: &amp;mut  [...]
\ No newline at end of file
diff --git a/arrow_cast/display/trait.DisplayIndexState.html b/arrow_cast/display/trait.DisplayIndexState.html
index 1aedeaee0..28197f37e 100644
--- a/arrow_cast/display/trait.DisplayIndexState.html
+++ b/arrow_cast/display/trait.DisplayIndexState.html
@@ -21,47 +21,47 @@
     state: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div><h2 id="foreign-impls" class="small-section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§ [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div><h2 id="foreign-impls" class="small-section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§ [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#671-674">source</a><a href="#method.w [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#772-794">source</a><a href="#method.w [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+FixedSiz [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#531">source</a><a href="#method.wri [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-1" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#718-722">source</a><a href="#method [...]
     &amp;self,
-    fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
+    s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Dictiona [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#534">source</a><a href="#method.wri [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-2" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#671-674">source</a><a href="#method [...]
     &amp;self,
-    fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
+    s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+UnionArr [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
-    options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-3" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#818-830">source</a><a href="#method [...]
+    _options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-3" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#425">source</a><a href="#method.wri [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+GenericL [...]
     &amp;self,
-    _options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-4" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#425">source</a><a href="#method.wri [...]
+    options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-4" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#701-706">source</a><a href="#method [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-5" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#480-485">source</a><a href="#method [...]
@@ -69,10 +69,10 @@
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-6" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#529">source</a><a href="#method.wri [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-6" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#532">source</a><a href="#method.wri [...]
     &amp;self,
     fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
@@ -85,63 +85,63 @@
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+MapArray [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+StructAr [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-8" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#772-794">source</a><a href="#method [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-8" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#747-760">source</a><a href="#method [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+GenericL [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-9" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#701-706">source</a><a href="#method [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-9" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#480-485">source</a><a href="#method [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-10" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#533">source</a><a href="#method.wr [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-10" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#529">source</a><a href="#method.wr [...]
     &amp;self,
     fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+FixedSiz [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-11" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#718-722">source</a><a href="#metho [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-11" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#480-485">source</a><a href="#metho [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+StructAr [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+UnionArr [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-12" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#747-760">source</a><a href="#metho [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-12" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#818-830">source</a><a href="#metho [...]
     &amp;self,
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-13" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#530">source</a><a href="#method.wr [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-13" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#534">source</a><a href="#method.wr [...]
     &amp;self,
     fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-14" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#480-485">source</a><a href="#metho [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-14" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#533">source</a><a href="#method.wr [...]
     &amp;self,
-    s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
+    fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     _options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-15" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#425">source</a><a href="#method.wr [...]
@@ -149,20 +149,20 @@
     s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-16" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#532">source</a><a href="#method.wr [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-16" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#531">source</a><a href="#method.wr [...]
     &amp;self,
     fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-DisplayIndexState%3C'a%3E-for-%26'a+Primitiv [...]
     &amp;self,
     options: &amp;<a class="struct" href="struct.FormatOptions.html" title="struct arrow_cast::display::FormatOptions">FormatOptions</a>&lt;'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;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-17" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#480-485">source</a><a href="#metho [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>, ArrowError&gt;</h4></section><section id="method.write-17" class="method trait-impl"><a class="srclink rightside" href="../../src/arrow_cast/display.rs.html#530">source</a><a href="#method.wr [...]
     &amp;self,
-    s: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
+    fmt: &amp;Self::<a class="associatedtype" href="trait.DisplayIndexState.html#associatedtype.State" title="type arrow_cast::display::DisplayIndexState::State">State</a>,
     idx: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
     f: &amp;mut dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Write.html" title="trait core::fmt::Write">Write</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="enum" href="enum.FormatError.html" title="enum arrow_cast::display::FormatError">FormatError</a>&gt;</h4></section></div></details><h2 id="implementors" class="small-section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><di [...]
\ No newline at end of file
diff --git a/arrow_cast/index.html b/arrow_cast/index.html
index d57f5b2a4..b02e17907 100644
--- a/arrow_cast/index.html
+++ b/arrow_cast/index.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Cast kernel for Apache Arrow"><title>arrow_cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/FiraSans-Regu [...]
+<!DOCTYPE html><html lang="en"><head><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 kernel for Apache Arrow"><title>arrow_cast - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/FiraSans-Regu [...]
 </div></details><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name"><code>pub use <a class="mod" href="cast/index.html" title="mod arrow_cast::cast">cast</a>::*;</code></div></li></ul><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="cast/index.html" title="mod arrow_cast::cast">cast</a></div><div class [...]
 supported datatypes.</div></li><li><div class="item-name"><a class="mod" href="display/index.html" title="mod arrow_cast::display">display</a></div><div class="desc docblock-short">Functions for printing array values, as strings, for debugging
 purposes. See the <code>pretty</code> crate for additional functions for
diff --git a/arrow_cast/parse/trait.Parser.html b/arrow_cast/parse/trait.Parser.html
index dc6855e6a..5f3c12788 100644
--- a/arrow_cast/parse/trait.Parser.html
+++ b/arrow_cast/parse/trait.Parser.html
@@ -6,4 +6,4 @@
     fn <a href="#method.parse_formatted" class="fn">parse_formatted</a>(string: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>, _format: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;Self::Native&gt; { ... }
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Specialized parsing implementations
 used by csv and json reader</p>
-</div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.parse" class="method"><a class="srclink rightside" href="../../src/arrow_cast/parse.rs.html#433">source</a><h4 class="code-header">fn <a href="#tymethod.parse" class="fn">parse</a>(string: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" [...]
\ No newline at end of file
+</div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.parse" class="method"><a class="srclink rightside" href="../../src/arrow_cast/parse.rs.html#433">source</a><h4 class="code-header">fn <a href="#tymethod.parse" class="fn">parse</a>(string: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>) -&gt; <a class="enum" [...]
\ No newline at end of file
diff --git a/arrow_csv/index.html b/arrow_csv/index.html
index 772e0f773..3ee4b16f6 100644
--- a/arrow_csv/index.html
+++ b/arrow_csv/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="Transfer data between the Arrow memory format and CSV (comma-separated values)."><title>arrow_csv - Rust</title><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="Transfer data between the Arrow memory format and CSV (comma-separated values)."><title>arrow_csv - Rust</title><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><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name" id="reexport.infer_schema_from_files"><code>pub use self::reader::<a class="fn" href="reader/fn.infer_schema_from_files.html" title="fn arrow_csv::reader::infer_schema_from_files">infer_schema_from_files</a>;</code></div></li><li><div class="item-name" id="reexport.Reader"><code>pub use self::reader::<a class="type" href="reader/type.Re [...]
\ No newline at end of file
diff --git a/arrow_data/index.html b/arrow_data/index.html
index 76352f3e7..a9f0cef48 100644
--- a/arrow_data/index.html
+++ b/arrow_data/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="Low-level array data abstractions for Apache Arrow Rust"><title>arrow_data - Rust</title><link rel="preload" 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="Low-level array data abstractions for Apache Arrow Rust"><title>arrow_data - Rust</title><link rel="preload" 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>For a higher-level, strongly-typed interface see <a href="https://docs.rs/arrow_array">arrow_array</a></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="bit_iterator/index.html" title="mod arrow_data::bit_iterator">bit_iterator</a></div><div class="desc docblock-short">Types for iterating over packed bitmasks</div></li><li><div class="item-name"><a class="mod" href="bit_mask/index.html" title="mod arrow_data::bit_mask">bit_mask</a></div><div class="desc docblock-short">Uti [...]
 common attributes and operations for Arrow array.</div></li><li><div class="item-name"><a class="mod" href="decimal/index.html" title="mod arrow_data::decimal">decimal</a></div></li><li><div class="item-name"><a class="mod" href="equal/index.html" title="mod arrow_data::equal">equal</a><span title="Restricted Visibility">&nbsp;🔒</span> </div><div class="desc docblock-short">Module containing functionality to compute array equality.
diff --git a/arrow_file_to_stream/index.html b/arrow_file_to_stream/index.html
index 34a67b9cd..ca23a8c7a 100644
--- a/arrow_file_to_stream/index.html
+++ b/arrow_file_to_stream/index.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 `arrow_file_to_stream` crate."><title>arrow_file_to_stream - Rust</title><link 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 [...]
\ 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 `arrow_file_to_stream` crate."><title>arrow_file_to_stream - Rust</title><link 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 [...]
\ No newline at end of file
diff --git a/arrow_flight/error/enum.FlightError.html b/arrow_flight/error/enum.FlightError.html
index c1e16b341..95bac1cd5 100644
--- a/arrow_flight/error/enum.FlightError.html
+++ b/arrow_flight/error/enum.FlightError.html
@@ -13,7 +13,7 @@
 </div><section id="variant.DecodeError" class="variant"><a href="#variant.DecodeError" class="anchor">§</a><h3 class="code-header">DecodeError(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>)</h3></section><div class="docblock"><p>An error occurred during decoding</p>
 </div><section id="variant.ExternalError" class="variant"><a href="#variant.ExternalError" class="anchor">§</a><h3 class="code-header">ExternalError(<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/error/trait.Error.html" title="trait core::error::Error">Error</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Se [...]
 </div></div><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="implementations-list"><details class="toggle implementors-toggle" open><summary><section id="impl-FlightError" class="impl"><a class="srclink rightside" href="../../src/arrow_flight/error.rs.html#39-48">source</a><a href="#impl-FlightError" class="anchor">§</a><h3 class="code-header">impl <a class="enum" href="enum.FlightError.html" title="enum arr [...]
-</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-Debug-for-FlightError" class="impl"><a class="srclink rightside" href="../../src/arrow_flight/error.rs.html#23">source</a><a href="#impl-Debug-for-FlightError" 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-Debug-for-FlightError" class="impl"><a class="srclink rightside" href="../../src/arrow_flight/error.rs.html#23">source</a><a href="#impl-Debug-for-FlightError" class="anchor">§</a><h3 class="code-header [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_flight/gen/struct.Location.html b/arrow_flight/gen/struct.Location.html
index 79b1aa9ff..a5284961d 100644
--- a/arrow_flight/gen/struct.Location.html
+++ b/arrow_flight/gen/struct.Location.html
@@ -2,7 +2,7 @@
     pub uri: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A location where a Flight service will accept retrieval of a particular
 stream given a ticket.</p>
-</div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.uri" class="structfield small-section-header"><a href="#structfield.uri" class="anchor field">§</a><code>uri: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><h2 id="trait-implementations" class="small-section-header">Trait Implementations<a href="# [...]
+</div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.uri" class="structfield small-section-header"><a href="#structfield.uri" class="anchor field">§</a><code>uri: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><h2 id="trait-implementations" class="small-section-header">Trait Implementations<a href="# [...]
     B: BufMut,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Encodes the message to a buffer. <a href="https://docs.rs/prost/0.11.9/prost/message/trait.Message.html#method.encode">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.encode_to_vec" class="method trait-impl"><a class="srclink rightside" href="h [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Encodes the message to a newly allocated buffer.</div></details><details class="toggle method-toggle" open><summary><section id="method.encode_length_delimited" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/prost/0.11.9/src/prost/message.rs.html#78-81">source</a><a  [...]
diff --git a/arrow_flight/index.html b/arrow_flight/index.html
index 1415779a8..b980f6d23 100644
--- a/arrow_flight/index.html
+++ b/arrow_flight/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="A native Rust implementation of Apache Arrow Flight for exchanging Arrow data between processes."><title>arrow_flight - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="A native Rust implementation of Apache Arrow Flight for exchanging Arrow data between processes."><title>arrow_flight - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="f [...]
 for exchanging <a href="https://arrow.apache.org">Arrow</a> data between processes.</p>
 <p>Please see the <a href="https://crates.io/crates/arrow-flight">arrow-flight crates.io</a>
 page for feature flags and more information.</p>
diff --git a/arrow_flight/sql/metadata/sql_info/enum.SqlInfoValue.html b/arrow_flight/sql/metadata/sql_info/enum.SqlInfoValue.html
index 687e3d155..29f33a953 100644
--- a/arrow_flight/sql/metadata/sql_info/enum.SqlInfoValue.html
+++ b/arrow_flight/sql/metadata/sql_info/enum.SqlInfoValue.html
@@ -6,7 +6,7 @@
     StringList(<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>&gt;),
     ListMap(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/collections/btree/map/struct.BTreeMap.html" title="struct alloc::collections::btree::map::BTreeMap">BTreeMap</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a>, <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32. [...]
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Represents a dynamic value</p>
-</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.String" class="variant"><a href="#variant.String" class="anchor">§</a><h3 class="code-header">String(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>)</h3></section><section id="variant.Bool" class="variant"><a href="#variant.Bool" cl [...]
+</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.String" class="variant"><a href="#variant.String" class="anchor">§</a><h3 class="code-header">String(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>)</h3></section><section id="variant.Bool" class="variant"><a href="#variant.Bool" 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-StructuralPartialEq-for-SqlInfoValue" class="impl"><a class="srclink rightside" href="../../../../src/arrow_flight/sql/metadata/sql_info.rs.html#48">source</a><a href="#impl-StructuralPartialEq-for-SqlInfoValue" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html" title="trait c [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_flight/struct.IpcMessage.html b/arrow_flight/struct.IpcMessage.html
index a7c0eedb8..70ab6bb67 100644
--- a/arrow_flight/struct.IpcMessage.html
+++ b/arrow_flight/struct.IpcMessage.html
@@ -1058,7 +1058,7 @@ is mapped to its ASCII lower case equivalent.</p>
 <p>ASCII letters ‘A’ to ‘Z’ are mapped to ‘a’ to ‘z’,
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
-</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-Debug-for-IpcMessage" class="impl"><a class="srclink rightside" href="../src/arrow_flight/lib.rs.html#128">source</a><a href="#impl-Debug-for-IpcMessage" class="anchor">§</a><h3 class="code-header">impl <a class="trait [...]
+</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-Debug-for-IpcMessage" class="impl"><a class="srclink rightside" href="../src/arrow_flight/lib.rs.html#128">source</a><a href="#impl-Debug-for-IpcMessage" class="anchor">§</a><h3 class="code-header">impl <a class="trait [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_flight/struct.Location.html b/arrow_flight/struct.Location.html
index 0d2cf6fe6..1324c9cd7 100644
--- a/arrow_flight/struct.Location.html
+++ b/arrow_flight/struct.Location.html
@@ -2,7 +2,7 @@
     pub uri: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>A location where a Flight service will accept retrieval of a particular
 stream given a ticket.</p>
-</div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.uri" class="structfield small-section-header"><a href="#structfield.uri" class="anchor field">§</a><code>uri: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><h2 id="trait-implementations" class="small-section-header">Trait Implementations<a href="# [...]
+</div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.uri" class="structfield small-section-header"><a href="#structfield.uri" class="anchor field">§</a><code>uri: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><h2 id="trait-implementations" class="small-section-header">Trait Implementations<a href="# [...]
     B: BufMut,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Encodes the message to a buffer. <a href="https://docs.rs/prost/0.11.9/prost/message/trait.Message.html#method.encode">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.encode_to_vec" class="method trait-impl"><a class="srclink rightside" href="h [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Encodes the message to a newly allocated buffer.</div></details><details class="toggle method-toggle" open><summary><section id="method.encode_length_delimited" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/prost/0.11.9/src/prost/message.rs.html#78-81">source</a><a  [...]
diff --git a/arrow_flight/struct.SchemaAsIpc.html b/arrow_flight/struct.SchemaAsIpc.html
index f0c6f0a51..f92265ada 100644
--- a/arrow_flight/struct.SchemaAsIpc.html
+++ b/arrow_flight/struct.SchemaAsIpc.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="SchemaAsIpc represents a pairing of a `Schema` with IpcWriteOptions"><title>SchemaAsIpc in arrow_flight - Rust</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 [...]
     pub pair: (&amp;'a <a class="struct" href="../arrow_schema/schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a>, &amp;'a <a class="struct" href="../arrow_ipc/writer/struct.IpcWriteOptions.html" title="struct arrow_ipc::writer::IpcWriteOptions">IpcWriteOptions</a>),
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>SchemaAsIpc represents a pairing of a <code>Schema</code> with IpcWriteOptions</p>
-</div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.pair" class="structfield small-section-header"><a href="#structfield.pair" class="anchor field">§</a><code>pair: (&amp;'a <a class="struct" href="../arrow_schema/schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a>, &amp;'a <a class="struct" href="../arrow_ipc/writer/struct.IpcWriteOptions.html" title="struct arrow_ipc::wr [...]
+</div></details><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.pair" class="structfield small-section-header"><a href="#structfield.pair" class="anchor field">§</a><code>pair: (&amp;'a <a class="struct" href="../arrow_schema/schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a>, &amp;'a <a class="struct" href="../arrow_ipc/writer/struct.IpcWriteOptions.html" title="struct arrow_ipc::wr [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_integration_test/index.html b/arrow_integration_test/index.html
index 3e34e05ae..42df8d398 100644
--- a/arrow_integration_test/index.html
+++ b/arrow_integration_test/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="Support for the Apache Arrow JSON test data format"><title>arrow_integration_test - Rust</title><link rel="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="Support for the Apache Arrow JSON test data format"><title>arrow_integration_test - Rust</title><link rel="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 [...]
 <p>These utilities define structs that read the integration JSON format for integration testing purposes.</p>
 <p>This is not a canonical format, but provides a human-readable way of verifying language implementations</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="datatype/index.html" title="mod arrow_integration_test::datatype">datatype</a><span title="Restricted Visibility">&nbsp;🔒</span> </div></li><li><div class="item-name"><a class="mod" href="field/index.html" title="mod arrow_integration_test::field">field</a><span title="Restricted Visibility">&nbsp;🔒</span> </div></li><li>< [...]
\ No newline at end of file
diff --git a/arrow_integration_test/struct.ArrowJsonField.html b/arrow_integration_test/struct.ArrowJsonField.html
index 2496350f3..46cf314c1 100644
--- a/arrow_integration_test/struct.ArrowJsonField.html
+++ b/arrow_integration_test/struct.ArrowJsonField.html
@@ -10,7 +10,7 @@
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_arrow_field" class="method"><a class="srclink rightside" href="../src/arrow_integration_test/lib.rs.html#273-278">source</a><h4 class="code-header">pub(crate) fn <a href="#method.to_arrow_field" class="fn">to_arrow_field</a>(&amp;self) -&gt; Result&lt;<a class="struct" href="../arrow_schema/field/struct.Field.html" title="struct arrow_schema::field::Field">Field</a>&gt;</h4></section></summary><div [...]
 TODO: convert to use an Into</p>
 </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-Debug-for-ArrowJsonField" class="impl"><a class="srclink rightside" href="../src/arrow_integration_test/lib.rs.html#71">source</a><a href="#impl-Debug-for-ArrowJsonField" class="anchor">§</a><h3 class=" [...]
-    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
     __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details></div><h2 id="synthetic-implementations" class="small-section-header">Auto Trait Implementations<a 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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
diff --git a/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/fn.authenticate.html b/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/fn.authenticate.html
index 6d18a273d..91b153bc9 100644
--- a/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/fn.authenticate.html
+++ b/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/fn.authenticate.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `authenticate` fn in crate `arrow_integration_testing`."><title>authenticate in arrow_integration_testing::flight_client_scenarios::auth_basic_proto - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/Source [...]
-    client: &amp;mut FlightServiceClient&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/transport/channel/struct.Channel.html" title="struct tonic::transport::channel::Channel">Channel</a>&gt;,
+    client: &amp;mut <a class="struct" href="../../../arrow_flight/gen/flight_service_client/struct.FlightServiceClient.html" title="struct arrow_flight::gen::flight_service_client::FlightServiceClient">FlightServiceClient</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/transport/channel/struct.Channel.html" title="struct tonic::transport::channel::Channel">Channel</a>&gt;,
     username: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>,
     password: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="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/boxed/struct.Box.html" title="struct alloc::boxed::Box">Box</a>&lt;dyn <a class="trait" href="https://doc.rust-lang.org/nightly/core/error/trait.E [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/type.Client.html b/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/type.Client.html
index a058ac7d3..453a4d63e 100644
--- a/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/type.Client.html
+++ b/arrow_integration_testing/flight_client_scenarios/auth_basic_proto/type.Client.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 `Client` type in crate `arrow_integration_testing`."><title>Client in arrow_integration_testing::flight_client_scenarios::auth_basic_proto - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Reg [...]
\ 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 `Client` type in crate `arrow_integration_testing`."><title>Client in arrow_integration_testing::flight_client_scenarios::auth_basic_proto - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Reg [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.consume_flight_location.html b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.consume_flight_location.html
index a8d2e13a3..092408cb9 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.consume_flight_location.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.consume_flight_location.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `consume_flight_location` fn in crate `arrow_integration_testing`."><title>consume_flight_location in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../ [...]
-    location: Location,
-    ticket: Ticket,
+    location: <a class="struct" href="../../../arrow_flight/gen/struct.Location.html" title="struct arrow_flight::gen::Location">Location</a>,
+    ticket: <a class="struct" href="../../../arrow_flight/gen/struct.Ticket.html" title="struct arrow_flight::gen::Ticket">Ticket</a>,
     expected_data: &amp;[<a class="struct" href="../../../arrow_array/record_batch/struct.RecordBatch.html" title="struct arrow_array::record_batch::RecordBatch">RecordBatch</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="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/error/trait.Error.html" title="trait core::error::Error">Er [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_batch_flight_data.html b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_batch_flight_data.html
index 64e68a5fc..6e85a9abd 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_batch_flight_data.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_batch_flight_data.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `receive_batch_flight_data` fn in crate `arrow_integration_testing`."><title>receive_batch_flight_data in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href=".. [...]
-    resp: &amp;mut <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;,
+    resp: &amp;mut <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;,
     schema: <a class="type" href="../../../arrow_schema/schema/type.SchemaRef.html" title="type arrow_schema::schema::SchemaRef">SchemaRef</a>,
     dictionaries_by_id: &amp;mut <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="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>, <a class="type" href="../../../arrow_array/array/type.ArrayRef.html" title="type arrow_array::array::ArrayRef">ArrayRef</a>&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;FlightData&gt;</code></pre></section></div></main></body></html>
\ No newline at end of file
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;</code></pre></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_schema_flight_data.html b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_schema_flight_data.html
index 2a729c96c..19d668eec 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_schema_flight_data.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.receive_schema_flight_data.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="API documentation for the Rust `receive_schema_flight_data` fn in crate `arrow_integration_testing`."><title>receive_schema_flight_data in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href=" [...]
-    resp: &amp;mut <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;
+    resp: &amp;mut <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&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;<a class="struct" href="../../../arrow_schema/schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a>&gt;</code></pre></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.send_batch.html b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.send_batch.html
index a72fcb764..6f73b376d 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.send_batch.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.send_batch.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `send_batch` fn in crate `arrow_integration_testing`."><title>send_batch in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSeri [...]
-    upload_tx: &amp;mut Sender&lt;FlightData&gt;,
+    upload_tx: &amp;mut Sender&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;,
     metadata: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>],
     batch: &amp;<a class="struct" href="../../../arrow_array/record_batch/struct.RecordBatch.html" title="struct arrow_array::record_batch::RecordBatch">RecordBatch</a>,
     options: &amp;<a class="struct" href="../../../arrow_ipc/writer/struct.IpcWriteOptions.html" title="struct arrow_ipc::writer::IpcWriteOptions">IpcWriteOptions</a>
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.upload_data.html b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.upload_data.html
index 2c4a9f3a0..511d52424 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.upload_data.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.upload_data.html
@@ -1,6 +1,6 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `upload_data` fn in crate `arrow_integration_testing`."><title>upload_data in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSe [...]
-    client: FlightServiceClient&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/transport/channel/struct.Channel.html" title="struct tonic::transport::channel::Channel">Channel</a>&gt;,
+    client: <a class="struct" href="../../../arrow_flight/gen/flight_service_client/struct.FlightServiceClient.html" title="struct arrow_flight::gen::flight_service_client::FlightServiceClient">FlightServiceClient</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/transport/channel/struct.Channel.html" title="struct tonic::transport::channel::Channel">Channel</a>&gt;,
     schema: <a class="type" href="../../../arrow_schema/schema/type.SchemaRef.html" title="type arrow_schema::schema::SchemaRef">SchemaRef</a>,
-    descriptor: FlightDescriptor,
+    descriptor: <a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>,
     original_data: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html" title="struct alloc::vec::Vec">Vec</a>&lt;<a class="struct" href="../../../arrow_array/record_batch/struct.RecordBatch.html" title="struct arrow_array::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="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <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/error/trait.Error.html" title="trait core::error::Error">Er [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.verify_data.html b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.verify_data.html
index 047cee15a..02b2e5107 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/fn.verify_data.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/fn.verify_data.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `verify_data` fn in crate `arrow_integration_testing`."><title>verify_data in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSe [...]
-    client: FlightServiceClient&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/transport/channel/struct.Channel.html" title="struct tonic::transport::channel::Channel">Channel</a>&gt;,
-    descriptor: FlightDescriptor,
+    client: <a class="struct" href="../../../arrow_flight/gen/flight_service_client/struct.FlightServiceClient.html" title="struct arrow_flight::gen::flight_service_client::FlightServiceClient">FlightServiceClient</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/transport/channel/struct.Channel.html" title="struct tonic::transport::channel::Channel">Channel</a>&gt;,
+    descriptor: <a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>,
     expected_data: &amp;[<a class="struct" href="../../../arrow_array/record_batch/struct.RecordBatch.html" title="struct arrow_array::record_batch::RecordBatch">RecordBatch</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="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/error/trait.Error.html" title="trait core::error::Error">Er [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_client_scenarios/integration_test/type.Client.html b/arrow_integration_testing/flight_client_scenarios/integration_test/type.Client.html
index 227f14840..16880985c 100644
--- a/arrow_integration_testing/flight_client_scenarios/integration_test/type.Client.html
+++ b/arrow_integration_testing/flight_client_scenarios/integration_test/type.Client.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 `Client` type in crate `arrow_integration_testing`."><title>Client in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Reg [...]
\ 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 `Client` type in crate `arrow_integration_testing`."><title>Client in arrow_integration_testing::flight_client_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Reg [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html b/arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html
index a281d5975..3ae6bbdd8 100644
--- a/arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html
+++ b/arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html
@@ -8,44 +8,44 @@
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.GrpcServerCallContext.html" title="struct arrow_integration_testing::flight_server_scenarios::auth_basic_proto::GrpcServerCallContext">GrpcServerCallContext</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;</h4></section><secti [...]
     &amp;self,
     token: <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>&gt;
-) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.GrpcServerCallContext.html" title="struct arrow_integration_testing::flight_server_scenarios::auth_basic_proto::GrpcServerCallContext">GrpcServerCallContext</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;</h4></section></div> [...]
+) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="struct.GrpcServerCallContext.html" title="struct arrow_integration_testing::flight_server_scenarios::auth_basic_proto::GrpcServerCallContext">GrpcServerCallContext</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;</h4></section></div> [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;FlightDescriptor&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema
 This is used when a consumer needs the Schema of flight stream. Similar to
 GetFlightInfo this interface may generate a new flight that was not previously
-available in ListFlights.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_get" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#118-124">source</a><a href="#method.do_get" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_get</a>&lt;'life0, 'async_trait&gt;(
+available in ListFlights.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_get" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#118-124">source</a><a href="#method.do_get" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_get" class="fn">do_get</a>&lt;'life0, [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Ticket&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Ticket.html" title="struct arrow_flight::gen::Ticket">Ticket</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Retrieve a single stream associated with a particular descriptor
 associated with the referenced ticket. A Flight can be composed of one or
 more streams where each stream can be retrieved using a separate opaque
-ticket that the flight service uses for managing a collection of streams.</div></details><details class="toggle method-toggle" open><summary><section id="method.handshake" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#126-173">source</a><a href="#method.handshake" class="anchor">§</a><h4 class="code-header">fn <a class="fn">handshake</a>&lt;'life0, 'async_trait&gt;(
+ticket that the flight service uses for managing a collection of streams.</div></details><details class="toggle method-toggle" open><summary><section id="method.handshake" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#126-173">source</a><a href="#method.handshake" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService. [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;HandshakeRequest&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.HandshakeRequest.html" title="struct arrow_flight::gen::HandshakeRequest">HandshakeRequest</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Handshake between client and server. Depending on the server, the
 handshake may be required to determine the token that should be used for
 future operations. Both request and response are streams to allow multiple
-round-trips depending on auth mechanism.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_flights" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#175-181">source</a><a href="#method.list_flights" class="anchor">§</a><h4 class="code-header">fn <a class="fn">list_flights</a>&lt;'life0, 'async_trait&gt;(
+round-trips depending on auth mechanism.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_flights" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#175-181">source</a><a href="#method.list_flights" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.list_flights" [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Criteria&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Criteria.html" title="struct arrow_flight::gen::Criteria">Criteria</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Get a list of available streams given a particular criteria. Most flight
 services will expose one or more streams that are readily available for
 retrieval. This api allows listing the streams available for
 consumption. A user can also provide a criteria. The criteria can limit
 the subset of streams that can be listed via this interface. Each flight
-service allows its own definition of how to consume criteria.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_flight_info" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#183-189">source</a><a href="#method.get_flight_info" class="anchor">§</a><h4 class="code-header">fn <a class="fn">get_flight_info</a>&lt;'life0, 'async_trait&gt;(
+service allows its own definition of how to consume criteria.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_flight_info" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#183-189">source</a><a href="#method.get_flight_info" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService. [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;FlightDescriptor&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>For a given FlightDescriptor, get information about how the flight can be
 consumed. This is a useful interface if the consumer of the interface
@@ -56,37 +56,37 @@ includes a SQL statement or a Pickled Python operation that will be
 executed. In those cases, the descriptor will not be previously available
 within the list of available streams provided by ListFlights but will be
 available for consumption for the duration defined by the specific flight
-service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_put" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#191-198">source</a><a href="#method.do_put" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_put</a>&lt;'life0, 'async_trait&gt;(
+service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_put" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#191-198">source</a><a href="#method.do_put" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_put" class="fn">do_put</a>&lt;'life0, 'async_trait&gt;(
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Push a stream to the flight service associated with a particular
 flight stream. This allows a client of a flight service to upload a stream
 of data. Depending on the particular flight service, a client consumer
 could be allowed to upload a single stream per descriptor or an unlimited
 number. In the latter, the service might implement a ‘seal’ action that
-can be applied to a descriptor once all streams are uploaded.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_action" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#200-210">source</a><a href="#method.do_action" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_action</a>&lt;'life0, 'async_trait&gt;(
+can be applied to a descriptor once all streams are uploaded.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_action" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#200-210">source</a><a href="#method.do_action" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymetho [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Action&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Action.html" title="struct arrow_flight::gen::Action">Action</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Flight services can support an arbitrary number of simple actions in
 addition to the possible ListFlights, GetFlightInfo, DoGet, DoPut
 operations that are potentially available. DoAction allows a flight client
 to do a specific action against a flight service. An action includes
 opaque request and response objects that are specific to the type action
-being undertaken.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_actions" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#212-218">source</a><a href="#method.list_actions" class="anchor">§</a><h4 class="code-header">fn <a class="fn">list_actions</a>&lt;'life0, 'async_trait&gt;(
+being undertaken.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_actions" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#212-218">source</a><a href="#method.list_actions" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.list_actions" class="fn">list_action [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Empty&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Empty.html" title="struct arrow_flight::gen::Empty">Empty</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>A flight service exposes all of the available action types that it has
 along with descriptions. This allows different flight consumers to
-understand the capabilities of the flight service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_exchange" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#220-227">source</a><a href="#method.do_exchange" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_exchange</a>&lt;'life0, 'async_trait&gt;(
+understand the capabilities of the flight service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_exchange" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/auth_basic_proto.rs.html#220-227">source</a><a href="#method.do_exchange" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_ex [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Open a bidirectional data channel for a given descriptor. This
 allows clients to send and receive arbitrary Arrow data and
diff --git a/arrow_integration_testing/flight_server_scenarios/fn.endpoint.html b/arrow_integration_testing/flight_server_scenarios/fn.endpoint.html
index 8b5f3ce39..c6b330069 100644
--- a/arrow_integration_testing/flight_server_scenarios/fn.endpoint.html
+++ b/arrow_integration_testing/flight_server_scenarios/fn.endpoint.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 `endpoint` fn in crate `arrow_integration_testing`."><title>endpoint in arrow_integration_testing::flight_server_scenarios - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac52 [...]
\ 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 `endpoint` fn in crate `arrow_integration_testing`."><title>endpoint in arrow_integration_testing::flight_server_scenarios - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac52 [...]
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_server_scenarios/integration_test/fn.save_uploaded_chunks.html b/arrow_integration_testing/flight_server_scenarios/integration_test/fn.save_uploaded_chunks.html
index ba4c86e4b..f36def6f0 100644
--- a/arrow_integration_testing/flight_server_scenarios/integration_test/fn.save_uploaded_chunks.html
+++ b/arrow_integration_testing/flight_server_scenarios/integration_test/fn.save_uploaded_chunks.html
@@ -1,8 +1,8 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `save_uploaded_chunks` fn in crate `arrow_integration_testing`."><title>save_uploaded_chunks in arrow_integration_testing::flight_server_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../sta [...]
     uploaded_chunks: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;Mutex&lt;<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 [...]
     schema_ref: <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_schema/schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a>&gt;,
-    input_stream: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;,
-    response_tx: Sender&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;PutResult, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;&gt;,
+    input_stream: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;,
+    response_tx: Sender&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.PutResult.html" title="struct arrow_flight::gen::PutResult">PutResult</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;&gt;,
     schema: <a class="struct" href="../../../arrow_schema/schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a>,
     key: <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="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;</code></pre></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_server_scenarios/integration_test/fn.send_app_metadata.html b/arrow_integration_testing/flight_server_scenarios/integration_test/fn.send_app_metadata.html
index 576fb28bb..5b928cd59 100644
--- a/arrow_integration_testing/flight_server_scenarios/integration_test/fn.send_app_metadata.html
+++ b/arrow_integration_testing/flight_server_scenarios/integration_test/fn.send_app_metadata.html
@@ -1,4 +1,4 @@
 <!DOCTYPE html><html lang="en"><head><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 `send_app_metadata` fn in crate `arrow_integration_testing`."><title>send_app_metadata in arrow_integration_testing::flight_server_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.fi [...]
-    tx: &amp;mut Sender&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;PutResult, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;&gt;,
+    tx: &amp;mut Sender&lt;<a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.PutResult.html" title="struct arrow_flight::gen::PutResult">PutResult</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;&gt;,
     app_metadata: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/status/struct.Status.html" title="struct tonic::status::Status">Status</a>&gt;</code></pre></section></div></main></body></html>
\ No newline at end of file
diff --git a/arrow_integration_testing/flight_server_scenarios/integration_test/struct.FlightServiceImpl.html b/arrow_integration_testing/flight_server_scenarios/integration_test/struct.FlightServiceImpl.html
index 69f0bef81..7d52fbd05 100644
--- a/arrow_integration_testing/flight_server_scenarios/integration_test/struct.FlightServiceImpl.html
+++ b/arrow_integration_testing/flight_server_scenarios/integration_test/struct.FlightServiceImpl.html
@@ -1,44 +1,44 @@
 <!DOCTYPE html><html lang="en"><head><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 `FlightServiceImpl` struct in crate `arrow_integration_testing`."><title>FlightServiceImpl in arrow_integration_testing::flight_server_scenarios::integration_test - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../stati [...]
     server_location: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>,
     uploaded_chunks: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.html" title="struct alloc::sync::Arc">Arc</a>&lt;Mutex&lt;<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 [...]
-}</code></pre><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.server_location" class="structfield small-section-header"><a href="#structfield.server_location" class="anchor field">§</a><code>server_location: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><span id="structfield.uploaded_chunks" class="structfield [...]
+}</code></pre><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.server_location" class="structfield small-section-header"><a href="#structfield.server_location" class="anchor field">§</a><code>server_location: <a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a></code></span><span id="structfield.uploaded_chunks" class="structfield [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;FlightDescriptor&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema
 This is used when a consumer needs the Schema of flight stream. Similar to
 GetFlightInfo this interface may generate a new flight that was not previously
-available in ListFlights.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_get" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#99-149">source</a><a href="#method.do_get" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_get</a>&lt;'life0, 'async_trait&gt;(
+available in ListFlights.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_get" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#99-149">source</a><a href="#method.do_get" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_get" class="fn">do_get</a>&lt;'life0,  [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Ticket&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Ticket.html" title="struct arrow_flight::gen::Ticket">Ticket</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Retrieve a single stream associated with a particular descriptor
 associated with the referenced ticket. A Flight can be composed of one or
 more streams where each stream can be retrieved using a separate opaque
-ticket that the flight service uses for managing a collection of streams.</div></details><details class="toggle method-toggle" open><summary><section id="method.handshake" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#151-156">source</a><a href="#method.handshake" class="anchor">§</a><h4 class="code-header">fn <a class="fn">handshake</a>&lt;'life0, 'async_trait&gt;(
+ticket that the flight service uses for managing a collection of streams.</div></details><details class="toggle method-toggle" open><summary><section id="method.handshake" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#151-156">source</a><a href="#method.handshake" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService. [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;HandshakeRequest&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.HandshakeRequest.html" title="struct arrow_flight::gen::HandshakeRequest">HandshakeRequest</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Handshake between client and server. Depending on the server, the
 handshake may be required to determine the token that should be used for
 future operations. Both request and response are streams to allow multiple
-round-trips depending on auth mechanism.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_flights" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#158-163">source</a><a href="#method.list_flights" class="anchor">§</a><h4 class="code-header">fn <a class="fn">list_flights</a>&lt;'life0, 'async_trait&gt;(
+round-trips depending on auth mechanism.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_flights" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#158-163">source</a><a href="#method.list_flights" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.list_flights" [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Criteria&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Criteria.html" title="struct arrow_flight::gen::Criteria">Criteria</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Get a list of available streams given a particular criteria. Most flight
 services will expose one or more streams that are readily available for
 retrieval. This api allows listing the streams available for
 consumption. A user can also provide a criteria. The criteria can limit
 the subset of streams that can be listed via this interface. Each flight
-service allows its own definition of how to consume criteria.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_flight_info" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#165-210">source</a><a href="#method.get_flight_info" class="anchor">§</a><h4 class="code-header">fn <a class="fn">get_flight_info</a>&lt;'life0, 'async_trait&gt;(
+service allows its own definition of how to consume criteria.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_flight_info" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#165-210">source</a><a href="#method.get_flight_info" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService. [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;FlightDescriptor&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>For a given FlightDescriptor, get information about how the flight can be
 consumed. This is a useful interface if the consumer of the interface
@@ -49,37 +49,37 @@ includes a SQL statement or a Pickled Python operation that will be
 executed. In those cases, the descriptor will not be previously available
 within the list of available streams provided by ListFlights but will be
 available for consumption for the duration defined by the specific flight
-service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_put" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#212-259">source</a><a href="#method.do_put" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_put</a>&lt;'life0, 'async_trait&gt;(
+service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_put" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#212-259">source</a><a href="#method.do_put" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_put" class="fn">do_put</a>&lt;'life0, 'async_trait&gt;(
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Push a stream to the flight service associated with a particular
 flight stream. This allows a client of a flight service to upload a stream
 of data. Depending on the particular flight service, a client consumer
 could be allowed to upload a single stream per descriptor or an unlimited
 number. In the latter, the service might implement a ‘seal’ action that
-can be applied to a descriptor once all streams are uploaded.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_action" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#261-266">source</a><a href="#method.do_action" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_action</a>&lt;'life0, 'async_trait&gt;(
+can be applied to a descriptor once all streams are uploaded.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_action" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#261-266">source</a><a href="#method.do_action" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymetho [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Action&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Action.html" title="struct arrow_flight::gen::Action">Action</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Flight services can support an arbitrary number of simple actions in
 addition to the possible ListFlights, GetFlightInfo, DoGet, DoPut
 operations that are potentially available. DoAction allows a flight client
 to do a specific action against a flight service. An action includes
 opaque request and response objects that are specific to the type action
-being undertaken.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_actions" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#268-273">source</a><a href="#method.list_actions" class="anchor">§</a><h4 class="code-header">fn <a class="fn">list_actions</a>&lt;'life0, 'async_trait&gt;(
+being undertaken.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_actions" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#268-273">source</a><a href="#method.list_actions" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.list_actions" class="fn">list_action [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Empty&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Empty.html" title="struct arrow_flight::gen::Empty">Empty</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>A flight service exposes all of the available action types that it has
 along with descriptions. This allows different flight consumers to
-understand the capabilities of the flight service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_exchange" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#275-280">source</a><a href="#method.do_exchange" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_exchange</a>&lt;'life0, 'async_trait&gt;(
+understand the capabilities of the flight service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_exchange" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/integration_test.rs.html#275-280">source</a><a href="#method.do_exchange" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_ex [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Open a bidirectional data channel for a given descriptor. This
 allows clients to send and receive arbitrary Arrow data and
diff --git a/arrow_integration_testing/flight_server_scenarios/middleware/struct.MiddlewareScenarioImpl.html b/arrow_integration_testing/flight_server_scenarios/middleware/struct.MiddlewareScenarioImpl.html
index dc0a7f104..a5f186fd3 100644
--- a/arrow_integration_testing/flight_server_scenarios/middleware/struct.MiddlewareScenarioImpl.html
+++ b/arrow_integration_testing/flight_server_scenarios/middleware/struct.MiddlewareScenarioImpl.html
@@ -1,41 +1,41 @@
-<!DOCTYPE html><html lang="en"><head><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 `MiddlewareScenarioImpl` struct in crate `arrow_integration_testing`."><title>MiddlewareScenarioImpl in arrow_integration_testing::flight_server_scenarios::middleware - 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="API documentation for the Rust `MiddlewareScenarioImpl` struct in crate `arrow_integration_testing`."><title>MiddlewareScenarioImpl in arrow_integration_testing::flight_server_scenarios::middleware - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../s [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;FlightDescriptor&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema
 This is used when a consumer needs the Schema of flight stream. Similar to
 GetFlightInfo this interface may generate a new flight that was not previously
-available in ListFlights.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_get" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#67-72">source</a><a href="#method.do_get" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_get</a>&lt;'life0, 'async_trait&gt;(
+available in ListFlights.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_get" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#67-72">source</a><a href="#method.do_get" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_get" class="fn">do_get</a>&lt;'life0, 'async_ [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Ticket&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Ticket.html" title="struct arrow_flight::gen::Ticket">Ticket</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Retrieve a single stream associated with a particular descriptor
 associated with the referenced ticket. A Flight can be composed of one or
 more streams where each stream can be retrieved using a separate opaque
-ticket that the flight service uses for managing a collection of streams.</div></details><details class="toggle method-toggle" open><summary><section id="method.handshake" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#74-79">source</a><a href="#method.handshake" class="anchor">§</a><h4 class="code-header">fn <a class="fn">handshake</a>&lt;'life0, 'async_trait&gt;(
+ticket that the flight service uses for managing a collection of streams.</div></details><details class="toggle method-toggle" open><summary><section id="method.handshake" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#74-79">source</a><a href="#method.handshake" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tym [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;HandshakeRequest&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.HandshakeRequest.html" title="struct arrow_flight::gen::HandshakeRequest">HandshakeRequest</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Handshake between client and server. Depending on the server, the
 handshake may be required to determine the token that should be used for
 future operations. Both request and response are streams to allow multiple
-round-trips depending on auth mechanism.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_flights" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#81-86">source</a><a href="#method.list_flights" class="anchor">§</a><h4 class="code-header">fn <a class="fn">list_flights</a>&lt;'life0, 'async_trait&gt;(
+round-trips depending on auth mechanism.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_flights" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#81-86">source</a><a href="#method.list_flights" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.list_flights" class=" [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Criteria&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Criteria.html" title="struct arrow_flight::gen::Criteria">Criteria</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Get a list of available streams given a particular criteria. Most flight
 services will expose one or more streams that are readily available for
 retrieval. This api allows listing the streams available for
 consumption. A user can also provide a criteria. The criteria can limit
 the subset of streams that can be listed via this interface. Each flight
-service allows its own definition of how to consume criteria.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_flight_info" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#88-122">source</a><a href="#method.get_flight_info" class="anchor">§</a><h4 class="code-header">fn <a class="fn">get_flight_info</a>&lt;'life0, 'async_trait&gt;(
+service allows its own definition of how to consume criteria.</div></details><details class="toggle method-toggle" open><summary><section id="method.get_flight_info" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#88-122">source</a><a href="#method.get_flight_info" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#ty [...]
     &amp;'life0 self,
-    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;FlightDescriptor&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightDescriptor.html" title="struct arrow_flight::gen::FlightDescriptor">FlightDescriptor</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>For a given FlightDescriptor, get information about how the flight can be
 consumed. This is a useful interface if the consumer of the interface
@@ -46,37 +46,37 @@ includes a SQL statement or a Pickled Python operation that will be
 executed. In those cases, the descriptor will not be previously available
 within the list of available streams provided by ListFlights but will be
 available for consumption for the duration defined by the specific flight
-service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_put" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#124-129">source</a><a href="#method.do_put" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_put</a>&lt;'life0, 'async_trait&gt;(
+service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_put" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#124-129">source</a><a href="#method.do_put" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_put" class="fn">do_put</a>&lt;'life0, 'async_trait&gt;(
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Push a stream to the flight service associated with a particular
 flight stream. This allows a client of a flight service to upload a stream
 of data. Depending on the particular flight service, a client consumer
 could be allowed to upload a single stream per descriptor or an unlimited
 number. In the latter, the service might implement a ‘seal’ action that
-can be applied to a descriptor once all streams are uploaded.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_action" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#131-136">source</a><a href="#method.do_action" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_action</a>&lt;'life0, 'async_trait&gt;(
+can be applied to a descriptor once all streams are uploaded.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_action" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#131-136">source</a><a href="#method.do_action" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_a [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Action&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Action.html" title="struct arrow_flight::gen::Action">Action</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Flight services can support an arbitrary number of simple actions in
 addition to the possible ListFlights, GetFlightInfo, DoGet, DoPut
 operations that are potentially available. DoAction allows a flight client
 to do a specific action against a flight service. An action includes
 opaque request and response objects that are specific to the type action
-being undertaken.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_actions" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#138-143">source</a><a href="#method.list_actions" class="anchor">§</a><h4 class="code-header">fn <a class="fn">list_actions</a>&lt;'life0, 'async_trait&gt;(
+being undertaken.</div></details><details class="toggle method-toggle" open><summary><section id="method.list_actions" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#138-143">source</a><a href="#method.list_actions" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.list_actions" class="fn">list_actions</a>& [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;Empty&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.Empty.html" title="struct arrow_flight::gen::Empty">Empty</a>&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>A flight service exposes all of the available action types that it has
 along with descriptions. This allows different flight consumers to
-understand the capabilities of the flight service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_exchange" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#145-150">source</a><a href="#method.do_exchange" class="anchor">§</a><h4 class="code-header">fn <a class="fn">do_exchange</a>&lt;'life0, 'async_trait&gt;(
+understand the capabilities of the flight service.</div></details><details class="toggle method-toggle" open><summary><section id="method.do_exchange" class="method trait-impl"><a class="srclink rightside" href="../../../src/arrow_integration_testing/flight_server_scenarios/middleware.rs.html#145-150">source</a><a href="#method.do_exchange" class="anchor">§</a><h4 class="code-header">fn <a href="../../../arrow_flight/gen/flight_service_server/trait.FlightService.html#tymethod.do_exchange [...]
     &amp;'life0 self,
-    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;FlightData&gt;&gt;
-) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
+    _request: <a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/request/struct.Request.html" title="struct tonic::request::Request">Request</a>&lt;<a class="struct" href="https://docs.rs/tonic/0.9.2/tonic/codec/decode/struct.Streaming.html" title="struct tonic::codec::decode::Streaming">Streaming</a>&lt;<a class="struct" href="../../../arrow_flight/gen/struct.FlightData.html" title="struct arrow_flight::gen::FlightData">FlightData</a>&gt;&gt;
+) -&gt; <a class="struct" href="https://doc.rust-lang.org/nightly/core/pin/struct.Pin.html" title="struct core::pin::Pin">Pin</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/future/future/trait.Future.html" title="trait core::future::future::Future">Future</a>&lt;Output = <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
     Self: 'async_trait,
     'life0: 'async_trait,</span></h4></section></summary><div class='docblock'>Open a bidirectional data channel for a given descriptor. This
 allows clients to send and receive arbitrary Arrow data and
diff --git a/arrow_integration_testing/index.html b/arrow_integration_testing/index.html
index b71ce1771..3570716ca 100644
--- a/arrow_integration_testing/index.html
+++ b/arrow_integration_testing/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="Common code used in the integration test binaries"><title>arrow_integration_testing - Rust</title><link rel="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="Common code used in the integration test binaries"><title>arrow_integration_testing - Rust</title><link rel="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><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="flight_client_scenarios/index.html" title="mod arrow_integration_testing::flight_client_scenarios">flight_client_scenarios</a></div></li><li><div class="item-name"><a class="mod" href="flight_server_scenarios/index.html" title="mod arrow_integration_testing::flight_server_scenarios">flight_server_scenarios</a></div></li></ [...]
\ No newline at end of file
diff --git a/arrow_ipc/index.html b/arrow_ipc/index.html
index 5eb9f78cd..b0c4a8a96 100644
--- a/arrow_ipc/index.html
+++ b/arrow_ipc/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="Support for the Arrow IPC Format"><title>arrow_ipc - Rust</title><link rel="preload" 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/FiraSans-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="Support for the Arrow IPC Format"><title>arrow_ipc - Rust</title><link rel="preload" 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/FiraSans-R [...]
 </div></details><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name"><code>pub use self::gen::<a class="mod" href="gen/File/index.html" title="mod arrow_ipc::gen::File">File</a>::*;</code></div></li><li><div class="item-name"><code>pub use self::gen::<a class="mod" href="gen/Message/index.html" title="mod arrow_ipc::gen::Message">Message</a>::*;</code></div></li><li><div class="item-name"><code>pub use s [...]
\ No newline at end of file
diff --git a/arrow_json/index.html b/arrow_json/index.html
index 1a5c5f0d2..f21ad54f7 100644
--- a/arrow_json/index.html
+++ b/arrow_json/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="Transfer data between the Arrow memory format and JSON line-delimited records. See the module level documentation for the `reader` and `writer` for usage examples."><title>arrow_json - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSer [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Transfer data between the Arrow memory format and JSON line-delimited records. See the module level documentation for the `reader` and `writer` for usage examples."><title>arrow_json - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSer [...]
 line-delimited records. See the module level documentation for the
 <a href="reader/index.html" title="mod arrow_json::reader"><code>reader</code></a> and <a href="writer/index.html" title="mod arrow_json::writer"><code>writer</code></a> for usage examples.</p>
 </div></details><h2 id="reexports" class="small-section-header"><a href="#reexports">Re-exports</a></h2><ul class="item-table"><li><div class="item-name" id="reexport.Reader"><code>pub use self::reader::<a class="struct" href="reader/struct.Reader.html" title="struct arrow_json::reader::Reader">Reader</a>;</code></div></li><li><div class="item-name" id="reexport.ReaderBuilder"><code>pub use self::reader::<a class="struct" href="reader/struct.ReaderBuilder.html" title="struct arrow_json:: [...]
\ No newline at end of file
diff --git a/arrow_json/reader/primitive_array/trait.ParseJsonNumber.html b/arrow_json/reader/primitive_array/trait.ParseJsonNumber.html
index fb6078aee..e4a5e2999 100644
--- a/arrow_json/reader/primitive_array/trait.ParseJsonNumber.html
+++ b/arrow_json/reader/primitive_array/trait.ParseJsonNumber.html
@@ -7,4 +7,4 @@ floating point numbers, including scientific representation such as <code>2e3</c
 <p>In practice, it is common to serialize numbers outside the range of an <code>f64</code> and expect
 them to round-trip correctly. As such when parsing integers we first parse as the integer
 and fallback to parsing as a floating point if this fails</p>
-</div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.parse" class="method"><a class="srclink rightside" href="../../../src/arrow_json/reader/primitive_array.rs.html#40">source</a><h4 class="code-header">fn <a href="#tymethod.parse" class="fn">parse</a>(s: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]) -&gt; < [...]
\ No newline at end of file
+</div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.parse" class="method"><a class="srclink rightside" href="../../../src/arrow_json/reader/primitive_array.rs.html#40">source</a><h4 class="code-header">fn <a href="#tymethod.parse" class="fn">parse</a>(s: &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>]) -&gt; < [...]
\ No newline at end of file
diff --git a/arrow_json/reader/serializer/struct.ListSerializer.html b/arrow_json/reader/serializer/struct.ListSerializer.html
index c1155c2ae..162d10616 100644
--- a/arrow_json/reader/serializer/struct.ListSerializer.html
+++ b/arrow_json/reader/serializer/struct.ListSerializer.html
@@ -1,9 +1,9 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `ListSerializer` struct in crate `arrow_json`."><title>ListSerializer in arrow_json::reader::serializer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><l [...]
     serializer: &amp;'a mut <a class="struct" href="struct.TapeSerializer.html" title="struct arrow_json::reader::serializer::TapeSerializer">TapeSerializer</a>&lt;'b&gt;,
     start: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
-}</code></pre><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.serializer" class="structfield small-section-header"><a href="#structfield.serializer" class="anchor field">§</a><code>serializer: &amp;'a mut <a class="struct" href="struct.TapeSerializer.html" title="struct arrow_json::reader::serializer::TapeSerializer">TapeSerializer</a>&lt;'b&gt;</code></span><span id="structfield.start" class="structfield small-se [...]
-    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a sequence element.</div></details><details class="toggle method-toggle" open><summary><section id="method.end-1" class="method trait-impl"><a class="sr [...]
-    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a tuple element.</div></details><details class="toggle method-toggle" open><summary><section id="method.end-2" class="method trait-impl"><a class="srcli [...]
+}</code></pre><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.serializer" class="structfield small-section-header"><a href="#structfield.serializer" class="anchor field">§</a><code>serializer: &amp;'a mut <a class="struct" href="struct.TapeSerializer.html" title="struct arrow_json::reader::serializer::TapeSerializer">TapeSerializer</a>&lt;'b&gt;</code></span><span id="structfield.start" class="structfield small-se [...]
+    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a sequence element.</div></details><details class="toggle method-toggle" open><summary><section id="method.end-2" class="method trait-impl"><a class="sr [...]
+    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a tuple element.</div></details><details class="toggle method-toggle" open><summary><section id="method.end-1" class="method trait-impl"><a class="srcli [...]
     T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a tuple struct field.</div></details><details class="toggle method-toggle" open><summary><section id="method.end" class="method trait-impl"><a class="sr [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
diff --git a/arrow_json/reader/serializer/struct.ObjectSerializer.html b/arrow_json/reader/serializer/struct.ObjectSerializer.html
index 376f72062..985fdeb77 100644
--- a/arrow_json/reader/serializer/struct.ObjectSerializer.html
+++ b/arrow_json/reader/serializer/struct.ObjectSerializer.html
@@ -1,20 +1,20 @@
 <!DOCTYPE html><html lang="en"><head><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 `ObjectSerializer` struct in crate `arrow_json`."><title>ObjectSerializer in arrow_json::reader::serializer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2 [...]
     serializer: &amp;'a mut <a class="struct" href="struct.TapeSerializer.html" title="struct arrow_json::reader::serializer::TapeSerializer">TapeSerializer</a>&lt;'b&gt;,
     start: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>,
-}</code></pre><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.serializer" class="structfield small-section-header"><a href="#structfield.serializer" class="anchor field">§</a><code>serializer: &amp;'a mut <a class="struct" href="struct.TapeSerializer.html" title="struct arrow_json::reader::serializer::TapeSerializer">TapeSerializer</a>&lt;'b&gt;</code></span><span id="structfield.start" class="structfield small-se [...]
+}</code></pre><h2 id="fields" class="fields small-section-header">Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.serializer" class="structfield small-section-header"><a href="#structfield.serializer" class="anchor field">§</a><code>serializer: &amp;'a mut <a class="struct" href="struct.TapeSerializer.html" title="struct arrow_json::reader::serializer::TapeSerializer">TapeSerializer</a>&lt;'b&gt;</code></span><span id="structfield.start" class="structfield small-se [...]
     T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a map key. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeMap.html#tymethod.serialize_key">Read more</a></div></details><details class= [...]
-    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a map value. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeMap.html#tymethod.serialize_value">Read more</a></div></details><details cl [...]
+    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a map value. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeMap.html#tymethod.serialize_value">Read more</a></div></details><details cl [...]
     &amp;mut self,
     key: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;K</a>,
     value: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;V</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, Self::<a class="associatedtype" href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeMap.html#associatedtype.Error" title="type serde::ser::SerializeMap::Error">Error</a>&gt;<span class="where fmt-newline">where
     K: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,
-    V: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a map entry consisting of a key and a value. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeMap.html#method.serialize_entry">Read more< [...]
+    V: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a map entry consisting of a key and a value. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeMap.html#method.serialize_entry">Read more< [...]
     &amp;mut self,
     key: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>,
     value: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;T</a>
 ) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>, Self::<a class="associatedtype" href="https://docs.rs/serde/1.0.164/serde/ser/trait.SerializeStruct.html#associatedtype.Error" title="type serde::ser::SerializeStruct::Error">Error</a>&gt;<span class="where fmt-newline">where
-    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a struct field.</div></details><details class="toggle method-toggle" open><summary><section id="method.end-1" class="method trait-impl"><a class="srclin [...]
+    T: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Serialize">Serialize</a> + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Serialize a struct field.</div></details><details class="toggle method-toggle" open><summary><section id="method.end" class="method trait-impl"><a class="srclink  [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_json/reader/serializer/struct.SerializerError.html b/arrow_json/reader/serializer/struct.SerializerError.html
index 4581b2492..b499d84df 100644
--- a/arrow_json/reader/serializer/struct.SerializerError.html
+++ b/arrow_json/reader/serializer/struct.SerializerError.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 `SerializerError` struct in crate `arrow_json`."><title>SerializerError in arrow_json::reader::serializer - 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="API documentation for the Rust `SerializerError` struct in crate `arrow_json`."><title>SerializerError in arrow_json::reader::serializer - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"> [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html" title="trait core::fmt::Display">Display</a>,</span></h4></section></summary><div class='docblock'>Used when a <a href="../trait.Serialize.html"><code>Serialize</code></a> implementation encounters any error
 while serializing a type. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Error.html#tymethod.custom">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Error-for-SerializerError-1" class="impl"><a class="srclink rightside" href="../../../src/arrow_json/reader/serializer.rs.html#29">source</a><a href="#impl-Error-for-SerializerError-1" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/arrow_json/trait.JsonSerializable.html b/arrow_json/trait.JsonSerializable.html
index 116a79acd..fe19c68bb 100644
--- a/arrow_json/trait.JsonSerializable.html
+++ b/arrow_json/trait.JsonSerializable.html
@@ -3,4 +3,4 @@
     fn <a href="#tymethod.into_json_value" class="fn">into_json_value</a>(self) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/option/enum.Option.html" title="enum core::option::Option">Option</a>&lt;<a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a>&gt;;
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Trait declaring any type that is serializable to JSON. This includes all primitive types (bool, i32, etc.).</p>
 </div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.into_json_value" class="method"><a class="srclink rightside" href="../src/arrow_json/lib.rs.html#48">source</a><h4 class="code-header">fn <a href="#tymethod.into_json_value" class="fn">into_json_value</a>(self) -&gt; <a class="enum" href="https://doc.rust-l [...]
-</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-JsonSerializable-for-i64" class="impl"><a class="srclink rightside" href="../src/arrow_json/lib.rs.html#69">source</a><a href="#impl-JsonSerializable-for-i64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.JsonSerializable.html" title [...]
\ No newline at end of file
+</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-JsonSerializable-for-i8" class="impl"><a class="srclink rightside" href="../src/arrow_json/lib.rs.html#66">source</a><a href="#impl-JsonSerializable-for-i8" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.JsonSerializable.html" title=" [...]
\ No newline at end of file
diff --git a/arrow_json_integration_test/index.html b/arrow_json_integration_test/index.html
index ed20ea570..8a7f5b6dd 100644
--- a/arrow_json_integration_test/index.html
+++ b/arrow_json_integration_test/index.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 `arrow_json_integration_test` crate."><title>arrow_json_integration_test - Rust</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 [...]
\ 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 `arrow_json_integration_test` crate."><title>arrow_json_integration_test - Rust</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 [...]
\ No newline at end of file
diff --git a/arrow_ord/index.html b/arrow_ord/index.html
index 0af29f9c5..b13cbf8dc 100644
--- a/arrow_ord/index.html
+++ b/arrow_ord/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="Arrow ordering kernels"><title>arrow_ord - Rust</title><link rel="preload" 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/FiraSans-Regular-018 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Arrow ordering kernels"><title>arrow_ord - Rust</title><link rel="preload" 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/FiraSans-Regular-018 [...]
 <h2 id="sort-recordbatch"><a href="#sort-recordbatch">Sort RecordBatch</a></h2>
 <div class="example-wrap"><pre class="rust rust-example-rendered"><code><span class="kw">let </span>a: ArrayRef = Arc::new(Int32Array::from(<span class="macro">vec!</span>[<span class="number">1</span>, <span class="number">2</span>, <span class="number">3</span>, <span class="number">4</span>]));
 <span class="kw">let </span>b: ArrayRef = Arc::new(StringArray::from(<span class="macro">vec!</span>[<span class="string">&quot;b&quot;</span>, <span class="string">&quot;a&quot;</span>, <span class="string">&quot;e&quot;</span>, <span class="string">&quot;d&quot;</span>]));
diff --git a/arrow_row/fixed/trait.FixedLengthEncoding.html b/arrow_row/fixed/trait.FixedLengthEncoding.html
index 254c6fbed..3f249e9b0 100644
--- a/arrow_row/fixed/trait.FixedLengthEncoding.html
+++ b/arrow_row/fixed/trait.FixedLengthEncoding.html
@@ -8,4 +8,4 @@
 <span class="item-spacer"></span>    fn <a href="#tymethod.decode" class="fn">decode</a>(encoded: Self::<a class="associatedtype" href="trait.FixedLengthEncoding.html#associatedtype.Encoded" title="type arrow_row::fixed::FixedLengthEncoding::Encoded">Encoded</a>) -&gt; Self;
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Encodes a value of a particular fixed width type into bytes according to the rules
 described on <a href="../struct.RowConverter.html" title="struct arrow_row::RowConverter"><code>super::RowConverter</code></a></p>
-</div></details><h2 id="required-associated-types" class="small-section-header">Required Associated Types<a href="#required-associated-types" class="anchor">§</a></h2><div class="methods"><section id="associatedtype.Encoded" class="method"><a class="srclink rightside" href="../../src/arrow_row/fixed.rs.html#47">source</a><h4 class="code-header">type <a href="#associatedtype.Encoded" class="associatedtype">Encoded</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/t [...]
\ No newline at end of file
+</div></details><h2 id="required-associated-types" class="small-section-header">Required Associated Types<a href="#required-associated-types" class="anchor">§</a></h2><div class="methods"><section id="associatedtype.Encoded" class="method"><a class="srclink rightside" href="../../src/arrow_row/fixed.rs.html#47">source</a><h4 class="code-header">type <a href="#associatedtype.Encoded" class="associatedtype">Encoded</a>: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/t [...]
\ No newline at end of file
diff --git a/arrow_row/index.html b/arrow_row/index.html
index 34b0d4ca2..0f60776cd 100644
--- a/arrow_row/index.html
+++ b/arrow_row/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="A comparable row-oriented representation of a collection of `Array`."><title>arrow_row - Rust</title><link 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 comparable row-oriented representation of a collection of `Array`."><title>arrow_row - Rust</title><link 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><a href="struct.Row.html" title="struct arrow_row::Row"><code>Row</code></a>s are <a href="https://citeseerx.ist.psu.edu/viewdoc/download?doi=10.1.1.83.1080&amp;rep=rep1&amp;type=pdf">normalized for sorting</a>, and can therefore be very efficiently <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html" title="trait core::cmp::PartialOrd">compared</a>,
 using <a href="https://www.man7.org/linux/man-pages/man3/memcmp.3.html"><code>memcmp</code></a> under the hood, or used in <a href="https://en.wikipedia.org/wiki/Sorting_algorithm#Non-comparison_sorts">non-comparison sorts</a> such as <a href="https://en.wikipedia.org/wiki/Radix_sort">radix sort</a>.
 This makes the row format ideal for implementing efficient multi-column sorting,
diff --git a/arrow_schema/datatype/enum.DataType.html b/arrow_schema/datatype/enum.DataType.html
index e4b096f34..9306933e0 100644
--- a/arrow_schema/datatype/enum.DataType.html
+++ b/arrow_schema/datatype/enum.DataType.html
@@ -220,8 +220,8 @@ and metadata.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.contains" class="method"><a class="srclink rightside" href="../../src/arrow_schema/datatype.rs.html#558-578">source</a><h4 class="code-header">pub fn <a href="#method.contains" class="fn">contains</a>(&amp;self, other: &amp;<a class="enum" href="enum.DataType.html" title="enum arrow_schema::datatype::DataType">DataType</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primiti [...]
 <p>If DataType is a nested type, then it will check to see if the nested type is a superset of the other nested type
 else it will check to see if the DataType is equal to the other DataType</p>
-</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-DataType" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/datatype.rs.html#38">source</a><a href="#impl-Clone-for-DataType" class="anchor">§</a><h3 class="code-header">i [...]
-    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Disp [...]
+</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-DataType" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/datatype.rs.html#38">source</a><a href="#impl-Clone-for-DataType" class="anchor">§</a><h3 class="code-header">i [...]
+    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Disp [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
@@ -232,8 +232,8 @@ sufficient, and should not be overridden without very good reason.</div></detail
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Serialize-for-DataType" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/datatype.rs.html#39">source</a><a href="#impl-Serialize-for-DataType" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser [...]
     __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26DataType%3E-f [...]
-</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-2" class="associatedtype trait-impl"><a href="#associatedtype.Error-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
+</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='docbloc [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/enum.ArrowError.html b/arrow_schema/enum.ArrowError.html
index 595dc6914..76c169ea3 100644
--- a/arrow_schema/enum.ArrowError.html
+++ b/arrow_schema/enum.ArrowError.html
@@ -19,7 +19,7 @@
 </div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.NotYetImplemented" class="variant"><a href="#variant.NotYetImplemented" class="anchor">§</a><h3 class="code-header">NotYetImplemented(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>)</h3></section><div class="docblock"><p>Returned wh [...]
 </div><section id="variant.ExternalError" class="variant"><a href="#variant.ExternalError" class="anchor">§</a><h3 class="code-header">ExternalError(<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/error/trait.Error.html" title="trait core::error::Error">Error</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Se [...]
 </div><section id="variant.DictionaryKeyOverflowError" class="variant"><a href="#variant.DictionaryKeyOverflowError" class="anchor">§</a><h3 class="code-header">DictionaryKeyOverflowError</h3></section><section id="variant.RunEndIndexOverflowError" class="variant"><a href="#variant.RunEndIndexOverflowError" class="anchor">§</a><h3 class="code-header">RunEndIndexOverflowError</h3></section></div><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations [...]
-</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-Debug-for-ArrowError" class="impl"><a class="srclink rightside" href="../src/arrow_schema/error.rs.html#25">source</a><a href="#impl-Debug-for-ArrowError" class="anchor">§</a><h3 class="code-header">imp [...]
+</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-Debug-for-ArrowError" class="impl"><a class="srclink rightside" href="../src/arrow_schema/error.rs.html#25">source</a><a href="#impl-Debug-for-ArrowError" class="anchor">§</a><h3 class="code-header">imp [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/enum.DataType.html b/arrow_schema/enum.DataType.html
index 454c20c42..ed841e264 100644
--- a/arrow_schema/enum.DataType.html
+++ b/arrow_schema/enum.DataType.html
@@ -220,8 +220,8 @@ and metadata.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.contains" class="method"><a class="srclink rightside" href="../src/arrow_schema/datatype.rs.html#558-578">source</a><h4 class="code-header">pub fn <a href="#method.contains" class="fn">contains</a>(&amp;self, other: &amp;<a class="enum" href="datatype/enum.DataType.html" title="enum arrow_schema::datatype::DataType">DataType</a>) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/p [...]
 <p>If DataType is a nested type, then it will check to see if the nested type is a superset of the other nested type
 else it will check to see if the DataType is equal to the other DataType</p>
-</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-DataType" class="impl"><a class="srclink rightside" href="../src/arrow_schema/datatype.rs.html#38">source</a><a href="#impl-Clone-for-DataType" class="anchor">§</a><h3 class="code-header">impl [...]
-    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Disp [...]
+</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-DataType" class="impl"><a class="srclink rightside" href="../src/arrow_schema/datatype.rs.html#38">source</a><a href="#impl-Clone-for-DataType" class="anchor">§</a><h3 class="code-header">impl [...]
+    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Disp [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
@@ -232,8 +232,8 @@ sufficient, and should not be overridden without very good reason.</div></detail
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Serialize-for-DataType" class="impl"><a class="srclink rightside" href="../src/arrow_schema/datatype.rs.html#39">source</a><a href="#impl-Serialize-for-DataType" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/tr [...]
     __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26DataType%3E-f [...]
-</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblo [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-2" class="associatedtype trait-impl"><a href="#associatedtype.Error-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblo [...]
+</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblo [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Error" class="associatedtype trait-impl"><a href="#associatedtype.Error" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='docblock'> [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/error/enum.ArrowError.html b/arrow_schema/error/enum.ArrowError.html
index 1d333b7ca..1c0bd8d65 100644
--- a/arrow_schema/error/enum.ArrowError.html
+++ b/arrow_schema/error/enum.ArrowError.html
@@ -19,7 +19,7 @@
 </div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.NotYetImplemented" class="variant"><a href="#variant.NotYetImplemented" class="anchor">§</a><h3 class="code-header">NotYetImplemented(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>)</h3></section><div class="docblock"><p>Returned wh [...]
 </div><section id="variant.ExternalError" class="variant"><a href="#variant.ExternalError" class="anchor">§</a><h3 class="code-header">ExternalError(<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/error/trait.Error.html" title="trait core::error::Error">Error</a> + <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Se [...]
 </div><section id="variant.DictionaryKeyOverflowError" class="variant"><a href="#variant.DictionaryKeyOverflowError" class="anchor">§</a><h3 class="code-header">DictionaryKeyOverflowError</h3></section><section id="variant.RunEndIndexOverflowError" class="variant"><a href="#variant.RunEndIndexOverflowError" class="anchor">§</a><h3 class="code-header">RunEndIndexOverflowError</h3></section></div><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations [...]
-</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-Debug-for-ArrowError" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/error.rs.html#25">source</a><a href="#impl-Debug-for-ArrowError" 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-Debug-for-ArrowError" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/error.rs.html#25">source</a><a href="#impl-Debug-for-ArrowError" class="anchor">§</a><h3 class="code-header"> [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/ffi/flags/struct.Flags.html b/arrow_schema/ffi/flags/struct.Flags.html
index 88c6be83f..851d92bf0 100644
--- a/arrow_schema/ffi/flags/struct.Flags.html
+++ b/arrow_schema/ffi/flags/struct.Flags.html
@@ -44,10 +44,10 @@ including any bits that don’t correspond to a defined flag.</p>
 <strong>unsetting</strong> any bits that don’t correspond to a defined flag.</p>
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Flags-2" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Flags-2" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter_names" class="method"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><h4 class="code-header">pub const fn <a href="#method.iter_names" class="fn">iter_names</a>(&amp;self) -&gt; <a class="struct" href="https://docs.rs/bitflags/2.3.3/bitflags/iter/struct.IterNames.html" title="struct bitflags::iter::IterNames">IterNames</a>&lt;<a class="struct" href="stru [...]
-</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-Binary-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Binary-for-Flags" class="anchor">§</a><h3 class="code-header">impl [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-4" class="associatedtype trait-impl"><a href="#associatedtype.Output-4" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The [...]
+</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-Binary-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Binary-for-Flags" class="anchor">§</a><h3 class="code-header">impl [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-2" class="associatedtype trait-impl"><a href="#associatedtype.Output-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The [...]
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BitOr%3CFlags%3E-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-BitOr%3CFlags%3E-for-Flags" class="anchor">§</a><h3 class="code-header">impl <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;<a class="struct" href=" [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-1" class="associatedtype trait-impl"><a href="#associatedtype.Output-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitOr.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The  [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-4" class="associatedtype trait-impl"><a href="#associatedtype.Output-4" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitOr.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The  [...]
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BitXor%3CFlags%3E-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-BitXor%3CFlags%3E-for-Flags" class="anchor">§</a><h3 class="code-header">impl <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;<a class="struct" h [...]
 </div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitXor.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The res [...]
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Extend%3CFlags%3E-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Extend%3CFlags%3E-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html" title="trait core::iter::traits::collect::Extend">Extend</ [...]
@@ -60,10 +60,10 @@ that do not correspond to flags. <a href="https://docs.rs/bitflags/2.3.3/bitflag
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Removes the specified flags in-place. <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.remove">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.toggle-1" class="method trait-impl"><a class="srclink rightside" href= [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Toggles the specified flags in-place. <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.toggle">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.set-1" class="method trait-impl"><a class="srclink rightside" href="ht [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Inserts or removes the specified flags depending on the passed value.</div></details><details class="toggle method-toggle" open><summary><section id="method.intersection-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/bitflags/2.3.3/src/bitflags/traits.rs.html#195" [...]
-in <code>self</code> and <code>other</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.complement-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/bitflags/2.3.3/src/bitflags/traits.rs.html#220">source</a><a href="#method.complement-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.complement" class="fn">complement</a>(self) -&gt; Sel [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-3" class="associatedtype trait-impl"><a href="#associatedtype.Output-3" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The re [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-2" class="associatedtype trait-impl"><a href="#associatedtype.Output-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/arith/trait.Sub.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The  [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-UpperHex-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-UpperHex-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.UpperHex.html" title="trait core::fmt::UpperHex">UpperHex</a> for <a class="struct" href="struct.Flags.ht [...]
+in <code>self</code> and <code>other</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.complement-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/bitflags/2.3.3/src/bitflags/traits.rs.html#220">source</a><a href="#method.complement-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.complement" class="fn">complement</a>(self) -&gt; Sel [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-3" class="associatedtype trait-impl"><a href="#associatedtype.Output-3" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The re [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-1" class="associatedtype trait-impl"><a href="#associatedtype.Output-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/arith/trait.Sub.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>The  [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-UpperHex-for-Flags" class="impl"><a class="srclink rightside" href="../../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-UpperHex-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.UpperHex.html" title="trait core::fmt::UpperHex">UpperHex</a> for <a class="struct" href="struct.Flags.ht [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     B: <a class="trait" href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html" title="trait bitflags::traits::Flags">Flags</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Iter" class="associatedtype trait-impl"><a href="#associatedtype.Iter" class="anchor">§</a><h4 class="code-header">type <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.BitFlags.html#associatedtype.Iter" class="ass [...]
     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="srclink 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="ht [...]
diff --git a/arrow_schema/ffi/struct.FFI_ArrowSchema.html b/arrow_schema/ffi/struct.FFI_ArrowSchema.html
index 7730a1f27..b97e7fc3d 100644
--- a/arrow_schema/ffi/struct.FFI_ArrowSchema.html
+++ b/arrow_schema/ffi/struct.FFI_ArrowSchema.html
@@ -24,9 +24,9 @@ See <a href="https://arrow.apache.org/docs/format/CDataInterface.html#structure-
     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.tuple.html">(S, S)</a>&gt;,
     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.str.html">str</a>&gt;,</span></h4></section><section id="method.empty" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#225-237">source</a><h4 class="code-header">pub fn <a href="#method.empty" class="fn">empty</a>() -&gt; Self</h4></sect [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.name" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#249-255">source</a><h4 class="code-header">pub fn <a href="#method.name" class="fn">name</a>(&amp;self) -&gt; &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a></h4></section></summary><div class="docblock"><p>returns the name of this schema.</p>
-</div></details><section id="method.flags" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#257-259">source</a><h4 class="code-header">pub fn <a href="#method.flags" class="fn">flags</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;<a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a>&gt;</h4></se [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-4" class="associatedtype trait-impl"><a href="#associatedtype.Error-4" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Error-9" class="associatedtype trait-impl"><a href="#associatedtype.Error-9" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
+</div></details><section id="method.flags" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#257-259">source</a><h4 class="code-header">pub fn <a href="#method.flags" class="fn">flags</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;<a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a>&gt;</h4></se [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Error-6" class="associatedtype trait-impl"><a href="#associatedtype.Error-6" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html#associatedtype.Error" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
+</div></details><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" class="associatedtype">Error</a> = <a class="enum" href="../error/enum.ArrowError.html" title="enum arrow_schema::error::ArrowError">ArrowError</a></h4></section></summary><div class='doc [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/ffi/struct.Flags.html b/arrow_schema/ffi/struct.Flags.html
index d7ce35af9..7195b66af 100644
--- a/arrow_schema/ffi/struct.Flags.html
+++ b/arrow_schema/ffi/struct.Flags.html
@@ -44,10 +44,10 @@ including any bits that don’t correspond to a defined flag.</p>
 <strong>unsetting</strong> any bits that don’t correspond to a defined flag.</p>
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Flags-2" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Flags-2" class="anchor">§</a><h3 class="code-header">impl <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summ [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter_names" class="method"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><h4 class="code-header">pub const fn <a href="#method.iter_names" class="fn">iter_names</a>(&amp;self) -&gt; <a class="struct" href="https://docs.rs/bitflags/2.3.3/bitflags/iter/struct.IterNames.html" title="struct bitflags::iter::IterNames">IterNames</a>&lt;<a class="struct" href="flags/s [...]
-</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-Binary-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Binary-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-4" class="associatedtype trait-impl"><a href="#associatedtype.Output-4" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docbloc [...]
+</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-Binary-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Binary-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-2" class="associatedtype trait-impl"><a href="#associatedtype.Output-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitAnd.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docbloc [...]
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BitOr%3CFlags%3E-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-BitOr%3CFlags%3E-for-Flags" class="anchor">§</a><h3 class="code-header">impl <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;<a class="struct" href="fla [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-1" class="associatedtype trait-impl"><a href="#associatedtype.Output-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitOr.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-4" class="associatedtype trait-impl"><a href="#associatedtype.Output-4" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitOr.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock [...]
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-BitXor%3CFlags%3E-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-BitXor%3CFlags%3E-for-Flags" class="anchor">§</a><h3 class="code-header">impl <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;<a class="struct" href [...]
 </div></details><details class="toggle" open><summary><section id="associatedtype.Output" class="associatedtype trait-impl"><a href="#associatedtype.Output" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.BitXor.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'>T [...]
 </div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Extend%3CFlags%3E-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-Extend%3CFlags%3E-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html" title="trait core::iter::traits::collect::Extend">Extend</a>& [...]
@@ -60,10 +60,10 @@ that do not correspond to flags. <a href="https://docs.rs/bitflags/2.3.3/bitflag
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Removes the specified flags in-place. <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.remove">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.toggle-1" class="method trait-impl"><a class="srclink rightside" href= [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Toggles the specified flags in-place. <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.toggle">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.set-1" class="method trait-impl"><a class="srclink rightside" href="ht [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Inserts or removes the specified flags depending on the passed value.</div></details><details class="toggle method-toggle" open><summary><section id="method.intersection-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/bitflags/2.3.3/src/bitflags/traits.rs.html#195" [...]
-in <code>self</code> and <code>other</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.complement-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/bitflags/2.3.3/src/bitflags/traits.rs.html#220">source</a><a href="#method.complement-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.complement" class="fn">complement</a>(self) -&gt; Sel [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-3" class="associatedtype trait-impl"><a href="#associatedtype.Output-3" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'> [...]
-</div></details><details class="toggle" open><summary><section id="associatedtype.Output-2" class="associatedtype trait-impl"><a href="#associatedtype.Output-2" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/arith/trait.Sub.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock [...]
-</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-UpperHex-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-UpperHex-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.UpperHex.html" title="trait core::fmt::UpperHex">UpperHex</a> for <a class="struct" href="flags/struct.Flags [...]
+in <code>self</code> and <code>other</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.complement-1" class="method trait-impl"><a class="srclink rightside" href="https://docs.rs/bitflags/2.3.3/src/bitflags/traits.rs.html#220">source</a><a href="#method.complement-1" class="anchor">§</a><h4 class="code-header">fn <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html#method.complement" class="fn">complement</a>(self) -&gt; Sel [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-3" class="associatedtype trait-impl"><a href="#associatedtype.Output-3" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock'> [...]
+</div></details><details class="toggle" open><summary><section id="associatedtype.Output-1" class="associatedtype trait-impl"><a href="#associatedtype.Output-1" class="anchor">§</a><h4 class="code-header">type <a href="https://doc.rust-lang.org/nightly/core/ops/arith/trait.Sub.html#associatedtype.Output" class="associatedtype">Output</a> = <a class="struct" href="flags/struct.Flags.html" title="struct arrow_schema::ffi::flags::Flags">Flags</a></h4></section></summary><div class='docblock [...]
+</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-UpperHex-for-Flags" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/ffi.rs.html#50-56">source</a><a href="#impl-UpperHex-for-Flags" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/fmt/trait.UpperHex.html" title="trait core::fmt::UpperHex">UpperHex</a> for <a class="struct" href="flags/struct.Flags [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     B: <a class="trait" href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.Flags.html" title="trait bitflags::traits::Flags">Flags</a>,</span></h3></section></summary><div class="impl-items"><details class="toggle" open><summary><section id="associatedtype.Iter" class="associatedtype trait-impl"><a href="#associatedtype.Iter" class="anchor">§</a><h4 class="code-header">type <a href="https://docs.rs/bitflags/2.3.3/bitflags/traits/trait.BitFlags.html#associatedtype.Iter" class="ass [...]
     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="srclink 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="ht [...]
diff --git a/arrow_schema/field/struct.Field.html b/arrow_schema/field/struct.Field.html
index 18031cdab..93084273c 100644
--- a/arrow_schema/field/struct.Field.html
+++ b/arrow_schema/field/struct.Field.html
@@ -146,7 +146,7 @@ by <code>==</code>.</div></details><details class="toggle method-toggle" open><s
 sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CField%3E-for-Field" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/field.rs.html#63-67">source</a><a href="#impl-PartialOrd%3CField%3E-for-Field" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.htm [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Serialize-for-Field" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/field.rs.html#36">source</a><a href="#impl-Serialize-for-Field" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Se [...]
-    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
+    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/fields/struct.Fields.html b/arrow_schema/fields/struct.Fields.html
index a749a67f6..61adb7ebc 100644
--- a/arrow_schema/fields/struct.Fields.html
+++ b/arrow_schema/fields/struct.Fields.html
@@ -1076,7 +1076,7 @@ is mapped to its ASCII lower case equivalent.</p>
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
 </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-Fields" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/fields.rs.html#41">source</a><a href="#impl-Clone-for-Fields" class="anchor">§</a><h3 class="code-header">impl <a class="trait" h [...]
-    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/arrow_schema/index.html b/arrow_schema/index.html
index 4e382ee66..696bfe79a 100644
--- a/arrow_schema/index.html
+++ b/arrow_schema/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="Arrow logical types"><title>arrow_schema - Rust</title><link rel="preload" 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/FiraSans-Regular-018 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Arrow logical types"><title>arrow_schema - Rust</title><link rel="preload" 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/FiraSans-Regular-018 [...]
 </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="datatype/index.html" title="mod arrow_schema::datatype">datatype</a><span title="Restricted Visibility">&nbsp;🔒</span> </div></li><li><div class="item-name"><a class="mod" href="error/index.html" title="mod arrow_schema::error">error</a><span title="Restricted Visibility">&nbsp;🔒</span> </div><div class="desc docblock-shor [...]
 values</div></li></ul><h2 id="types" class="small-section-header"><a href="#types">Type Definitions</a></h2><ul class="item-table"><li><div class="item-name"><a class="type" href="type.FieldRef.html" title="type arrow_schema::FieldRef">FieldRef</a></div><div class="desc docblock-short">A reference counted <a href="field/struct.Field.html" title="struct arrow_schema::field::Field"><code>Field</code></a></div></li><li><div class="item-name"><a class="type" href="type.SchemaRef.html" title= [...]
\ No newline at end of file
diff --git a/arrow_schema/schema/struct.Schema.html b/arrow_schema/schema/struct.Schema.html
index 9ea99ca8c..2cf4b8f70 100644
--- a/arrow_schema/schema/struct.Schema.html
+++ b/arrow_schema/schema/struct.Schema.html
@@ -76,7 +76,7 @@ and <a href="../fields/struct.Fields.html#method.contains" title="method arrow_s
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
 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="srclink" 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" 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-Serialize-for-Schema" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#122">source</a><a href="#impl-Serialize-for-Schema" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser: [...]
-    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
+    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/schema/struct.SchemaBuilder.html b/arrow_schema/schema/struct.SchemaBuilder.html
index af7bfc7df..405e9b00e 100644
--- a/arrow_schema/schema/struct.SchemaBuilder.html
+++ b/arrow_schema/schema/struct.SchemaBuilder.html
@@ -7,7 +7,7 @@
 </div></details><details class="toggle method-toggle" open><summary><section id="method.try_merge" class="method"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#54-70">source</a><h4 class="code-header">pub fn <a href="#method.try_merge" class="fn">try_merge</a>(&amp;mut self, field: &amp;<a class="type" href="../field/type.FieldRef.html" title="type arrow_schema::field::FieldRef">FieldRef</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/re [...]
 <p>If an existing field exists with the same name, calls <a href="../field/struct.Field.html#method.try_merge" title="method arrow_schema::field::Field::try_merge"><code>Field::try_merge</code></a></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#73-75">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(self) -&gt; <a class="struct" href="struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a></h4></section></summary><div class="docblock"><p>Consume this <a href="struct.SchemaBuilder.html" titl [...]
-</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-Debug-for-SchemaBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#28">source</a><a href="#impl-Debug-for-SchemaBuilder" class="anchor">§</a><h3 class="code-h [...]
+</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-Debug-for-SchemaBuilder" class="impl"><a class="srclink rightside" href="../../src/arrow_schema/schema.rs.html#28">source</a><a href="#impl-Debug-for-SchemaBuilder" class="anchor">§</a><h3 class="code-h [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/struct.Field.html b/arrow_schema/struct.Field.html
index 61bbd5e63..50c73025b 100644
--- a/arrow_schema/struct.Field.html
+++ b/arrow_schema/struct.Field.html
@@ -146,7 +146,7 @@ by <code>==</code>.</div></details><details class="toggle method-toggle" open><s
 sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CField%3E-for-Field" class="impl"><a class="srclink rightside" href="../src/arrow_schema/field.rs.html#63-67">source</a><a href="#impl-PartialOrd%3CField%3E-for-Field" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html"  [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-Serialize-for-Field" class="impl"><a class="srclink rightside" href="../src/arrow_schema/field.rs.html#36">source</a><a href="#impl-Serialize-for-Field" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Seria [...]
-    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
+    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/struct.Fields.html b/arrow_schema/struct.Fields.html
index 911f7004e..257c1c73e 100644
--- a/arrow_schema/struct.Fields.html
+++ b/arrow_schema/struct.Fields.html
@@ -1076,7 +1076,7 @@ is mapped to its ASCII lower case equivalent.</p>
 but non-ASCII letters are unchanged.</p>
 <p>To lowercase the value in-place, use <a href="https://doc.rust-lang.org/nightly/std/primitive.slice.html#method.make_ascii_lowercase" title="method slice::make_ascii_lowercase"><code>make_ascii_lowercase</code></a>.</p>
 </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-Fields" class="impl"><a class="srclink rightside" href="../src/arrow_schema/fields.rs.html#41">source</a><a href="#impl-Clone-for-Fields" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href [...]
-    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
+    __D: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserializer.html" title="trait serde::de::Deserializer">Deserializer</a>&lt;'de&gt;,</span></h4></section></summary><div class='docblock'>Deserialize this value from the given Serde deserializer. <a href="https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html#tymethod.deserialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-From [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/arrow_schema/struct.Schema.html b/arrow_schema/struct.Schema.html
index ead7616f2..4088bc9df 100644
--- a/arrow_schema/struct.Schema.html
+++ b/arrow_schema/struct.Schema.html
@@ -76,7 +76,7 @@ and <a href="fields/struct.Fields.html#method.contains" title="method arrow_sche
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
 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="srclink" 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" 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-Serialize-for-Schema" class="impl"><a class="srclink rightside" href="../src/arrow_schema/schema.rs.html#122">source</a><a href="#impl-Serialize-for-Schema" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html" title="trait serde::ser::Se [...]
-    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
+    __S: <a class="trait" href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serializer.html" title="trait serde::ser::Serializer">Serializer</a>,</span></h4></section></summary><div class='docblock'>Serialize this value into the given Serde serializer. <a href="https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html#tymethod.serialize">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-TryFrom%3C%26FFI_ArrowSche [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_schema/struct.SchemaBuilder.html b/arrow_schema/struct.SchemaBuilder.html
index b7a173d60..799f5753b 100644
--- a/arrow_schema/struct.SchemaBuilder.html
+++ b/arrow_schema/struct.SchemaBuilder.html
@@ -7,7 +7,7 @@
 </div></details><details class="toggle method-toggle" open><summary><section id="method.try_merge" class="method"><a class="srclink rightside" href="../src/arrow_schema/schema.rs.html#54-70">source</a><h4 class="code-header">pub fn <a href="#method.try_merge" class="fn">try_merge</a>(&amp;mut self, field: &amp;<a class="type" href="field/type.FieldRef.html" title="type arrow_schema::field::FieldRef">FieldRef</a>) -&gt; <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/e [...]
 <p>If an existing field exists with the same name, calls <a href="field/struct.Field.html#method.try_merge" title="method arrow_schema::field::Field::try_merge"><code>Field::try_merge</code></a></p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.finish" class="method"><a class="srclink rightside" href="../src/arrow_schema/schema.rs.html#73-75">source</a><h4 class="code-header">pub fn <a href="#method.finish" class="fn">finish</a>(self) -&gt; <a class="struct" href="schema/struct.Schema.html" title="struct arrow_schema::schema::Schema">Schema</a></h4></section></summary><div class="docblock"><p>Consume this <a href="schema/struct.SchemaBuilder [...]
-</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-Debug-for-SchemaBuilder" class="impl"><a class="srclink rightside" href="../src/arrow_schema/schema.rs.html#28">source</a><a href="#impl-Debug-for-SchemaBuilder" class="anchor">§</a><h3 class="code-head [...]
+</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-Debug-for-SchemaBuilder" class="impl"><a class="srclink rightside" href="../src/arrow_schema/schema.rs.html#28">source</a><a href="#impl-Debug-for-SchemaBuilder" class="anchor">§</a><h3 class="code-head [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/arrow_select/index.html b/arrow_select/index.html
index a77d8fc32..ede38d9c3 100644
--- a/arrow_select/index.html
+++ b/arrow_select/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="Arrow selection kernels"><title>arrow_select - Rust</title><link rel="preload" 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/FiraSans-Regular [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Arrow selection kernels"><title>arrow_select - Rust</title><link rel="preload" 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/FiraSans-Regular [...]
 </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="concat/index.html" title="mod arrow_select::concat">concat</a></div><div class="desc docblock-short">Defines concat kernel for <code>ArrayRef</code></div></li><li><div class="item-name"><a class="mod" href="filter/index.html" title="mod arrow_select::filter">filter</a></div><div class="desc docblock-short">Defines filter k [...]
\ No newline at end of file
diff --git a/arrow_stream_to_file/index.html b/arrow_stream_to_file/index.html
index 2345a53f2..dad727f78 100644
--- a/arrow_stream_to_file/index.html
+++ b/arrow_stream_to_file/index.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 `arrow_stream_to_file` crate."><title>arrow_stream_to_file - Rust</title><link 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 [...]
\ 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 `arrow_stream_to_file` crate."><title>arrow_stream_to_file - Rust</title><link 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 [...]
\ No newline at end of file
diff --git a/arrow_string/index.html b/arrow_string/index.html
index 2cbffc5be..484c6c212 100644
--- a/arrow_string/index.html
+++ b/arrow_string/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="Arrow string kernels"><title>arrow_string - Rust</title><link rel="preload" 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/FiraSans-Regular-01 [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Arrow string kernels"><title>arrow_string - Rust</title><link rel="preload" 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/FiraSans-Regular-01 [...]
 </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="concat_elements/index.html" title="mod arrow_string::concat_elements">concat_elements</a></div></li><li><div class="item-name"><a class="mod" href="length/index.html" title="mod arrow_string::length">length</a></div><div class="desc docblock-short">Defines kernel for length of string arrays and binary arrays</div></li><li> [...]
 expression of a [Large]StringArray</div></li><li><div class="item-name"><a class="mod" href="substring/index.html" title="mod arrow_string::substring">substring</a></div><div class="desc docblock-short">Defines kernel to extract a substring of an Array
 Supported array types:
diff --git a/flight_sql_client/index.html b/flight_sql_client/index.html
index 752891205..b802071c3 100644
--- a/flight_sql_client/index.html
+++ b/flight_sql_client/index.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 `flight_sql_client` crate."><title>flight_sql_client - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
\ 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 `flight_sql_client` crate."><title>flight_sql_client - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin [...]
\ No newline at end of file
diff --git a/flight_test_integration_client/index.html b/flight_test_integration_client/index.html
index cd29f0fa1..29784a85b 100644
--- a/flight_test_integration_client/index.html
+++ b/flight_test_integration_client/index.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 `flight_test_integration_client` crate."><title>flight_test_integration_client - 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 [...]
\ 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 `flight_test_integration_client` crate."><title>flight_test_integration_client - 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 [...]
\ No newline at end of file
diff --git a/flight_test_integration_server/index.html b/flight_test_integration_server/index.html
index 16eadef57..1dbe795fe 100644
--- a/flight_test_integration_server/index.html
+++ b/flight_test_integration_server/index.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 `flight_test_integration_server` crate."><title>flight_test_integration_server - 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 [...]
\ 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 `flight_test_integration_server` crate."><title>flight_test_integration_server - 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 [...]
\ No newline at end of file
diff --git a/implementors/arrow_flight/gen/flight_service_server/trait.FlightService.js b/implementors/arrow_flight/gen/flight_service_server/trait.FlightService.js
index 22d024b50..df82a2b4a 100644
--- a/implementors/arrow_flight/gen/flight_service_server/trait.FlightService.js
+++ b/implementors/arrow_flight/gen/flight_service_server/trait.FlightService.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
 "arrow_flight":[],
-"arrow_integration_testing":[["impl FlightService for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/middleware/struct.MiddlewareScenarioImpl.html\" title=\"struct arrow_integration_testing::flight_server_scenarios::middleware::MiddlewareScenarioImpl\">MiddlewareScenarioImpl</a>"],["impl FlightService for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html\" title=\"struct arrow [...]
+"arrow_integration_testing":[["impl <a class=\"trait\" href=\"arrow_flight/gen/flight_service_server/trait.FlightService.html\" title=\"trait arrow_flight::gen::flight_service_server::FlightService\">FlightService</a> for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html\" title=\"struct arrow_integration_testing::flight_server_scenarios::auth_basic_proto::AuthBasicProtoScenarioImpl\">AuthBasicProtoScenari [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/clap_builder/derive/trait.Parser.js b/implementors/clap_builder/derive/trait.Parser.js
index c3b864532..21b1dfe2b 100644
--- a/implementors/clap_builder/derive/trait.Parser.js
+++ b/implementors/clap_builder/derive/trait.Parser.js
@@ -1,7 +1,7 @@
 (function() {var implementors = {
 "arrow_file_to_stream":[["impl Parser for <a class=\"struct\" href=\"arrow_file_to_stream/struct.Args.html\" title=\"struct arrow_file_to_stream::Args\">Args</a>"]],
 "arrow_json_integration_test":[["impl Parser for <a class=\"struct\" href=\"arrow_json_integration_test/struct.Args.html\" title=\"struct arrow_json_integration_test::Args\">Args</a>"]],
-"flight_sql_client":[["impl Parser for <a class=\"struct\" href=\"flight_sql_client/struct.ClientArgs.html\" title=\"struct flight_sql_client::ClientArgs\">ClientArgs</a>"],["impl Parser for <a class=\"struct\" href=\"flight_sql_client/struct.Args.html\" title=\"struct flight_sql_client::Args\">Args</a>"]],
+"flight_sql_client":[["impl Parser for <a class=\"struct\" href=\"flight_sql_client/struct.Args.html\" title=\"struct flight_sql_client::Args\">Args</a>"],["impl Parser for <a class=\"struct\" href=\"flight_sql_client/struct.ClientArgs.html\" title=\"struct flight_sql_client::ClientArgs\">ClientArgs</a>"]],
 "flight_test_integration_client":[["impl Parser for <a class=\"struct\" href=\"flight_test_integration_client/struct.Args.html\" title=\"struct flight_test_integration_client::Args\">Args</a>"]],
 "flight_test_integration_server":[["impl Parser for <a class=\"struct\" href=\"flight_test_integration_server/struct.Args.html\" title=\"struct flight_test_integration_server::Args\">Args</a>"]],
 "parquet_concat":[["impl Parser for <a class=\"struct\" href=\"parquet_concat/struct.Args.html\" title=\"struct parquet_concat::Args\">Args</a>"]],
diff --git a/implementors/core/clone/trait.Clone.js b/implementors/core/clone/trait.Clone.js
index 5ccef31a1..3255c8e5e 100644
--- a/implementors/core/clone/trait.Clone.js
+++ b/implementors/core/clone/trait.Clone.js
@@ -1,24 +1,24 @@
 (function() {var implementors = {
 "arrow":[["impl&lt;T: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow/util/test_util/struct.BadIterator.html\" title=\"struct arrow::util::test_util::BadIterator\">BadIterator</a>&lt;T&gt;"]],
-"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_array/array/boolean_array/struct.BooleanArray.html\" title=\"struct arrow_array::array::boolean_array::BooleanArray\">BooleanArray</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"stru [...]
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_buffer/buffer/immutable/struct.Buffer.html\" title=\"struct arrow_buffer::buffer::immutable::Buffer\">Buffer</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_buf [...]
-"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.IntervalAmount.html\" title=\"struct arrow_cast::parse::IntervalAmount\">IntervalAmount</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arro [...]
-"arrow_csv":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_csv/reader/records/struct.StringRecord.html\" title=\"struct arrow_csv::reader::records::StringRecord\">StringRecord</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\" [...]
-"arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\" [...]
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.XdbcDatetimeSubcode.html\" title=\"enum arrow_flight::sql::gen::XdbcDatetimeSubcode\">XdbcDatetimeSubcode</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" h [...]
-"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonDictionaryBatch.html\" title=\"struct arrow_integration_test::ArrowJsonDictionaryBatch\">ArrowJsonDictionaryBatch</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Cl [...]
-"arrow_integration_testing":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/auth_basic_proto/struct.AuthBasicProtoScenarioImpl.html\" title=\"struct arrow_integration_testing::flight_server_scenarios::auth_basic_proto::AuthBasicProtoScenarioImpl\">AuthBasicProtoScenarioImpl</a>"],["impl <a class=\"trait\" href=\"ht [...]
-"arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Bool.html\" title=\"struct arrow_ipc::gen::Schema::Bool\">Bool</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_ipc/compress [...]
-"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_json/reader/ [...]
+"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_array/timezone/private/struct.TzOffset.html\" title=\"struct arrow_array::timezone::private::TzOffset\">TzOffset</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_ [...]
+"arrow_buffer":[["impl&lt;O: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> + <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_b [...]
+"arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_cast/display/struct.FormatOptions.html\" title=\"struct arrow_cast::display::FormatOptions\">FormatOptions</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\ [...]
+"arrow_csv":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_csv/reader/records/struct.StringRecord.html\" title=\"struct arrow_csv::reader::records::StringRecord\">StringRecord</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\" [...]
+"arrow_data":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_data/transform/enum.Capacities.html\" title=\"enum arrow_data::transform::Capacities\">Capacities</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_data/data/struct.A [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_flight/gen/struct.BasicAuth.html\" title=\"struct arrow_flight::gen::BasicAuth\">BasicAuth</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.Sql [...]
+"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonBatch.html\" title=\"struct arrow_integration_test::ArrowJsonBatch\">ArrowJsonBatch</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\ [...]
+"arrow_integration_testing":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/integration_test/struct.IntegrationDataset.html\" title=\"struct arrow_integration_testing::flight_server_scenarios::integration_test::IntegrationDataset\">IntegrationDataset</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/ [...]
+"arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Binary.html\" title=\"struct arrow_ipc::gen::Schema::Binary\">Binary</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\" [...]
+"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_json/reader/ [...]
 "arrow_json_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_json_integration_test/enum.Mode.html\" title=\"enum arrow_json_integration_test::Mode\">Mode</a>"]],
 "arrow_ord":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_ord/sort/struct.SortColumn.html\" title=\"struct arrow_ord::sort::SortColumn\">SortColumn</a>"]],
-"arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"st [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.IntervalUnit.html\" title=\"enum arrow_schema::datatype::IntervalUnit\">IntervalUnit</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_schema/f [...]
+"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Bucket.html\" title=\"struct arrow_row::interner::Bucket\">Bucket</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Slot.html [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.DataType.html\" title=\"enum arrow_schema::datatype::DataType\">DataType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.I [...]
 "arrow_select":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"arrow_select/take/struct.TakeOptions.html\" title=\"struct arrow_select::take::TakeOptions\">TakeOptions</a>"]],
 "flight_sql_client":[["impl&lt;K: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a>, V: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"flight_sql_cli [...]
 "flight_test_integration_client":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"flight_test_integration_client/enum.Scenario.html\" title=\"enum flight_test_integration_client::Scenario\">Scenario</a>"]],
 "flight_test_integration_server":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"flight_test_integration_server/enum.Scenario.html\" title=\"enum flight_test_integration_server::Scenario\">Scenario</a>"]],
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"parquet/arrow/arrow_reader/struct.ArrowReaderOptions.html\" title=\"struct parquet::arrow::arrow_reader::ArrowReaderOptions\">ArrowReaderOptions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\" [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"parquet/format/struct.TypeDefinedOrder.html\" title=\"struct parquet::format::TypeDefinedOrder\">TypeDefinedOrder</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"struct\" href=\"parquet/format/ [...]
 "parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.CsvDialect.html\" title=\"enum parquet_fromcsv::CsvDialect\">CsvDialect</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTermi [...]
-"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"parquet_rewrite/e [...]
+"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a> for <a class=\"enum\" href=\"parquet_rewrite/e [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/cmp/trait.Eq.js b/implementors/core/cmp/trait.Eq.js
index cc9acd5b0..06281c80b 100644
--- a/implementors/core/cmp/trait.Eq.js
+++ b/implementors/core/cmp/trait.Eq.js
@@ -1,13 +1,13 @@
 (function() {var implementors = {
 "arrow_array":[["impl&lt;T: ToByteSlice&gt; <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=\"arrow_array/builder/primitive_dictionary_builder/struct.Value.html\" title=\"struct arrow_array::builder::primitive_dictionary_builder::Value\">Value</a>&lt;T&gt;"]],
-"arrow_buffer":[["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=\"arrow_buffer/buffer/null/struct.NullBuffer.html\" title=\"struct arrow_buffer::buffer::null::NullBuffer\">NullBuffer</a>"],["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=\"arrow_buffer/bigint/struct.i256.h [...]
-"arrow_cast":[["impl&lt;'a&gt; <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=\"arrow_cast/display/struct.FormatOptions.html\" title=\"struct arrow_cast::display::FormatOptions\">FormatOptions</a>&lt;'a&gt;"],["impl&lt;'a&gt; <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=\"arrow_cas [...]
-"arrow_data":[["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=\"enum\" href=\"arrow_data/data/enum.BufferSpec.html\" title=\"enum arrow_data::data::BufferSpec\">BufferSpec</a>"],["impl&lt;'a&gt; <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=\"arrow_data/data/buffers/struct.Buffers.html\" titl [...]
-"arrow_flight":[["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=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedCaseSensitivity.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedCaseSensitivity\">SqlSupportedCaseSensitivity</a>"],["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=\"enum\" href= [...]
-"arrow_ipc":[["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=\"arrow_ipc/gen/Schema/struct.TimeUnit.html\" title=\"struct arrow_ipc::gen::Schema::TimeUnit\">TimeUnit</a>"],["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=\"arrow_ipc/gen/Schema/struct.DateUnit.html\" title= [...]
+"arrow_buffer":[["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=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"],["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=\"arrow_buffer/buffer/null/struct.NullBuffer.html\" title=\"stru [...]
+"arrow_cast":[["impl&lt;'a&gt; <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=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;"],["impl&lt;'a&gt; <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=\"arrow_cast/display/st [...]
+"arrow_data":[["impl&lt;'a&gt; <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=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"],["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=\"enum\" href=\"arrow_data/data/enum.BufferS [...]
+"arrow_flight":[["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=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedElementActions.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedElementActions\">SqlSupportedElementActions</a>"],["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=\"enum\" href=\"a [...]
+"arrow_ipc":[["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=\"arrow_ipc/gen/Schema/struct.DictionaryKind.html\" title=\"struct arrow_ipc::gen::Schema::DictionaryKind\">DictionaryKind</a>"],["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=\"arrow_ipc/gen/Schema/struct.Unio [...]
 "arrow_json":[["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=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"]],
-"arrow_row":[["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=\"arrow_row/interner/struct.Interned.html\" title=\"struct arrow_row::interner::Interned\">Interned</a>"],["impl&lt;'a&gt; <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=\"arrow_row/struct.Row.html\" title=\"struct ar [...]
-"arrow_schema":[["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=\"enum\" href=\"arrow_schema/datatype/enum.IntervalUnit.html\" title=\"enum arrow_schema::datatype::IntervalUnit\">IntervalUnit</a>"],["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=\"arrow_schema/field/struct.Field.html\" t [...]
-"parquet":[["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=\"enum\" href=\"parquet/format/enum.TimeUnit.html\" title=\"enum parquet::format::TimeUnit\">TimeUnit</a>"],["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=\"parquet/format/struct.EncryptionWithFooterKey.html\" title=\"struct par [...]
+"arrow_row":[["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=\"arrow_row/struct.SortField.html\" title=\"struct arrow_row::SortField\">SortField</a>"],["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=\"arrow_row/struct.OwnedRow.html\" title=\"struct arrow_row::OwnedRow\">O [...]
+"arrow_schema":[["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=\"enum\" href=\"arrow_schema/datatype/enum.TimeUnit.html\" title=\"enum arrow_schema::datatype::TimeUnit\">TimeUnit</a>"],["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=\"arrow_schema/schema/struct.Schema.html\" title=\"str [...]
+"parquet":[["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=\"parquet/format/struct.AesGcmCtrV1.html\" title=\"struct parquet::format::AesGcmCtrV1\">AesGcmCtrV1</a>"],["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=\"parquet/format/struct.BoundaryOrder.html\" title=\"struc [...]
 "parquet_rewrite":[["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=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["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=\"enum\" href=\"parquet_rewrite/enum.EnabledStatisticsArgs. [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/cmp/trait.Ord.js b/implementors/core/cmp/trait.Ord.js
index e9e6e9a14..88aede611 100644
--- a/implementors/core/cmp/trait.Ord.js
+++ b/implementors/core/cmp/trait.Ord.js
@@ -1,9 +1,9 @@
 (function() {var implementors = {
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"]],
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.Nullable.html\" title=\"enum arrow_flight::sql::gen::Nullable\">Nullable</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedTransaction [...]
-"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.TimeUnit.html\" title=\"struct arrow_ipc::gen::Schema::TimeUnit\">TimeUnit</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Endianness.html\ [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedSubqueries.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedSubqueries\">SqlSupportedSubqueries</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"arrow_f [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.MetadataVersion.html\" title=\"struct arrow_ipc::gen::Schema::MetadataVersion\">MetadataVersion</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/st [...]
 "arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"struct arrow_row::Owne [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" titl [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"parquet/format/struct.Type.html\" title=\"struct parquet::format::Type\">Type</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"parquet/format/struct.Statistics.html\" title=\"struct parquet::format: [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.TimeUnit.html\" title=\"enum arrow_schema::datatype::TimeUnit\">TimeUnit</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"arrow_schema/struct.SortOptions.html\" title=\ [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"parquet/basic/enum.Encoding.html\" title=\"enum parquet::basic::Encoding\">Encoding</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"struct\" href=\"parquet/format/struct.AesGcmCtrV1.html\" title=\"struct parquet::fo [...]
 "parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.EnabledStatisticsArgs.html\" title=\"enum parquet_rewrite::EnabledStatisticsArgs\">EnabledStatisticsArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html\" title=\"trait core::cmp::Ord\">Ord</a> for <a class=\"enum\" href=\"parquet_rewrite/enu [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/cmp/trait.PartialEq.js b/implementors/core/cmp/trait.PartialEq.js
index fcadf2385..5259a07b8 100644
--- a/implementors/core/cmp/trait.PartialEq.js
+++ b/implementors/core/cmp/trait.PartialEq.js
@@ -1,15 +1,15 @@
 (function() {var implementors = {
-"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_array/array/boolean_array/struct.BooleanArray.html\" title=\"struct arrow_array::array::boolean_array::BooleanArray\">BooleanArray</a>&gt; for <a class=\"struct\" href=\"arrow_array/array/boolean_array/struct.BooleanArray.html\" title=\"struct arrow_array::array::boolean_array::BooleanArray [...]
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>&gt; for <a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/c [...]
-"arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;"],["impl <a class=\"tra [...]
-"arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"],["impl <a c [...]
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_flight/gen/struct.PutResult.html\" title=\"struct arrow_flight::gen::PutResult\">PutResult</a>&gt; for <a class=\"struct\" href=\"arrow_flight/gen/struct.PutResult.html\" title=\"struct arrow_flight::gen::PutResult\">PutResult</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.or [...]
-"arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Timestamp.html\" title=\"struct arrow_ipc::gen::Schema::Timestamp\">Timestamp</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Timestamp.html\" title=\"struct arrow_ipc::gen::Schema::Timestamp\">Timestamp</a>&lt;'a&gt;"],["impl&lt;'a [...]
+"arrow_array":[["impl&lt;OffsetSize: <a class=\"trait\" href=\"arrow_array/array/list_array/trait.OffsetSizeTrait.html\" title=\"trait arrow_array::array::list_array::OffsetSizeTrait\">OffsetSizeTrait</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_array/array/list_array/struct.GenericListArray.html\" title=\"struct arrow_array::array::list_array::Gen [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>&gt; for <a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/c [...]
+"arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_cast/display/struct.FormatOptions.html\" title=\"struct arrow_cast::display::FormatOptions\">FormatOptions</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_cast/display/struct.FormatOptions.html\" title=\"struct arrow_cast::display::FormatOptions\">FormatOptions</a>&lt;'a&gt; [...]
+"arrow_data":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"arrow_data/data/enum.BufferSpec.html\" title=\"enum arrow_data::data::BufferSpec\">BufferSpec</a>&gt; for <a class=\"enum\" href=\"arrow_data/data/enum.BufferSpec.html\" title=\"enum arrow_data::data::BufferSpec\">BufferSpec</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/co [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"arrow_flight/sql/gen/enum.Searchable.html\" title=\"enum arrow_flight::sql::gen::Searchable\">Searchable</a>&gt; for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.Searchable.html\" title=\"enum arrow_flight::sql::gen::Searchable\">Searchable</a>"],["impl <a class=\"trait\" href=\"https://doc. [...]
+"arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_ipc/gen/SparseTensor/struct.SparseTensorIndexCSF.html\" title=\"struct arrow_ipc::gen::SparseTensor::SparseTensorIndexCSF\">SparseTensorIndexCSF</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/SparseTensor/struct.SparseTensorIndexCSF.html\" title=\"struct arrow_ipc::g [...]
 "arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>&gt; for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"]],
-"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"struct arrow_row::OwnedRow\">OwnedRow</a>&gt; for <a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"struct arrow_row::OwnedRow\">OwnedRow</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>&gt; for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl <a class=\"trait\" href=\"https://doc.rust [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"parquet/file/properties/struct.ColumnProperties.html\" title=\"struct parquet::file::properties::ColumnProperties\">ColumnProperties</a>&gt; for <a class=\"struct\" href=\"parquet/file/properties/struct.ColumnProperties.html\" title=\"struct parquet::file::properties::ColumnProperties\">ColumnPropert [...]
-"parquet_derive":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"parquet_derive/parquet_field/enum.ThirdPartyType.html\" title=\"enum parquet_derive::parquet_field::ThirdPartyType\">ThirdPartyType</a>&gt; for <a class=\"enum\" href=\"parquet_derive/parquet_field/enum.ThirdPartyType.html\" title=\"enum parquet_derive::parquet_field::ThirdPartyType\">ThirdParty [...]
+"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"arrow_row/struct.SortField.html\" title=\"struct arrow_row::SortField\">SortField</a>&gt; for <a class=\"struct\" href=\"arrow_row/struct.SortField.html\" title=\"struct arrow_row::SortField\">SortField</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialE [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"arrow_schema/datatype/enum.IntervalUnit.html\" title=\"enum arrow_schema::datatype::IntervalUnit\">IntervalUnit</a>&gt; for <a class=\"enum\" href=\"arrow_schema/datatype/enum.IntervalUnit.html\" title=\"enum arrow_schema::datatype::IntervalUnit\">IntervalUnit</a>"],["impl <a class=\"trait\" href= [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"struct\" href=\"parquet/schema/types/struct.BasicTypeInfo.html\" title=\"struct parquet::schema::types::BasicTypeInfo\">BasicTypeInfo</a>&gt; for <a class=\"struct\" href=\"parquet/schema/types/struct.BasicTypeInfo.html\" title=\"struct parquet::schema::types::BasicTypeInfo\">BasicTypeInfo</a>"],["impl <a class=\"tr [...]
+"parquet_derive":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"parquet_derive/parquet_field/enum.ThirdPartyType.html\" title=\"enum parquet_derive::parquet_field::ThirdPartyType\">ThirdPartyType</a>&gt; for <a class=\"enum\" href=\"parquet_derive/parquet_field/enum.ThirdPartyType.html\" title=\"enum parquet_derive::parquet_field::ThirdPartyType\">ThirdParty [...]
 "parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTerminator.html\" title=\"enum parquet_fromcsv::RecordTerminator\">RecordTerminator</a>&gt; for <a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTerminator.html\" title=\"enum parquet_fromcsv::RecordTerminator\">RecordTerminator</a>"],["impl <a class=\"trait\" href [...]
 "parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html\" title=\"trait core::cmp::PartialEq\">PartialEq</a>&lt;<a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>&gt; for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["impl <a class=\"trait\" href=\"htt [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/cmp/trait.PartialOrd.js b/implementors/core/cmp/trait.PartialOrd.js
index f167cce7c..f5ec37d6c 100644
--- a/implementors/core/cmp/trait.PartialOrd.js
+++ b/implementors/core/cmp/trait.PartialOrd.js
@@ -1,9 +1,9 @@
 (function() {var implementors = {
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>&gt; for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"]],
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedSubqueries.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedSubqueries\">SqlSupportedSubqueries</a>&gt; for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedSubqueries.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedSubqueries\" [...]
-"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.DateUnit.html\" title=\"struct arrow_ipc::gen::Schema::DateUnit\">DateUnit</a>&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.DateUnit.html\" title=\"struct arrow_ipc::gen::Schema::DateUnit\">DateUnit</a>"],["impl <a class=\"trait\" href=\"https://doc. [...]
-"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"struct arrow_row::OwnedRow\">OwnedRow</a>&gt; for <a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"struct arrow_row::OwnedRow\">OwnedRow</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.P [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"enum\" href=\"arrow_schema/datatype/enum.IntervalUnit.html\" title=\"enum arrow_schema::datatype::IntervalUnit\">IntervalUnit</a>&gt; for <a class=\"enum\" href=\"arrow_schema/datatype/enum.IntervalUnit.html\" title=\"enum arrow_schema::datatype::IntervalUnit\">IntervalUnit</a>"],["impl <a class=\"trait\" hr [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"parquet/format/struct.ColumnChunk.html\" title=\"struct parquet::format::ColumnChunk\">ColumnChunk</a>&gt; for <a class=\"struct\" href=\"parquet/format/struct.ColumnChunk.html\" title=\"struct parquet::format::ColumnChunk\">ColumnChunk</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang. [...]
-"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>&gt; for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["impl <a class=\"trait\" href=\" [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedElementActions.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedElementActions\">SqlSupportedElementActions</a>&gt; for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedElementActions.html\" title=\"enum arrow_flight::sql::gen::SqlSuppo [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Endianness.html\" title=\"struct arrow_ipc::gen::Schema::Endianness\">Endianness</a>&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Endianness.html\" title=\"struct arrow_ipc::gen::Schema::Endianness\">Endianness</a>"],["impl <a class=\"trait\" href=\" [...]
+"arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd. [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>&gt; for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl <a class=\"trait\" href=\"https://doc.r [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"struct\" href=\"parquet/data_type/struct.ByteArray.html\" title=\"struct parquet::data_type::ByteArray\">ByteArray</a>&gt; for <a class=\"struct\" href=\"parquet/data_type/struct.ByteArray.html\" title=\"struct parquet::data_type::ByteArray\">ByteArray</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang. [...]
+"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html\" title=\"trait core::cmp::PartialOrd\">PartialOrd</a>&lt;<a class=\"enum\" href=\"parquet_rewrite/enum.EnabledStatisticsArgs.html\" title=\"enum parquet_rewrite::EnabledStatisticsArgs\">EnabledStatisticsArgs</a>&gt; for <a class=\"enum\" href=\"parquet_rewrite/enum.EnabledStatisticsArgs.html\" title=\"enum parquet_rewrite::EnabledStatisticsArgs\">EnabledStatisticsArgs</a> [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/convert/trait.AsRef.js b/implementors/core/convert/trait.AsRef.js
index 9c5c3beab..e083e096c 100644
--- a/implementors/core/convert/trait.AsRef.js
+++ b/implementors/core/convert/trait.AsRef.js
@@ -2,5 +2,5 @@
 "arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html\" title=\"trait core::convert::AsRef\">AsRef</a>&lt;PyAny&gt; for <a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>"]],
 "arrow_buffer":[["impl&lt;T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <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; for <a class=\"struct\" href=\"arrow_buffer/buffer/scalar/struct. [...]
 "arrow_row":[["impl&lt;'a&gt; <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; for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html\" title=\"t [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html\" title=\"trait core::convert::AsRef\">AsRef</a>&lt;[<a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/alloc/string/struct.String.html\" title=\"struct alloc::string::String\">String</a>]&gt; for <a class=\"struct\" href=\"parquet/schema/types/struct.ColumnPath.html\" title=\"struct parquet::schema::types::ColumnPath\">ColumnPath</a>"],["impl <a class=\"trait\" href=\"ht [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html\" title=\"trait core::convert::AsRef\">AsRef</a>&lt;[<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u8.html\">u8</a>]&gt; for <a class=\"struct\" href=\"parquet/data_type/struct.FixedLenByteArray.html\" title=\"struct parquet::data_type::FixedLenByteArray\">FixedLenByteArray</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/convert/trait.From.js b/implementors/core/convert/trait.From.js
index e4219824b..dee0e0ed2 100644
--- a/implementors/core/convert/trait.From.js
+++ b/implementors/core/convert/trait.From.js
@@ -1,14 +1,14 @@
 (function() {var implementors = {
-"arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;&amp;<a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>&gt; for PyErr"],["impl&lt;T: <a class=\"trait\" href=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"arrow/pyarrow [...]
-"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html\" title=\"struct alloc::vec::Vec\">Vec</a>&lt;<a class=\"enum\" href=\"https://doc.rust-lang.org/nightly/core/option/enum.Option.html\" title=\"enum core::option::Option\">Option</a>&lt;&lt;<a class=\"struct\" href=\"arrow_array/types/struct.Da [...]
-"arrow_buffer":[["impl&lt;T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"arrow_buffer/buffer/immutable/struct.Buffer.html\" title=\"struct arrow_buffer::buffer::immutable::Buffer\">Buffer</a>&gt; for <a class=\"struct [...]
-"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/core/fmt/struct.Error.html\" title=\"struct core::fmt::Error\">Error</a>&gt; for <a class=\"enum\" href=\"arrow_cast/display/enum.FormatError.html\" title=\"enum arrow_cast::display::FormatError\">FormatError</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.o [...]
+"arrow":[["impl&lt;T: <a class=\"trait\" href=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"arrow/pyarrow/trait.IntoPyArrow.html\" title=\"trait arrow::pyarrow::IntoPyArrow\">IntoPyArrow</a>&gt; <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; for <a class=\"struct\" href=\"arrow/pyarrow/struct.PyArrowType.html\ [...]
+"arrow_array":[["impl <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=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.i64.html\">i64</a>&gt; for <a class=\"struct\" href=\"arrow_array/array/primitive_array/struct.NativeAdapter.html\" title=\"struct arrow_array::array::primitive_array::NativeAdapter\">NativeAdapter</a>&lt;<a class=\"struct\" href=\"arrow_array/types/str [...]
+"arrow_buffer":[["impl <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=\"arrow_buffer/buffer/mutable/struct.MutableBuffer.html\" title=\"struct arrow_buffer::buffer::mutable::MutableBuffer\">MutableBuffer</a>&gt; for <a class=\"struct\" href=\"arrow_buffer/buffer/immutable/struct.Buffer.html\" title=\"struct arrow_buffer::buffer::immutable::Buffer\">Buffer</a>"],["impl <a c [...]
+"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;ArrowError&gt; for <a class=\"enum\" href=\"arrow_cast/display/enum.FormatError.html\" title=\"enum arrow_cast::display::FormatError\">FormatError</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"https: [...]
 "arrow_data":[["impl <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=\"arrow_data/data/struct.ArrayData.html\" title=\"struct arrow_data::data::ArrayData\">ArrayData</a>&gt; for <a class=\"struct\" href=\"arrow_data/data/struct.ArrayDataBuilder.html\" title=\"struct arrow_data::data::ArrayDataBuilder\">ArrayDataBuilder</a>"]],
-"arrow_flight":[["impl <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=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlInfo.html\" title=\"enum arrow_flight::sql::gen::SqlInfo\">SqlInfo</a>&gt; for <a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.i32.html\">i32</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\"  [...]
-"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;&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=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>&gt;&gt; for <a class=\"struct\" href=\"arrow_integration_tes [...]
+"arrow_flight":[["impl <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=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedResultSetConcurrency.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedResultSetConcurrency\">SqlSupportedResultSetConcurrency</a>&gt; for <a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.i32.html\">i32</a>"],["impl <a class=\"trait [...]
+"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;&amp;<a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>&gt; for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonField.html\" title=\"struct arrow_integration_test::ArrowJsonField\">ArrowJsonField</a>"],["impl <a class=\"trait\" href= [...]
 "arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Field.html\" title=\"struct arrow_ipc::gen::Schema::Field\">Field</a>&lt;'a&gt;&gt; for <a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>"]],
-"arrow_schema":[["impl&lt;W: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Write.html\" title=\"trait std::io::Write\">Write</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/std/io/buffered/struct.IntoInnerError.html\" title=\"struct std::io::buffered::IntoInnerError\">IntoInnerError</a>&lt;W&gt;&gt; for  [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;&amp;<a class=\"struct\" href=\"parquet/format/struct.Encoding.html\" title=\"struct parquet::format::Encoding\">Encoding</a>&gt; for <a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.i32.html\">i32</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" titl [...]
-"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;Error&lt;RichFormatter&gt;&gt; for <a class=\"enum\" href=\"parquet_fromcsv/enum.ParquetFromCsvError.html\" title=\"enum parquet_fromcsv::ParquetFromCsvError\">ParquetFromCsvError</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a [...]
-"parquet_rewrite":[["impl <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=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>&gt; for <a class=\"enum\" href=\"parquet/basic/enum.Compression.html\" title=\"enum parquet::basic::Compression\">Compression</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.From.html\" title=\"trait core::convert::From\">From</a>&lt;<a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/alloc/vec/struct.Vec.html\" title=\"struct alloc::vec::Vec\">Vec</a>&lt;<a class=\"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_schema/field/struct.Field.htm [...]
+"parquet":[["impl <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=\"enum\" href=\"https://doc.rust-lang.org/nightly/core/option/enum.Option.html\" title=\"enum core::option::Option\">Option</a>&lt;<a class=\"enum\" href=\"parquet/basic/enum.LogicalType.html\" title=\"enum parquet::basic::LogicalType\">LogicalType</a>&gt;&gt; for <a class=\"enum\" href=\"parquet/basic/enum.ConvertedType.htm [...]
+"parquet_fromcsv":[["impl <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=\"enum\" href=\"arrow_schema/error/enum.ArrowError.html\" title=\"enum arrow_schema::error::ArrowError\">ArrowError</a>&gt; for <a class=\"enum\" href=\"parquet_fromcsv/enum.ParquetFromCsvError.html\" title=\"enum parquet_fromcsv::ParquetFromCsvError\">ParquetFromCsvError</a>"],["impl <a class=\"trait\" href=\"https: [...]
+"parquet_rewrite":[["impl <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=\"enum\" href=\"parquet_rewrite/enum.WriterVersionArgs.html\" title=\"enum parquet_rewrite::WriterVersionArgs\">WriterVersionArgs</a>&gt; for <a class=\"enum\" href=\"parquet/file/properties/enum.WriterVersion.html\" title=\"enum parquet::file::properties::WriterVersion\">WriterVersion</a>"],["impl <a class=\"trait\" [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/convert/trait.TryFrom.js b/implementors/core/convert/trait.TryFrom.js
index fa59250cf..4ad58b17d 100644
--- a/implementors/core/convert/trait.TryFrom.js
+++ b/implementors/core/convert/trait.TryFrom.js
@@ -1,7 +1,7 @@
 (function() {var implementors = {
 "arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</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;(&amp;<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.str.html\">str</a>, <a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/alloc/sync/struct.Arc.ht [...]
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.i32.html\">i32</a>&gt; for <a class=\"enum\" href=\"arrow_flight/gen/flight_descriptor/enum.DescriptorType.html\" title=\"enum arrow_flight::gen::flight_descriptor::DescriptorType\">DescriptorType</a>"],["impl <a class=\"trait\" href=\"https:/ [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;&amp;<a class=\"struct\" href=\"arrow_flight/gen/struct.SchemaResult.html\" title=\"struct arrow_flight::gen::SchemaResult\">SchemaResult</a>&gt; for <a class=\"struct\" href=\"arrow_schema/schema/struct.Schema.html\" title=\"struct arrow_schema::schema::Schema\">Schema</a>"],["impl <a class=\"trait\" href=\"https://doc [...]
 "arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;<a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.CompressionType.html\" title=\"struct arrow_ipc::gen::Message::CompressionType\">CompressionType</a>&gt; for <a class=\"enum\" href=\"arrow_ipc/compression/enum.CompressionCodec.html\" title=\"enum arrow_ipc::compression::CompressionCodec\">CompressionCodec</a>"]],
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;<a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>&gt; for <a class=\"struct\" href=\"arrow_schema/ffi/struct.FFI_ArrowSchema.html\" title=\"struct arrow_schema::ffi::FFI_ArrowSchema\">FFI_ArrowSchema</a>"],["impl <a class=\"trait\" href=\"https://doc. [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;<a class=\"struct\" href=\"parquet/format/struct.FieldRepetitionType.html\" title=\"struct parquet::format::FieldRepetitionType\">FieldRepetitionType</a>&gt; for <a class=\"enum\" href=\"parquet/basic/enum.Repetition.html\" title=\"enum parquet::basic::Repetition\">Repetition</a>"],["impl <a class=\"trait\" href=\"https://do [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;&amp;<a class=\"struct\" href=\"arrow_schema/ffi/struct.FFI_ArrowSchema.html\" title=\"struct arrow_schema::ffi::FFI_ArrowSchema\">FFI_ArrowSchema</a>&gt; for <a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>"],["impl <a class=\"trait\" href=\"https:/ [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom.html\" title=\"trait core::convert::TryFrom\">TryFrom</a>&lt;<a class=\"struct\" href=\"parquet/format/struct.PageType.html\" title=\"struct parquet::format::PageType\">PageType</a>&gt; for <a class=\"enum\" href=\"parquet/basic/enum.PageType.html\" title=\"enum parquet::basic::PageType\">PageType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/tr [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/default/trait.Default.js b/implementors/core/default/trait.Default.js
index 9eba93038..f8d787343 100644
--- a/implementors/core/default/trait.Default.js
+++ b/implementors/core/default/trait.Default.js
@@ -1,16 +1,16 @@
 (function() {var implementors = {
 "arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow/util/string_writer/struct.StringWriter.html\" title=\"struct arrow::util::string_writer::StringWriter\">StringWriter</a>"]],
-"arrow_array":[["impl&lt;O: <a class=\"trait\" href=\"arrow_array/array/list_array/trait.OffsetSizeTrait.html\" title=\"trait arrow_array::array::list_array::OffsetSizeTrait\">OffsetSizeTrait</a>, T: <a class=\"trait\" href=\"arrow_array/builder/trait.ArrayBuilder.html\" title=\"trait arrow_array::builder::ArrayBuilder\">ArrayBuilder</a> + <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a>&gt; < [...]
+"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_array/record_batch/struct.RecordBatchOptions.html\" title=\"struct arrow_array::record_batch::RecordBatchOptions\">RecordBatchOptions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default< [...]
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"]],
-"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.Interval.html\" title=\"struct arrow_cast::parse::Interval\">Interval</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"ar [...]
-"arrow_csv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_csv/reader/struct.Format.html\" title=\"struct arrow_csv::reader::Format\">Format</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_csv/reader/st [...]
+"arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"s [...]
+"arrow_csv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_csv/reader/struct.InferredDataType.html\" title=\"struct arrow_csv::reader::InferredDataType\">InferredDataType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struc [...]
 "arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"]],
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_flight/sql/metadata/xdbc_info/struct.XdbcTypeInfo.html\" title=\"struct arrow_flight::sql::metadata::xdbc_info::XdbcTypeInfo\">XdbcTypeInfo</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">D [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.Nullable.html\" title=\"enum arrow_flight::sql::gen::Nullable\">Nullable</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_f [...]
 "arrow_integration_testing":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/middleware/struct.MiddlewareScenarioImpl.html\" title=\"struct arrow_integration_testing::flight_server_scenarios::middleware::MiddlewareScenarioImpl\">MiddlewareScenarioImpl</a>"],["impl <a class=\"trait\" href=\"https://doc.rust [...]
-"arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.IntArgs.html\" title=\"struct arrow_ipc::gen::Schema::IntArgs\">IntArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href [...]
-"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_json/reader/boolean_array/struct.BooleanArrayDecoder.html\" title=\"struct arrow_json::reader::boolean_array::BooleanArrayDecoder\">BooleanArrayDecoder</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::D [...]
-"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.InternBuffer.html\" title=\"struct arrow_row::interner::InternBuffer\">InternBuffer</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_ipc/gen/SparseTensor/struct.SparseTensorIndex.html\" title=\"struct arrow_ipc::gen::SparseTensor::SparseTensorIndex\">SparseTensorIndex</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\ [...]
+"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_json/writer/struct.LineDelimited.html\" title=\"struct arrow_json::writer::LineDelimited\">LineDelimited</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" hr [...]
+"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.InternBuffer.html\" title=\"struct arrow_row::interner::InternBuffer\">InternBuffer</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href [...]
 "arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields.html\" title=\"struct arrow_schema::fields::Fields\">Fields</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_sche [...]
 "arrow_select":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"arrow_select/take/struct.TakeOptions.html\" title=\"struct arrow_select::take::TakeOptions\">TakeOptions</a>"]],
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"parquet/file/properties/struct.ColumnProperties.html\" title=\"struct parquet::file::properties::ColumnProperties\">ColumnProperties</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a  [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"parquet/format/struct.DateType.html\" title=\"struct parquet::format::DateType\">DateType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/default/trait.Default.html\" title=\"trait core::default::Default\">Default</a> for <a class=\"struct\" href=\"parquet/format/stru [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/fmt/trait.Debug.js b/implementors/core/fmt/trait.Debug.js
index 034280511..4d6367877 100644
--- a/implementors/core/fmt/trait.Debug.js
+++ b/implementors/core/fmt/trait.Debug.js
@@ -1,32 +1,32 @@
 (function() {var implementors = {
-"arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow/ffi/struct.ArrowA [...]
-"arrow_array":[["impl&lt;K, V&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_array/builder/primitive_dictionary_builder/struct.PrimitiveDictionaryBuilder.html\" title=\"struct arrow_array::builder::primitive_dictionary_builder::PrimitiveDictionaryBuilder\">PrimitiveDictionaryBuilder</a>&lt;K, V&gt;<span class=\"where fmt-newline\">where\n    K: <a class=\"trait\" h [...]
-"arrow_buffer":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_buffer/util/bit_iterator/struct.BitSliceIterator.html\" title=\"struct arrow_buffer::util::bit_iterator::BitSliceIterator\">BitSliceIterator</a>&lt;'a&gt;"],["impl&lt;E: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\"> [...]
-"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.IntervalAmount.html\" title=\"struct arrow_cast::parse::IntervalAmount\">IntervalAmount</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_cast/parse/struc [...]
-"arrow_csv":[["impl&lt;R&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_csv/reader/struct.BufReader.html\" title=\"struct arrow_csv::reader::BufReader\">BufReader</a>&lt;R&gt;<span class=\"where fmt-newline\">where\n    R: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.BufRead.html\" title=\"trait std::io::BufRead\">BufRead</a>,</span>"],[ [...]
-"arrow_data":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_data/data/struct.ArrayDataBuilder.html\" title=\"struct arrow_data::data::ArrayDataBuilder\">ArrayDataBuilder</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_da [...]
+"arrow":[["impl&lt;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=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"arrow/pyarrow/trait.IntoPyArrow.html\" title=\"trait arrow::pyarrow::IntoPyArrow\">IntoPyArrow</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug. [...]
+"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_array/types/struct.Date64Type.html\" title=\"struct arrow_array::types::Date64Type\">Date64Type</a>"],["impl&lt;'a, R: <a class=\"trait\" href=\"arrow_array/types/trait.RunEndIndexType.html\" title=\"trait arrow_array::types::RunEndIndexType\">RunEndIndexType</a>, V&gt; <a class=\"trait\" href=\"https [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_buffer/buffer/mutable/struct.MutableBuffer.html\" title=\"struct arrow_buffer::buffer::mutable::MutableBuffer\">MutableBuffer</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct [...]
+"arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_cast/display/struct.FormatOptions.html\" title=\"struct arrow_cast::display::FormatOptions\">FormatOptions</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\ [...]
+"arrow_csv":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_csv/reader/records/struct.StringRecord.html\" title=\"struct arrow_csv::reader::records::StringRecord\">StringRecord</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" [...]
+"arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_data/transform/struct.MutableArrayData.html\" title=\"struct arrow_data::transform::MutableArrayData\">MutableArrayData</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum [...]
 "arrow_file_to_stream":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_file_to_stream/struct.Args.html\" title=\"struct arrow_file_to_stream::Args\">Args</a>"]],
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/action_end_transaction_request/enum.EndTransaction.html\" title=\"enum arrow_flight::sql::gen::action_end_transaction_request::EndTransaction\">EndTransaction</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Deb [...]
-"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonField.html\" title=\"struct arrow_integration_test::ArrowJsonField\">ArrowJsonField</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\ [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedElementActions.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedElementActions\">SqlSupportedElementActions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class [...]
+"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonColumn.html\" title=\"struct arrow_integration_test::ArrowJsonColumn\">ArrowJsonColumn</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" hre [...]
 "arrow_integration_testing":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_integration_testing/flight_server_scenarios/integration_test/struct.IntegrationDataset.html\" title=\"struct arrow_integration_testing::flight_server_scenarios::integration_test::IntegrationDataset\">IntegrationDataset</a>"]],
-"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Interval.html\" title=\"struct arrow_ipc::gen::Schema::Interval\">Interval</a>&lt;'_&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/s [...]
-"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_json/writer/struct [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.FixedSizeList.html\" title=\"struct arrow_ipc::gen::Schema::FixedSizeList\">FixedSizeList</a>&lt;'_&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_i [...]
+"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_json/reader/serializer/struct.SerializerError.html\" title=\"struct arrow_json::reader::serializer::SerializerError\">SerializerError</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" hre [...]
 "arrow_json_integration_test":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_json_integration_test/enum.Mode.html\" title=\"enum arrow_json_integration_test::Mode\">Mode</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_json_integrati [...]
 "arrow_ord":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_ord/sort/struct.SortColumn.html\" title=\"struct arrow_ord::sort::SortColumn\">SortColumn</a>"]],
-"arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_row/struct.RowsIter.html\" title=\" [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.TimeUnit.html\" title=\"enum arrow_schema::datatype::TimeUnit\">TimeUnit</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields. [...]
-"arrow_select":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_select/take/struct.TakeOptions.html\" title=\"struct arrow_select::take::TakeOptions\">TakeOptions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_select/filter/enum.Iter [...]
-"flight_sql_client":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"flight_sql_client/struct.ClientArgs.html\" title=\"struct flight_sql_client::ClientArgs\">ClientArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"flight_sql_client/struct.A [...]
-"flight_test_integration_client":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"flight_test_integration_client/enum.Scenario.html\" title=\"enum flight_test_integration_client::Scenario\">Scenario</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\ [...]
+"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_row/struct.RowConverter.html\" title=\"struct arrow_row::RowConverter\">RowConverter</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_row/struct.OwnedRow.html\" title=\"str [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_schema/struct.SortOptions.html\" title=\"struct arrow_schema::SortOptions\">SortOptions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_schema/schema/struct.Schema.html [...]
+"arrow_select":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"arrow_select/filter/enum.IterationStrategy.html\" title=\"enum arrow_select::filter::IterationStrategy\">IterationStrategy</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"arrow_selec [...]
+"flight_sql_client":[["impl&lt;K: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a>, V: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"flight_sql_client/struct.K [...]
+"flight_test_integration_client":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"flight_test_integration_client/struct.Args.html\" title=\"struct flight_test_integration_client::Args\">Args</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"flight_ [...]
 "flight_test_integration_server":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"flight_test_integration_server/enum.Scenario.html\" title=\"enum flight_test_integration_server::Scenario\">Scenario</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\ [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet/basic/enum.PageType.html\" title=\"enum parquet::basic::PageType\">PageType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet/format/struct.TypeDefinedOrder.html\" title=\"s [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet/bloom_filter/struct.Block.html\" title=\"struct parquet::bloom_filter::Block\">Block</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet/format/struct.DataPageHeaderV2.html\ [...]
 "parquet_concat":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_concat/struct.Args.html\" title=\"struct parquet_concat::Args\">Args</a>"]],
-"parquet_derive":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_derive/parquet_field/struct.Field.html\" title=\"struct parquet_derive::parquet_field::Field\">Field</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_derive/parquet_ [...]
-"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.CsvDialect.html\" title=\"enum parquet_fromcsv::CsvDialect\">CsvDialect</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_fromcsv/struct.Args.html\" tit [...]
+"parquet_derive":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_derive/parquet_field/enum.Type.html\" title=\"enum parquet_derive::parquet_field::Type\">Type</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_derive/parquet_field/enu [...]
+"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.CsvDialect.html\" title=\"enum parquet_fromcsv::CsvDialect\">CsvDialect</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTerminator.ht [...]
 "parquet_index":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_index/struct.Args.html\" title=\"struct parquet_index::Args\">Args</a>"]],
-"parquet_layout":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_layout/struct.RowGroup.html\" title=\"struct parquet_layout::RowGroup\">RowGroup</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_layout/struct.ColumnChunk.html\"  [...]
+"parquet_layout":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_layout/struct.Args.html\" title=\"struct parquet_layout::Args\">Args</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_layout/struct.ColumnChunk.html\" title=\"stru [...]
 "parquet_read":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_read/struct.Args.html\" title=\"struct parquet_read::Args\">Args</a>"]],
-"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_rewrite/struct.Args.html\" title=\"struct parquet_rewrite::Args\">Args</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\" [...]
+"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_rewrite/struct.Args.html\" title=\"struct parquet_rewrite::Args\">Args</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\" [...]
 "parquet_rowcount":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_rowcount/struct.Args.html\" title=\"struct parquet_rowcount::Args\">Args</a>"]],
 "parquet_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_schema/struct.Args.html\" title=\"struct parquet_schema::Args\">Args</a>"]],
 "parquet_show_bloom_filter":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Debug.html\" title=\"trait core::fmt::Debug\">Debug</a> for <a class=\"struct\" href=\"parquet_show_bloom_filter/struct.Args.html\" title=\"struct parquet_show_bloom_filter::Args\">Args</a>"]]
diff --git a/implementors/core/fmt/trait.Display.js b/implementors/core/fmt/trait.Display.js
index 0ce2c1354..bfe4c8cf6 100644
--- a/implementors/core/fmt/trait.Display.js
+++ b/implementors/core/fmt/trait.Display.js
@@ -1,11 +1,11 @@
 (function() {var implementors = {
 "arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>"]],
 "arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_array/timezone/private/struct.TzOffset.html\" title=\"struct arrow_array::timezone::private::TzOffset\">TzOffset</a>"]],
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.ParseI256Error.html\" title=\"struct arrow_buffer::bigint::ParseI256Error\">ParseI256Error</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"ar [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.Parse [...]
 "arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_cast/display/struct.ValueFormatter.html\" title=\"struct arrow_cast::display::ValueFormatter\">ValueFormatter</a>&lt;'a&gt;"]],
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_flight/gen/struct.Location.html\" title=\"struct arrow_flight::gen::Location\">Location</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_flight/gen/struct.Fl [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_flight/gen/struct.FlightInfo.html\" title=\"struct arrow_flight::gen::FlightInfo\">FlightInfo</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_flight/gen/str [...]
 "arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_json/reader/serializer/struct.SerializerError.html\" title=\"struct arrow_json::reader::serializer::SerializerError\">SerializerError</a>"]],
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.DataType.html\" title=\"enum arrow_schema::datatype::DataType\">DataType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"enum\" href=\"arrow_schema/error/enum. [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"enum\" href=\"parquet/errors/enum.ParquetError.html\" title=\"enum parquet::errors::ParquetError\">ParquetError</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"enum\" href=\"parquet/file/statistics/enum.St [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"arrow_schema/schema/struct.Sche [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"enum\" href=\"parquet/basic/enum.Encoding.html\" title=\"enum parquet::basic::Encoding\">Encoding</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"struct\" href=\"parquet/data_type/struct.Int96.html\" title [...]
 "parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/fmt/trait.Display.html\" title=\"trait core::fmt::Display\">Display</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.ParquetFromCsvError.html\" title=\"enum parquet_fromcsv::ParquetFromCsvError\">ParquetFromCsvError</a>"]]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/hash/trait.Hash.js b/implementors/core/hash/trait.Hash.js
index 7cbdc5a13..0b1f0b8ba 100644
--- a/implementors/core/hash/trait.Hash.js
+++ b/implementors/core/hash/trait.Hash.js
@@ -2,9 +2,9 @@
 "arrow_array":[["impl&lt;T: ToByteSlice&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_array/builder/primitive_dictionary_builder/struct.Value.html\" title=\"struct arrow_array::builder::primitive_dictionary_builder::Value\">Value</a>&lt;T&gt;"]],
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"]],
 "arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_cast/display/struct.FormatOptions.html\" title=\"struct arrow_cast::display::FormatOptions\">FormatOptions</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\"  [...]
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.XdbcDataType.html\" title=\"enum arrow_flight::sql::gen::XdbcDataType\">XdbcDataType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.S [...]
-"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Type.html\" title=\"struct arrow_ipc::gen::Schema::Type\">Type</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Endianness.html\"  [...]
-"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Interned.html\" title=\"struct arrow_row::interner::Interned\">Interned</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" t [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.UnionFields.html\" title=\"struct arrow_schema::fields::UnionFields\">UnionFields</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_schema/schema/struc [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"parquet/format/struct.JsonType.html\" title=\"struct parquet::format::JsonType\">JsonType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"parquet/format/struct.IntType.html\" title=\"stru [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedTransaction.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedTransaction\">SqlSupportedTransaction</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"enum\" h [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Feature.html\" title=\"struct arrow_ipc::gen::Schema::Feature\">Feature</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.IntervalU [...]
+"arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Interned.html\" title=\"str [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.UnionFields.html\" title=\"struct arrow_schema::fields::UnionFields\">UnionFields</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"arrow_schema/schema/struc [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"parquet/format/struct.SplitBlockAlgorithm.html\" title=\"struct parquet::format::SplitBlockAlgorithm\">SplitBlockAlgorithm</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html\" title=\"trait core::hash::Hash\">Hash</a> for <a class=\"struct\" href=\"parquet/format/s [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/iter/traits/collect/trait.Extend.js b/implementors/core/iter/traits/collect/trait.Extend.js
index 028177742..9081634bf 100644
--- a/implementors/core/iter/traits/collect/trait.Extend.js
+++ b/implementors/core/iter/traits/collect/trait.Extend.js
@@ -1,5 +1,5 @@
 (function() {var implementors = {
-"arrow_array":[["impl&lt;K: <a class=\"trait\" href=\"arrow_array/types/trait.ArrowDictionaryKeyType.html\" title=\"trait arrow_array::types::ArrowDictionaryKeyType\">ArrowDictionaryKeyType</a>, P: <a class=\"trait\" href=\"arrow_array/types/trait.ArrowPrimitiveType.html\" title=\"trait arrow_array::types::ArrowPrimitiveType\">ArrowPrimitiveType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html\" title=\"trait core::iter::trait [...]
+"arrow_array":[["impl&lt;K: <a class=\"trait\" href=\"arrow_array/types/trait.ArrowDictionaryKeyType.html\" title=\"trait arrow_array::types::ArrowDictionaryKeyType\">ArrowDictionaryKeyType</a>, T: <a class=\"trait\" href=\"arrow_array/types/trait.ByteArrayType.html\" title=\"trait arrow_array::types::ByteArrayType\">ByteArrayType</a>, V: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.AsRef.html\" title=\"trait core::convert::AsRef\">AsRef</a>&lt;T::<a cla [...]
 "arrow_buffer":[["impl&lt;A: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html\" title=\"trait core::iter::traits::collect::Extend\">Extend</a>&lt;A&gt; for <a class=\"struct\" href=\"arrow_buffer/buffer/mutable/struct.MutableBuffer.html\" title=\"struct arrow_buffer::buffer::mutable:: [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html\" title=\"trait core::iter::traits::collect::Extend\">Extend</a>&lt;<a class=\"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_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>&gt;&gt; for <a class=\"struct\" href=\"arro [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.Extend.html\" title=\"trait core::iter::traits::collect::Extend\">Extend</a>&lt;<a class=\"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_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>&gt;&gt; for <a class=\"struct\" href=\"arro [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/iter/traits/collect/trait.FromIterator.js b/implementors/core/iter/traits/collect/trait.FromIterator.js
index f84b06b41..4750cc398 100644
--- a/implementors/core/iter/traits/collect/trait.FromIterator.js
+++ b/implementors/core/iter/traits/collect/trait.FromIterator.js
@@ -1,5 +1,5 @@
 (function() {var implementors = {
-"arrow_array":[["impl&lt;T: <a class=\"trait\" href=\"arrow_array/types/trait.ArrowPrimitiveType.html\" title=\"trait arrow_array::types::ArrowPrimitiveType\">ArrowPrimitiveType</a>, Ptr: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/convert/trait.Into.html\" title=\"trait core::convert::Into\">Into</a>&lt;<a class=\"struct\" href=\"arrow_array/array/primitive_array/struct.NativeAdapter.html\" title=\"struct arrow_array::array::primitive_array::NativeAdapter\">NativeAd [...]
-"arrow_buffer":[["impl&lt;T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html\" title=\"trait core::iter::traits::collect::FromIterator\">FromIterator</a>&lt;T&gt; for <a class=\"struct\" href=\"arrow_buffer/buffer/immutable/struct.Buffer.html\" title=\"struct arrow_buffer::buff [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html\" title=\"trait core::iter::traits::collect::FromIterator\">FromIterator</a>&lt;<a class=\"struct\" href=\"arrow_schema/field/struct.Field.html\" title=\"struct arrow_schema::field::Field\">Field</a>&gt; for <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields.html\" title=\"struct arrow_schema::fields::Fields\">Fields</a>"],["impl <a class=\"trait\" [...]
+"arrow_array":[["impl&lt;'a, T: <a class=\"trait\" href=\"arrow_array/types/trait.ArrowDictionaryKeyType.html\" title=\"trait arrow_array::types::ArrowDictionaryKeyType\">ArrowDictionaryKeyType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html\" title=\"trait core::iter::traits::collect::FromIterator\">FromIterator</a>&lt;<a class=\"enum\" href=\"https://doc.rust-lang.org/nightly/core/option/enum.Option.html\" title=\"enu [...]
+"arrow_buffer":[["impl&lt;T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html\" title=\"trait core::iter::traits::collect::FromIterator\">FromIterator</a>&lt;T&gt; for <a class=\"struct\" href=\"arrow_buffer/buffer/immutable/struct.Buffer.html\" title=\"struct arrow_buffer::buff [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.FromIterator.html\" title=\"trait core::iter::traits::collect::FromIterator\">FromIterator</a>&lt;(<a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.i8.html\">i8</a>, <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_schema/field/st [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/iter/traits/collect/trait.IntoIterator.js b/implementors/core/iter/traits/collect/trait.IntoIterator.js
index 78f721dad..97822c84c 100644
--- a/implementors/core/iter/traits/collect/trait.IntoIterator.js
+++ b/implementors/core/iter/traits/collect/trait.IntoIterator.js
@@ -1,8 +1,8 @@
 (function() {var implementors = {
-"arrow_array":[["impl&lt;'a&gt; <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> for &amp;'a <a class=\"struct\" href=\"arrow_array/array/boolean_array/struct.BooleanArray.html\" title=\"struct arrow_array::array::boolean_array::BooleanArray\">BooleanArray</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/trait [...]
-"arrow_buffer":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_buffer/util/bit_chunk_iterator/struct.BitChunks.html\" title=\"struct arrow_buffer::util::bit_chunk_iterator::BitChunks\">BitChunks</a>&lt;'a&gt;"],["impl&lt;'a, T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.htm [...]
+"arrow_array":[["impl&lt;'a, R, V&gt; <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> for <a class=\"struct\" href=\"arrow_array/array/run_array/struct.TypedRunArray.html\" title=\"struct arrow_array::array::run_array::TypedRunArray\">TypedRunArray</a>&lt;'a, R, V&gt;<span class=\"where fmt-newline\">where\n    R: <a class=\"trait\" href=\"arrow_array/ [...]
+"arrow_buffer":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_buffer/util/bit_chunk_iterator/struct.BitChunks.html\" title=\"struct arrow_buffer::util::bit_chunk_iterator::BitChunks\">BitChunks</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/t [...]
 "arrow_data":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"]],
 "arrow_row":[["impl&lt;'a&gt; <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> for &amp;'a <a class=\"struct\" href=\"arrow_row/struct.Rows.html\" title=\"struct arrow_row::Rows\">Rows</a>"]],
-"arrow_schema":[["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> for <a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Flags.html\" title=\"struct arrow_schema::ffi::flags::Flags\">Flags</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html\" title=\"trait core:: [...]
+"arrow_schema":[["impl&lt;'a&gt; <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> for &amp;'a <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields.html\" title=\"struct arrow_schema::fields::Fields\">Fields</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/collect/trait.IntoIterator.html\" title=\"trait co [...]
 "parquet":[["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> for <a class=\"struct\" href=\"parquet/file/serialized_reader/struct.SerializedFileReader.html\" title=\"struct parquet::file::serialized_reader::SerializedFileReader\">SerializedFileReader</a>&lt;<a class=\"struct\" href=\"https://doc.rust-lang.org/nightly/std/fs/struct.File.html\" titl [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/iter/traits/double_ended/trait.DoubleEndedIterator.js b/implementors/core/iter/traits/double_ended/trait.DoubleEndedIterator.js
index 75b9f155a..f8dedd477 100644
--- a/implementors/core/iter/traits/double_ended/trait.DoubleEndedIterator.js
+++ b/implementors/core/iter/traits/double_ended/trait.DoubleEndedIterator.js
@@ -1,5 +1,5 @@
 (function() {var implementors = {
-"arrow_array":[["impl&lt;T: <a class=\"trait\" href=\"arrow_array/array/trait.ArrayAccessor.html\" title=\"trait arrow_array::array::ArrayAccessor\">ArrayAccessor</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/double_ended/trait.DoubleEndedIterator.html\" title=\"trait core::iter::traits::double_ended::DoubleEndedIterator\">DoubleEndedIterator</a> for <a class=\"struct\" href=\"arrow_array/iterator/struct.ArrayIter.html\" title=\"struct arrow_array:: [...]
+"arrow_array":[["impl&lt;'a, R, V&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/double_ended/trait.DoubleEndedIterator.html\" title=\"trait core::iter::traits::double_ended::DoubleEndedIterator\">DoubleEndedIterator</a> for <a class=\"struct\" href=\"arrow_array/run_iterator/struct.RunArrayIter.html\" title=\"struct arrow_array::run_iterator::RunArrayIter\">RunArrayIter</a>&lt;'a, R, V&gt;<span class=\"where fmt-newline\">where\n    R: <a class=\"trait\ [...]
 "arrow_buffer":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/double_ended/trait.DoubleEndedIterator.html\" title=\"trait core::iter::traits::double_ended::DoubleEndedIterator\">DoubleEndedIterator</a> for <a class=\"struct\" href=\"arrow_buffer/util/bit_iterator/struct.BitIterator.html\" title=\"struct arrow_buffer::util::bit_iterator::BitIterator\">BitIterator</a>&lt;'a&gt;"]],
 "arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/double_ended/trait.DoubleEndedIterator.html\" title=\"trait core::iter::traits::double_ended::DoubleEndedIterator\">DoubleEndedIterator</a> for <a class=\"struct\" href=\"arrow_row/struct.RowsIter.html\" title=\"struct arrow_row::RowsIter\">RowsIter</a>&lt;'a&gt;"]]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/iter/traits/iterator/trait.Iterator.js b/implementors/core/iter/traits/iterator/trait.Iterator.js
index 6a7a1a427..a92d50d4d 100644
--- a/implementors/core/iter/traits/iterator/trait.Iterator.js
+++ b/implementors/core/iter/traits/iterator/trait.Iterator.js
@@ -1,13 +1,13 @@
 (function() {var implementors = {
 "arrow":[["impl&lt;T: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/clone/trait.Clone.html\" title=\"trait core::clone::Clone\">Clone</a>&gt; <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> for <a class=\"struct\" href=\"arrow/util/test_util/struct.BadIterator.html\" title=\"struct arrow::util::test_util::BadIterator\">BadIterator</a>&lt;T&gt; [...]
-"arrow_array":[["impl&lt;'a, R, V&gt; <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> for <a class=\"struct\" href=\"arrow_array/run_iterator/struct.RunArrayIter.html\" title=\"struct arrow_array::run_iterator::RunArrayIter\">RunArrayIter</a>&lt;'a, R, V&gt;<span class=\"where fmt-newline\">where\n    R: <a class=\"trait\" href=\"arrow_array/types/trait.RunEndIn [...]
-"arrow_buffer":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_buffer/util/bit_iterator/struct.BitSliceIterator.html\" title=\"struct arrow_buffer::util::bit_iterator::BitSliceIterator\">BitSliceIterator</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/tr [...]
+"arrow_array":[["impl&lt;'a, R, V&gt; <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> for <a class=\"struct\" href=\"arrow_array/run_iterator/struct.RunArrayIter.html\" title=\"struct arrow_array::run_iterator::RunArrayIter\">RunArrayIter</a>&lt;'a, R, V&gt;<span class=\"where fmt-newline\">where\n    R: <a class=\"trait\" href=\"arrow_array/types/trait.RunEndIn [...]
+"arrow_buffer":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_buffer/util/bit_iterator/struct.BitIndexIterator.html\" title=\"struct arrow_buffer::util::bit_iterator::BitIndexIterator\">BitIndexIterator</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/itera [...]
 "arrow_csv":[["impl&lt;R: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.BufRead.html\" title=\"trait std::io::BufRead\">BufRead</a>&gt; <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> for <a class=\"struct\" href=\"arrow_csv/reader/struct.BufReader.html\" title=\"struct arrow_csv::reader::BufReader\">BufReader</a>&lt;R&gt;"]],
 "arrow_data":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.IntoIter.html\" title=\"struct arrow_data::data::buffers::IntoIter\">IntoIter</a>&lt;'a&gt;"]],
 "arrow_ipc":[["impl&lt;R: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Read.html\" title=\"trait std::io::Read\">Read</a>&gt; <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> for <a class=\"struct\" href=\"arrow_ipc/reader/struct.StreamReader.html\" title=\"struct arrow_ipc::reader::StreamReader\">StreamReader</a>&lt;R&gt;"],["impl&lt; [...]
-"arrow_json":[["impl&lt;R: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.BufRead.html\" title=\"trait std::io::BufRead\">BufRead</a>&gt; <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> for <a class=\"struct\" href=\"arrow_json/reader/schema/struct.ValueIter.html\" title=\"struct arrow_json::reader::schema::ValueIter\">ValueIter</a>&lt; [...]
+"arrow_json":[["impl&lt;R: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.BufRead.html\" title=\"trait std::io::BufRead\">BufRead</a>&gt; <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> for <a class=\"struct\" href=\"arrow_json/reader/struct.Reader.html\" title=\"struct arrow_json::reader::Reader\">Reader</a>&lt;R&gt;"],["impl&lt;R: <a  [...]
 "arrow_ord":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_ord/partition/struct.LexicographicalPartitionIterator.html\" title=\"struct arrow_ord::partition::LexicographicalPartitionIterator\">LexicographicalPartitionIterator</a>&lt;'a&gt;"]],
 "arrow_row":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_row/struct.RowsIter.html\" title=\"struct arrow_row::RowsIter\">RowsIter</a>&lt;'a&gt;"]],
-"arrow_select":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_select/filter/struct.IndexIterator.html\" title=\"struct arrow_select::filter::IndexIterator\">IndexIterator</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.htm [...]
-"parquet":[["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> for <a class=\"struct\" href=\"parquet/arrow/arrow_reader/struct.ParquetRecordBatchReader.html\" title=\"struct parquet::arrow::arrow_reader::ParquetRecordBatchReader\">ParquetRecordBatchReader</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/iter [...]
+"arrow_select":[["impl&lt;'a&gt; <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> for <a class=\"struct\" href=\"arrow_select/filter/struct.SlicesIterator.html\" title=\"struct arrow_select::filter::SlicesIterator\">SlicesIterator</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator. [...]
+"parquet":[["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> for <a class=\"struct\" href=\"parquet/record/reader/struct.ReaderIter.html\" title=\"struct parquet::record::reader::ReaderIter\">ReaderIter</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html\" title=\"trait core::iter::traits::i [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/marker/trait.Copy.js b/implementors/core/marker/trait.Copy.js
index ff4d3fa3a..9e1f1db0e 100644
--- a/implementors/core/marker/trait.Copy.js
+++ b/implementors/core/marker/trait.Copy.js
@@ -1,15 +1,15 @@
 (function() {var implementors = {
-"arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_array/timezone/private/struct.TzOffset.html\" title=\"struct arrow_array::timezone::private::TzOffset\">TzOffset</a>"],["impl&lt;'a, K: <a class=\"trait\" href=\"arrow_array/types/trait.ArrowDictionaryKeyType.html\" title=\"trait arrow_array::types::ArrowDictionaryKeyType\">ArrowDictionaryKeyType</ [...]
+"arrow_array":[["impl&lt;'a, R: <a class=\"trait\" href=\"arrow_array/types/trait.RunEndIndexType.html\" title=\"trait arrow_array::types::RunEndIndexType\">RunEndIndexType</a>, V&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_array/array/run_array/struct.TypedRunArray.html\" title=\"struct arrow_array::array::run_array::TypedRunArray\">TypedRunArray</a>&lt;'a,  [...]
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"]],
 "arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.IntervalAmount.html\" title=\"struct arrow_cast::parse::IntervalAmount\">IntervalAmount</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_cast/parse/e [...]
-"arrow_csv":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_csv/reader/records/struct.StringRecord.html\" title=\"struct arrow_csv::reader::records::StringRecord\">StringRecord</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"st [...]
+"arrow_csv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_csv/reader/struct.InferredDataType.html\" title=\"struct arrow_csv::reader::InferredDataType\">InferredDataType</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"a [...]
 "arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"]],
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.UpdateDeleteRules.html\" title=\"enum arrow_flight::sql::gen::UpdateDeleteRules\">UpdateDeleteRules</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arro [...]
-"arrow_ipc":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_ipc/gen/SparseTensor/struct.SparseMatrixIndexCSX.html\" title=\"struct arrow_ipc::gen::SparseTensor::SparseMatrixIndexCSX\">SparseMatrixIndexCSX</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::mar [...]
-"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_json/reader/ta [...]
-"arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Interned.html\" title=\"struct arrow_row::interner::Interned\">Interned</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_row/struct.Row. [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedUnions.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedUnions\">SqlSupportedUnions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"a [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Precision.html\" title=\"struct arrow_ipc::gen::Schema::Precision\">Precision</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_ipc/gen [...]
+"arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.DecoderState.html\" title=\"enum arrow_json::reader::tape::DecoderState\">DecoderState</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_json/reader [...]
+"arrow_row":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_row/struct.Row.html\" title=\"struct arrow_row::Row\">Row</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Interned.html\" tit [...]
 "arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"arrow_schema/struct.SortO [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"parquet/format/struct.PageType.html\" title=\"struct parquet::format::PageType\">PageType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"parquet/basic/struct.GzipLevel.html\" tit [...]
-"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.CsvDialect.html\" title=\"enum parquet_fromcsv::CsvDialect\">CsvDialect</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTermina [...]
-"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_rewrite/enu [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet/basic/enum.Repetition.html\" title=\"enum parquet::basic::Repetition\">Repetition</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"struct\" href=\"parquet/format/struct.PageType.html\" title [...]
+"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTerminator.html\" title=\"enum parquet_fromcsv::RecordTerminator\">RecordTerminator</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_fromcsv/ [...]
+"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.WriterVersionArgs.html\" title=\"enum parquet_rewrite::WriterVersionArgs\">WriterVersionArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html\" title=\"trait core::marker::Copy\">Copy</a> for <a class=\"enum\" href=\"parquet_rewri [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/marker/trait.Send.js b/implementors/core/marker/trait.Send.js
index 8791a76be..0c05ef204 100644
--- a/implementors/core/marker/trait.Send.js
+++ b/implementors/core/marker/trait.Send.js
@@ -2,7 +2,7 @@
 "arrow":[["impl&lt;'a&gt; !<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=\"arrow/ffi/struct.ArrowArray.html\" title=\"struct arrow::ffi::ArrowArray\">ArrowArray</a>&lt;'a&gt;",1,["arrow::ffi::ArrowArray"]],["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\" hre [...]
 "arrow_arith":[["impl&lt;T&gt; <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=\"arrow_arith/aggregate/simd/struct.SumAggregate.html\" title=\"struct arrow_arith::aggregate::simd::SumAggregate\">SumAggregate</a>&lt;T&gt;<span class=\"where fmt-newline\">where\n    T: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" title=\"trait core: [...]
 "arrow_array":[["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=\"arrow_array/array/boolean_array/struct.BooleanArray.html\" title=\"struct arrow_array::array::boolean_array::BooleanArray\">BooleanArray</a>",1,["arrow_array::array::boolean_array::BooleanArray"]],["impl&lt;T&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" ti [...]
-"arrow_buffer":[["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=\"enum\" href=\"arrow_buffer/alloc/enum.Deallocation.html\" title=\"enum arrow_buffer::alloc::Deallocation\">Deallocation</a>",1,["arrow_buffer::alloc::Deallocation"]],["impl&lt;O&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" title=\"trait core::marker::Send\">Send</a> for  [...]
+"arrow_buffer":[["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=\"enum\" href=\"arrow_buffer/alloc/enum.Deallocation.html\" title=\"enum arrow_buffer::alloc::Deallocation\">Deallocation</a>",1,["arrow_buffer::alloc::Deallocation"]],["impl&lt;O&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" title=\"trait core::marker::Send\">Send</a> for  [...]
 "arrow_cast":[["impl&lt;'a&gt; <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=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;",1,["arrow_cast::cast::CastOptions"]],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" title=\"trait core::marker::Send\">S [...]
 "arrow_csv":[["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=\"arrow_csv/reader/records/struct.RecordDecoder.html\" title=\"struct arrow_csv::reader::records::RecordDecoder\">RecordDecoder</a>",1,["arrow_csv::reader::records::RecordDecoder"]],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" title=\"trait core:: [...]
 "arrow_data":[["impl&lt;'a&gt; <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=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;",1,["arrow_data::data::buffers::Buffers"]],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Send.html\" title=\"trait core::marker [...]
diff --git a/implementors/core/marker/trait.StructuralEq.js b/implementors/core/marker/trait.StructuralEq.js
index 8880a843d..bcb1f5c13 100644
--- a/implementors/core/marker/trait.StructuralEq.js
+++ b/implementors/core/marker/trait.StructuralEq.js
@@ -1,12 +1,12 @@
 (function() {var implementors = {
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct [...]
 "arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq [...]
-"arrow_data":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_data/data/struct.DataTypeLayout.html\" title=\"struct arrow_data::data::DataTypeLayout\">DataTypeLayout</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">Structur [...]
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"arrow_flight/gen/flight_descriptor/enum.DescriptorType.html\" title=\"enum arrow_flight::gen::flight_descriptor::DescriptorType\">DescriptorType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker [...]
-"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.CompressionType.html\" title=\"struct arrow_ipc::gen::Message::CompressionType\">CompressionType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">Str [...]
+"arrow_data":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"arrow_data/data/enum.BufferSpec.html\" title=\"enum arrow_data::data::BufferSpec\">BufferSpec</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a cl [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlInfo.html\" title=\"enum arrow_flight::sql::gen::SqlInfo\">SqlInfo</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\" [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Endianness.html\" title=\"struct arrow_ipc::gen::Schema::Endianness\">Endianness</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for [...]
 "arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"]],
 "arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_row/struct.SortField.html\" title=\"struct arrow_row::SortField\">SortField</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\ [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.UnionFields.html\" title=\"struct arrow_schema::fields::UnionFields\">UnionFields</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a>  [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"parquet/format/struct.KeyValue.html\" title=\"struct parquet::format::KeyValue\">KeyValue</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\"  [...]
-"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.CompressionArgs.html\" title=\"enum parquet_rewrite::CompressionArgs\">CompressionArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a>  [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a c [...]
+"parquet":[["impl&lt;T&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"struct\" href=\"parquet/file/page_index/index/struct.PageIndex.html\" title=\"struct parquet::file::page_index::index::PageIndex\">PageIndex</a>&lt;T&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::Str [...]
+"parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\">StructuralEq</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.EnabledStatisticsArgs.html\" title=\"enum parquet_rewrite::EnabledStatisticsArgs\">EnabledStatisticsArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralEq.html\" title=\"trait core::marker::StructuralEq\" [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/marker/trait.StructuralPartialEq.js b/implementors/core/marker/trait.StructuralPartialEq.js
index 5b85c1c4e..b1ac30ab1 100644
--- a/implementors/core/marker/trait.StructuralPartialEq.js
+++ b/implementors/core/marker/trait.StructuralPartialEq.js
@@ -1,15 +1,15 @@
 (function() {var implementors = {
 "arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_array/record_batch/struct.RecordBatch.html\" title=\"struct arrow_array::record_batch::RecordBatch\">RecordBatch</a>"]],
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">Str [...]
-"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.IntervalAmount.html\" title=\"struct arrow_cast::parse::IntervalAmount\">IntervalAmount</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::m [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_buffer/buffer/null/struct.NullBuffer.html\" title=\"struct arrow_buffer::buffer::null::NullBuffer\">NullBuffer</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::mark [...]
+"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.IntervalAmount.html\" title=\"struct arrow_cast::parse::IntervalAmount\">IntervalAmount</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::m [...]
 "arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait cor [...]
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"arrow_flight/sql/gen/enum.SqlSupportedElementActions.html\" title=\"enum arrow_flight::sql::gen::SqlSupportedElementActions\">SqlSupportedElementActions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartial [...]
-"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Feature.html\" title=\"struct arrow_ipc::gen::Schema::Feature\">Feature</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::Struct [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_flight/gen/struct.Ticket.html\" title=\"struct arrow_flight::gen::Ticket\">Ticket</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">Str [...]
+"arrow_ipc":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.MetadataVersion.html\" title=\"struct arrow_ipc::gen::Schema::MetadataVersion\">MetadataVersion</a>"],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"tr [...]
 "arrow_json":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"arrow_json/reader/tape/enum.TapeElement.html\" title=\"enum arrow_json::reader::tape::TapeElement\">TapeElement</a>"]],
 "arrow_row":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_row/interner/struct.Interned.html\" title=\"struct arrow_row::interner::Interned\">Interned</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialE [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"arrow_schema/datatype/enum.DataType.html\" title=\"enum arrow_schema::datatype::DataType\">DataType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralParti [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"parquet/basic/enum.LogicalType.html\" title=\"enum parquet::basic::LogicalType\">LogicalType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">Struc [...]
-"parquet_derive":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"parquet_derive/parquet_field/enum.Type.html\" title=\"enum parquet_derive::parquet_field::Type\">Type</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralP [...]
-"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.CsvDialect.html\" title=\"enum parquet_fromcsv::CsvDialect\">CsvDialect</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields.html\" title=\"struct arrow_schema::fields::Fields\">Fields</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"parquet/basic/enum.Compression.html\" title=\"enum parquet::basic::Compression\">Compression</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">Struc [...]
+"parquet_derive":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"struct\" href=\"parquet_derive/parquet_field/struct.Field.html\" title=\"struct parquet_derive::parquet_field::Field\">Field</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::St [...]
+"parquet_fromcsv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"parquet_fromcsv/enum.RecordTerminator.html\" title=\"enum parquet_fromcsv::RecordTerminator\">RecordTerminator</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::S [...]
 "parquet_rewrite":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait core::marker::StructuralPartialEq\">StructuralPartialEq</a> for <a class=\"enum\" href=\"parquet_rewrite/enum.EnabledStatisticsArgs.html\" title=\"enum parquet_rewrite::EnabledStatisticsArgs\">EnabledStatisticsArgs</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html\" title=\"trait  [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/marker/trait.Sync.js b/implementors/core/marker/trait.Sync.js
index 599202231..209b3fd1d 100644
--- a/implementors/core/marker/trait.Sync.js
+++ b/implementors/core/marker/trait.Sync.js
@@ -2,7 +2,7 @@
 "arrow":[["impl&lt;'a&gt; !<a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" href=\"arrow/ffi/struct.ArrowArray.html\" title=\"struct arrow::ffi::ArrowArray\">ArrowArray</a>&lt;'a&gt;",1,["arrow::ffi::ArrowArray"]],["impl !<a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" hre [...]
 "arrow_arith":[["impl&lt;T&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" href=\"arrow_arith/aggregate/simd/struct.SumAggregate.html\" title=\"struct arrow_arith::aggregate::simd::SumAggregate\">SumAggregate</a>&lt;T&gt;<span class=\"where fmt-newline\">where\n    T: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core: [...]
 "arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" href=\"arrow_array/array/boolean_array/struct.BooleanArray.html\" title=\"struct arrow_array::array::boolean_array::BooleanArray\">BooleanArray</a>",1,["arrow_array::array::boolean_array::BooleanArray"]],["impl&lt;T&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" ti [...]
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"enum\" href=\"arrow_buffer/alloc/enum.Deallocation.html\" title=\"enum arrow_buffer::alloc::Deallocation\">Deallocation</a>",1,["arrow_buffer::alloc::Deallocation"]],["impl&lt;O&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for  [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"enum\" href=\"arrow_buffer/alloc/enum.Deallocation.html\" title=\"enum arrow_buffer::alloc::Deallocation\">Deallocation</a>",1,["arrow_buffer::alloc::Deallocation"]],["impl&lt;O&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for  [...]
 "arrow_cast":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" href=\"arrow_cast/cast/struct.CastOptions.html\" title=\"struct arrow_cast::cast::CastOptions\">CastOptions</a>&lt;'a&gt;",1,["arrow_cast::cast::CastOptions"]],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">S [...]
 "arrow_csv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" href=\"arrow_csv/reader/records/struct.RecordDecoder.html\" title=\"struct arrow_csv::reader::records::RecordDecoder\">RecordDecoder</a>",1,["arrow_csv::reader::records::RecordDecoder"]],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core:: [...]
 "arrow_data":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker::Sync\">Sync</a> for <a class=\"struct\" href=\"arrow_data/data/buffers/struct.Buffers.html\" title=\"struct arrow_data::data::buffers::Buffers\">Buffers</a>&lt;'a&gt;",1,["arrow_data::data::buffers::Buffers"]],["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/marker/trait.Sync.html\" title=\"trait core::marker [...]
diff --git a/implementors/core/ops/bit/trait.BitOr.js b/implementors/core/ops/bit/trait.BitOr.js
index 0e550bff3..04bc466d1 100644
--- a/implementors/core/ops/bit/trait.BitOr.js
+++ b/implementors/core/ops/bit/trait.BitOr.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
-"arrow_buffer":[["impl <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=\"arrow_buffer/buffer/boolean/struct.BooleanBuffer.html\" title=\"struct arrow_buffer::buffer::boolean::BooleanBuffer\">BooleanBuffer</a>&gt; for &amp;<a class=\"struct\" href=\"arrow_buffer/buffer/boolean/struct.BooleanBuffer.html\" title=\"struct arrow_buffer::buffer::boolean::BooleanBuffer\"> [...]
+"arrow_buffer":[["impl <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;<a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>&gt; for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/bi [...]
 "arrow_schema":[["impl <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;<a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Flags.html\" title=\"struct arrow_schema::ffi::flags::Flags\">Flags</a>&gt; for <a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Flags.html\" title=\"struct arrow_schema::ffi::flags::Flags\">Flags</a>"]]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/ops/bit/trait.BitXor.js b/implementors/core/ops/bit/trait.BitXor.js
index cef6b5c28..c019051ce 100644
--- a/implementors/core/ops/bit/trait.BitXor.js
+++ b/implementors/core/ops/bit/trait.BitXor.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
-"arrow_buffer":[["impl <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=\"arrow_buffer/buffer/boolean/struct.BooleanBuffer.html\" title=\"struct arrow_buffer::buffer::boolean::BooleanBuffer\">BooleanBuffer</a>&gt; for &amp;<a class=\"struct\" href=\"arrow_buffer/buffer/boolean/struct.BooleanBuffer.html\" title=\"struct arrow_buffer::buffer::boolean::BooleanBuffer [...]
+"arrow_buffer":[["impl <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;<a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>&gt; for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops [...]
 "arrow_schema":[["impl <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;<a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Flags.html\" title=\"struct arrow_schema::ffi::flags::Flags\">Flags</a>&gt; for <a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Flags.html\" title=\"struct arrow_schema::ffi::flags::Flags\">Flags</a>"]]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/ops/bit/trait.Not.js b/implementors/core/ops/bit/trait.Not.js
index 00f5002c6..18567e2d5 100644
--- a/implementors/core/ops/bit/trait.Not.js
+++ b/implementors/core/ops/bit/trait.Not.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html\" title=\"trait core::ops::bit::Not\">Not</a> for &amp;<a class=\"struct\" href=\"arrow_buffer/buffer/boolean/struct.BooleanBuffer.html\" title=\"struct arrow_buffer::buffer::boolean::BooleanBuffer\">BooleanBuffer</a>"]],
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html\" title=\"trait core::ops::bit::Not\">Not</a> for <a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Flags.html\" title=\"struct arrow_schema::ffi::flags::Flags\">Flags</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html\" title=\"trait core::ops::bit::Not\">Not</a> for <a class=\"struct\" href=\"arrow_schema/struct.SortOpti [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html\" title=\"trait core::ops::bit::Not\">Not</a> for <a class=\"struct\" href=\"arrow_schema/struct.SortOptions.html\" title=\"struct arrow_schema::SortOptions\">SortOptions</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/bit/trait.Not.html\" title=\"trait core::ops::bit::Not\">Not</a> for <a class=\"struct\" href=\"arrow_schema/ffi/flags/struct.Fl [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/ops/deref/trait.Deref.js b/implementors/core/ops/deref/trait.Deref.js
index 500d60e90..fed660278 100644
--- a/implementors/core/ops/deref/trait.Deref.js
+++ b/implementors/core/ops/deref/trait.Deref.js
@@ -1,6 +1,6 @@
 (function() {var implementors = {
 "arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>"]],
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>"],["impl&lt;T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https:/ [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>"],["impl&lt;T: <a class=\"trait\" href=\"arrow_buffer/native/trait.ArrowNativeType.html\" title=\"trait arrow_buffer::native::ArrowNativeType\">ArrowNativeType</a>&gt; <a class=\"trait\" href=\"https:/ [...]
 "arrow_csv":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" href=\"arrow_csv/reader/struct.REGEX_SET.html\" title=\"struct arrow_csv::reader::REGEX_SET\">REGEX_SET</a>"]],
 "arrow_flight":[["impl&lt;'a&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" href=\"arrow_flight/struct.SchemaAsIpc.html\" title=\"struct arrow_flight::SchemaAsIpc\">SchemaAsIpc</a>&lt;'a&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" [...]
 "arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/deref/trait.Deref.html\" title=\"trait core::ops::deref::Deref\">Deref</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields.html\" title=\"struct arrow_schema::fields::Fields\">Fields</a>"]],
diff --git a/implementors/core/ops/drop/trait.Drop.js b/implementors/core/ops/drop/trait.Drop.js
index a36f9e521..b55a73c8a 100644
--- a/implementors/core/ops/drop/trait.Drop.js
+++ b/implementors/core/ops/drop/trait.Drop.js
@@ -1,6 +1,6 @@
 (function() {var implementors = {
 "arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\"struct\" href=\"arrow/ffi_stream/struct.FFI_ArrowArrayStream.html\" title=\"struct arrow::ffi_stream::FFI_ArrowArrayStream\">FFI_ArrowArrayStream</a>"]],
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\"struct\" href=\"arrow_buffer/buffer/mutable/struct.MutableBuffer.html\" title=\"struct arrow_buffer::buffer::mutable::MutableBuffer\">MutableBuffer</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\" [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\"struct\" href=\"arrow_buffer/bytes/struct.Bytes.html\" title=\"struct arrow_buffer::bytes::Bytes\">Bytes</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\"struct\" href=\"arrow_buffer/buffer/mutable [...]
 "arrow_data":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\"struct\" href=\"arrow_data/ffi/struct.FFI_ArrowArray.html\" title=\"struct arrow_data::ffi::FFI_ArrowArray\">FFI_ArrowArray</a>"]],
 "arrow_schema":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/ops/drop/trait.Drop.html\" title=\"trait core::ops::drop::Drop\">Drop</a> for <a class=\"struct\" href=\"arrow_schema/ffi/struct.FFI_ArrowSchema.html\" title=\"struct arrow_schema::ffi::FFI_ArrowSchema\">FFI_ArrowSchema</a>"]]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/core/str/traits/trait.FromStr.js b/implementors/core/str/traits/trait.FromStr.js
index 9063ca5e5..98f8c7462 100644
--- a/implementors/core/str/traits/trait.FromStr.js
+++ b/implementors/core/str/traits/trait.FromStr.js
@@ -1,7 +1,7 @@
 (function() {var implementors = {
 "arrow_array":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"struct\" href=\"arrow_array/timezone/private/struct.Tz.html\" title=\"struct arrow_array::timezone::private::Tz\">Tz</a>"]],
 "arrow_buffer":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>"]],
-"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"enum\" href=\"arrow_cast/parse/enum.IntervalUnit.html\" title=\"enum arrow_cast::parse::IntervalUnit\">IntervalUnit</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"struct\" [...]
+"arrow_cast":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"struct\" href=\"arrow_cast/parse/struct.IntervalAmount.html\" title=\"struct arrow_cast::parse::IntervalAmount\">IntervalAmount</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a clas [...]
 "flight_sql_client":[["impl&lt;K, V&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"struct\" href=\"flight_sql_client/struct.KeyValue.html\" title=\"struct flight_sql_client::KeyValue\">KeyValue</a>&lt;K, V&gt;<span class=\"where fmt-newline\">where\n    K: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait  [...]
-"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"enum\" href=\"parquet/basic/enum.ConvertedType.html\" title=\"enum parquet::basic::ConvertedType\">ConvertedType</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"enum\" href=\" [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"enum\" href=\"parquet/basic/enum.Type.html\" title=\"enum parquet::basic::Type\">Type</a>"],["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/core/str/traits/trait.FromStr.html\" title=\"trait core::str::traits::FromStr\">FromStr</a> for <a class=\"enum\" href=\"parquet/basic/enum.Repetiti [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/flatbuffers/endian_scalar/trait.EndianScalar.js b/implementors/flatbuffers/endian_scalar/trait.EndianScalar.js
index 77b1dbd01..47c513961 100644
--- a/implementors/flatbuffers/endian_scalar/trait.EndianScalar.js
+++ b/implementors/flatbuffers/endian_scalar/trait.EndianScalar.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_ipc":[["impl EndianScalar for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Precision.html\" title=\"struct arrow_ipc::gen::Schema::Precision\">Precision</a>"],["impl EndianScalar for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Endianness.html\" title=\"struct arrow_ipc::gen::Schema::Endianness\">Endianness</a>"],["impl EndianScalar for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.DictionaryKind.html\" title=\"struct arrow_ipc::gen::Schema::Dictionary [...]
+"arrow_ipc":[["impl EndianScalar for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.CompressionType.html\" title=\"struct arrow_ipc::gen::Message::CompressionType\">CompressionType</a>"],["impl EndianScalar for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.TimeUnit.html\" title=\"struct arrow_ipc::gen::Schema::TimeUnit\">TimeUnit</a>"],["impl EndianScalar for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Feature.html\" title=\"struct arrow_ipc::gen::Schema::Fea [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/flatbuffers/follow/trait.Follow.js b/implementors/flatbuffers/follow/trait.Follow.js
index 883dd57dc..8fed0e6ea 100644
--- a/implementors/flatbuffers/follow/trait.Follow.js
+++ b/implementors/flatbuffers/follow/trait.Follow.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_ipc":[["impl&lt;'a&gt; Follow&lt;'a&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/SparseTensor/struct.SparseTensorIndexCOO.html\" title=\"struct arrow_ipc::gen::SparseTensor::SparseTensorIndexCOO\">SparseTensorIndexCOO</a>&lt;'a&gt;"],["impl&lt;'a&gt; Follow&lt;'a&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Precision.html\" title=\"struct arrow_ipc::gen::Schema::Precision\">Precision</a>"],["impl&lt;'a&gt; Follow&lt;'a&gt; for <a class=\"struct\" href=\"arrow [...]
+"arrow_ipc":[["impl&lt;'a&gt; Follow&lt;'a&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.MetadataVersion.html\" title=\"struct arrow_ipc::gen::Schema::MetadataVersion\">MetadataVersion</a>"],["impl&lt;'a&gt; Follow&lt;'a&gt; for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.BodyCompressionMethod.html\" title=\"struct arrow_ipc::gen::Message::BodyCompressionMethod\">BodyCompressionMethod</a>"],["impl&lt;'a&gt; Follow&lt;'a&gt; for <a class=\"struct\" href=\"arro [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/flatbuffers/push/trait.Push.js b/implementors/flatbuffers/push/trait.Push.js
index 704077015..a6ba28beb 100644
--- a/implementors/flatbuffers/push/trait.Push.js
+++ b/implementors/flatbuffers/push/trait.Push.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_ipc":[["impl Push for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.MessageHeader.html\" title=\"struct arrow_ipc::gen::Message::MessageHeader\">MessageHeader</a>"],["impl&lt;'b&gt; Push for <a class=\"struct\" href=\"arrow_ipc/gen/File/struct.Block.html\" title=\"struct arrow_ipc::gen::File::Block\">Block</a>"],["impl Push for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Feature.html\" title=\"struct arrow_ipc::gen::Schema::Feature\">Feature</a>"],["impl Push  [...]
+"arrow_ipc":[["impl Push for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Precision.html\" title=\"struct arrow_ipc::gen::Schema::Precision\">Precision</a>"],["impl Push for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.DictionaryKind.html\" title=\"struct arrow_ipc::gen::Schema::DictionaryKind\">DictionaryKind</a>"],["impl&lt;'b&gt; Push for <a class=\"struct\" href=\"arrow_ipc/gen/File/struct.Block.html\" title=\"struct arrow_ipc::gen::File::Block\">Block</a>"],["imp [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/flatbuffers/verifier/trait.SimpleToVerifyInSlice.js b/implementors/flatbuffers/verifier/trait.SimpleToVerifyInSlice.js
index d6fa677fb..1a47c1860 100644
--- a/implementors/flatbuffers/verifier/trait.SimpleToVerifyInSlice.js
+++ b/implementors/flatbuffers/verifier/trait.SimpleToVerifyInSlice.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_ipc":[["impl SimpleToVerifyInSlice for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.IntervalUnit.html\" title=\"struct arrow_ipc::gen::Schema::IntervalUnit\">IntervalUnit</a>"],["impl SimpleToVerifyInSlice for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Precision.html\" title=\"struct arrow_ipc::gen::Schema::Precision\">Precision</a>"],["impl SimpleToVerifyInSlice for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.MetadataVersion.html\" title=\"struct  [...]
+"arrow_ipc":[["impl SimpleToVerifyInSlice for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Type.html\" title=\"struct arrow_ipc::gen::Schema::Type\">Type</a>"],["impl SimpleToVerifyInSlice for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.IntervalUnit.html\" title=\"struct arrow_ipc::gen::Schema::IntervalUnit\">IntervalUnit</a>"],["impl SimpleToVerifyInSlice for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.BodyCompressionMethod.html\" title=\"struct arrow_ip [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/flatbuffers/verifier/trait.Verifiable.js b/implementors/flatbuffers/verifier/trait.Verifiable.js
index 99591f6c4..95a3a4b4c 100644
--- a/implementors/flatbuffers/verifier/trait.Verifiable.js
+++ b/implementors/flatbuffers/verifier/trait.Verifiable.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_ipc":[["impl&lt;'a&gt; Verifiable for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct.BodyCompressionMethod.html\" title=\"struct arrow_ipc::gen::Message::BodyCompressionMethod\">BodyCompressionMethod</a>"],["impl Verifiable for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.FixedSizeList.html\" title=\"struct arrow_ipc::gen::Schema::FixedSizeList\">FixedSizeList</a>&lt;'_&gt;"],["impl&lt;'a&gt; Verifiable for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct [...]
+"arrow_ipc":[["impl Verifiable for <a class=\"struct\" href=\"arrow_ipc/gen/Schema/struct.Interval.html\" title=\"struct arrow_ipc::gen::Schema::Interval\">Interval</a>&lt;'_&gt;"],["impl&lt;'a&gt; Verifiable for <a class=\"struct\" href=\"arrow_ipc/gen/SparseTensor/struct.SparseMatrixCompressedAxis.html\" title=\"struct arrow_ipc::gen::SparseTensor::SparseMatrixCompressedAxis\">SparseMatrixCompressedAxis</a>"],["impl Verifiable for <a class=\"struct\" href=\"arrow_ipc/gen/Message/struct [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/futures_core/stream/trait.Stream.js b/implementors/futures_core/stream/trait.Stream.js
index 101ca064c..18fd08bfd 100644
--- a/implementors/futures_core/stream/trait.Stream.js
+++ b/implementors/futures_core/stream/trait.Stream.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
-"arrow_flight":[["impl Stream for <a class=\"struct\" href=\"arrow_flight/encode/struct.FlightDataEncoder.html\" title=\"struct arrow_flight::encode::FlightDataEncoder\">FlightDataEncoder</a>"],["impl Stream for <a class=\"struct\" href=\"arrow_flight/decode/struct.FlightRecordBatchStream.html\" title=\"struct arrow_flight::decode::FlightRecordBatchStream\">FlightRecordBatchStream</a>"],["impl Stream for <a class=\"struct\" href=\"arrow_flight/decode/struct.FlightDataDecoder.html\" title [...]
+"arrow_flight":[["impl Stream for <a class=\"struct\" href=\"arrow_flight/decode/struct.FlightRecordBatchStream.html\" title=\"struct arrow_flight::decode::FlightRecordBatchStream\">FlightRecordBatchStream</a>"],["impl Stream for <a class=\"struct\" href=\"arrow_flight/encode/struct.FlightDataEncoder.html\" title=\"struct arrow_flight::encode::FlightDataEncoder\">FlightDataEncoder</a>"],["impl Stream for <a class=\"struct\" href=\"arrow_flight/decode/struct.FlightDataDecoder.html\" title [...]
 "parquet":[["impl&lt;T&gt; Stream for <a class=\"struct\" href=\"parquet/arrow/async_reader/struct.ParquetRecordBatchStream.html\" title=\"struct parquet::arrow::async_reader::ParquetRecordBatchStream\">ParquetRecordBatchStream</a>&lt;T&gt;<span class=\"where fmt-newline\">where\n    T: <a class=\"trait\" href=\"parquet/arrow/async_reader/trait.AsyncFileReader.html\" title=\"trait parquet::arrow::async_reader::AsyncFileReader\">AsyncFileReader</a> + <a class=\"trait\" href=\"https://doc. [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/num_traits/cast/trait.AsPrimitive.js b/implementors/num_traits/cast/trait.AsPrimitive.js
index 6341e4262..b0463222d 100644
--- a/implementors/num_traits/cast/trait.AsPrimitive.js
+++ b/implementors/num_traits/cast/trait.AsPrimitive.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_buffer":[["impl <a class=\"trait\" href=\"https://docs.rs/num-traits/0.2/num_traits/cast/trait.AsPrimitive.html\" title=\"trait num_traits::cast::AsPrimitive\">AsPrimitive</a>&lt;<a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>&gt; for <a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u16.html\">u16</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/num-traits/0.2/num_traits/cast/ [...]
+"arrow_buffer":[["impl <a class=\"trait\" href=\"https://docs.rs/num-traits/0.2/num_traits/cast/trait.AsPrimitive.html\" title=\"trait num_traits::cast::AsPrimitive\">AsPrimitive</a>&lt;<a class=\"struct\" href=\"arrow_buffer/bigint/struct.i256.html\" title=\"struct arrow_buffer::bigint::i256\">i256</a>&gt; for <a class=\"primitive\" href=\"https://doc.rust-lang.org/nightly/std/primitive.u64.html\">u64</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/num-traits/0.2/num_traits/cast/ [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/prost/message/trait.Message.js b/implementors/prost/message/trait.Message.js
index 80a2092c1..44cb6bdc5 100644
--- a/implementors/prost/message/trait.Message.js
+++ b/implementors/prost/message/trait.Message.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow_flight":[["impl <a class=\"trait\" href=\"https://docs.rs/prost/0.11.9/prost/message/trait.Message.html\" title=\"trait prost::message::Message\">Message</a> for <a class=\"struct\" href=\"arrow_flight/gen/struct.Result.html\" title=\"struct arrow_flight::gen::Result\">Result</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/prost/0.11.9/prost/message/trait.Message.html\" title=\"trait prost::message::Message\">Message</a> for <a class=\"struct\" href=\"arrow_flight/sql/gen/s [...]
+"arrow_flight":[["impl <a class=\"trait\" href=\"https://docs.rs/prost/0.11.9/prost/message/trait.Message.html\" title=\"trait prost::message::Message\">Message</a> for <a class=\"struct\" href=\"arrow_flight/sql/gen/struct.ActionEndSavepointRequest.html\" title=\"struct arrow_flight::sql::gen::ActionEndSavepointRequest\">ActionEndSavepointRequest</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/prost/0.11.9/prost/message/trait.Message.html\" title=\"trait prost::message::Message\" [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/pyo3/conversion/trait.FromPyObject.js b/implementors/pyo3/conversion/trait.FromPyObject.js
index c8328f385..5a3a1989a 100644
--- a/implementors/pyo3/conversion/trait.FromPyObject.js
+++ b/implementors/pyo3/conversion/trait.FromPyObject.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow":[["impl&lt;'source, T: <a class=\"trait\" href=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"arrow/pyarrow/trait.IntoPyArrow.html\" title=\"trait arrow::pyarrow::IntoPyArrow\">IntoPyArrow</a>&gt; FromPyObject&lt;'source&gt; for <a class=\"struct\" href=\"arrow/pyarrow/struct.PyArrowType.html\" title=\"struct arrow::pyarrow::PyArrowType\">PyArrowType</a>&lt;T&gt;"],["impl&lt;'py&gt; FromPyObject&lt; [...]
+"arrow":[["impl&lt;'py&gt; FromPyObject&lt;'py&gt; for &amp;'py <a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>"],["impl&lt;'source, T: <a class=\"trait\" href=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"arrow/pyarrow/trait.IntoPyArrow.html\" title=\"trait arrow::pyarrow::IntoPyArrow\">IntoPyArrow</a>&gt; FromPyObjec [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/pyo3/conversion/trait.IntoPy.js b/implementors/pyo3/conversion/trait.IntoPy.js
index ca8b8006f..939d2e788 100644
--- a/implementors/pyo3/conversion/trait.IntoPy.js
+++ b/implementors/pyo3/conversion/trait.IntoPy.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"arrow":[["impl&lt;T: <a class=\"trait\" href=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"arrow/pyarrow/trait.IntoPyArrow.html\" title=\"trait arrow::pyarrow::IntoPyArrow\">IntoPyArrow</a>&gt; IntoPy&lt;Py&lt;PyAny&gt;&gt; for <a class=\"struct\" href=\"arrow/pyarrow/struct.PyArrowType.html\" title=\"struct arrow::pyarrow::PyArrowType\">PyArrowType</a>&lt;T&gt;"],["impl IntoPy&lt;Py&lt;<a class=\"struct\ [...]
+"arrow":[["impl IntoPy&lt;Py&lt;<a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>&gt;&gt; for &amp;<a class=\"struct\" href=\"arrow/pyarrow/struct.ArrowException.html\" title=\"struct arrow::pyarrow::ArrowException\">ArrowException</a>"],["impl&lt;T: <a class=\"trait\" href=\"arrow/pyarrow/trait.FromPyArrow.html\" title=\"trait arrow::pyarrow::FromPyArrow\">FromPyArrow</a> + <a class=\"trait\" href=\"a [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/serde/de/trait.Deserialize.js b/implementors/serde/de/trait.Deserialize.js
index 96d581811..b2808b600 100644
--- a/implementors/serde/de/trait.Deserialize.js
+++ b/implementors/serde/de/trait.Deserialize.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
-"arrow_integration_test":[["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde::de::Deserialize\">Deserialize</a>&lt;'de&gt; for <a class=\"struct\" href=\"arrow_integration_test/schema/struct.MetadataKeyValue.html\" title=\"struct arrow_integration_test::schema::MetadataKeyValue\">MetadataKeyValue</a>"],["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" tit [...]
-"arrow_schema":[["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde::de::Deserialize\">Deserialize</a>&lt;'de&gt; for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde::de::Deserialize\">Deserialize</a>&l [...]
+"arrow_integration_test":[["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde::de::Deserialize\">Deserialize</a>&lt;'de&gt; for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonColumn.html\" title=\"struct arrow_integration_test::ArrowJsonColumn\">ArrowJsonColumn</a>"],["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde:: [...]
+"arrow_schema":[["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde::de::Deserialize\">Deserialize</a>&lt;'de&gt; for <a class=\"enum\" href=\"arrow_schema/datatype/enum.UnionMode.html\" title=\"enum arrow_schema::datatype::UnionMode\">UnionMode</a>"],["impl&lt;'de&gt; <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/de/trait.Deserialize.html\" title=\"trait serde::de::Deserialize\">Deserialize</a>&l [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/serde/ser/trait.Serialize.js b/implementors/serde/ser/trait.Serialize.js
index e380f0ffa..b5d960f7e 100644
--- a/implementors/serde/ser/trait.Serialize.js
+++ b/implementors/serde/ser/trait.Serialize.js
@@ -1,5 +1,5 @@
 (function() {var implementors = {
-"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonDictionaryBatch.html\" title=\"struct arrow_integration_test::ArrowJsonDictionaryBatch\">ArrowJsonDictionaryBatch</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serial [...]
-"arrow_schema":[["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.UnionFields.html\" title=\"struct arrow_schema::fields::UnionFields\">UnionFields</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"enum\" href=\"arrow [...]
-"parquet_layout":[["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"parquet_layout/struct.RowGroup.html\" title=\"struct parquet_layout::RowGroup\">RowGroup</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"parquet_layout/struct [...]
+"arrow_integration_test":[["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"arrow_integration_test/struct.ArrowJsonFieldDictionary.html\" title=\"struct arrow_integration_test::ArrowJsonFieldDictionary\">ArrowJsonFieldDictionary</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serial [...]
+"arrow_schema":[["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"arrow_schema/fields/struct.Fields.html\" title=\"struct arrow_schema::fields::Fields\">Fields</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"enum\" href=\"arrow_schema/datatyp [...]
+"parquet_layout":[["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"parquet_layout/struct.ParquetFile.html\" title=\"struct parquet_layout::ParquetFile\">ParquetFile</a>"],["impl <a class=\"trait\" href=\"https://docs.rs/serde/1.0.164/serde/ser/trait.Serialize.html\" title=\"trait serde::ser::Serialize\">Serialize</a> for <a class=\"struct\" href=\"parquet_layo [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/std/io/trait.Write.js b/implementors/std/io/trait.Write.js
index 7611c9adb..5a9505629 100644
--- a/implementors/std/io/trait.Write.js
+++ b/implementors/std/io/trait.Write.js
@@ -1,4 +1,4 @@
 (function() {var implementors = {
 "arrow":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Write.html\" title=\"trait std::io::Write\">Write</a> for <a class=\"struct\" href=\"arrow/util/string_writer/struct.StringWriter.html\" title=\"struct arrow::util::string_writer::StringWriter\">StringWriter</a>"]],
-"parquet":[["impl&lt;W: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Write.html\" title=\"trait std::io::Write\">Write</a>&gt; <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Write.html\" title=\"trait std::io::Write\">Write</a> for <a class=\"struct\" href=\"parquet/file/writer/struct.TrackedWrite.html\" title=\"struct parquet::file::writer::TrackedWrite\">TrackedWrite</a>&lt;W&gt;"],["impl <a class=\"trait\" href=\"https://doc.rust-l [...]
+"parquet":[["impl <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Write.html\" title=\"trait std::io::Write\">Write</a> for <a class=\"struct\" href=\"parquet/arrow/async_writer/struct.SharedBuffer.html\" title=\"struct parquet::arrow::async_writer::SharedBuffer\">SharedBuffer</a>"],["impl&lt;W: <a class=\"trait\" href=\"https://doc.rust-lang.org/nightly/std/io/trait.Write.html\" title=\"trait std::io::Write\">Write</a>&gt; <a class=\"trait\" href=\"https://doc.r [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/implementors/thrift/protocol/trait.TSerializable.js b/implementors/thrift/protocol/trait.TSerializable.js
index 605753237..564462e9a 100644
--- a/implementors/thrift/protocol/trait.TSerializable.js
+++ b/implementors/thrift/protocol/trait.TSerializable.js
@@ -1,3 +1,3 @@
 (function() {var implementors = {
-"parquet":[["impl TSerializable for <a class=\"enum\" href=\"parquet/format/enum.ColumnCryptoMetaData.html\" title=\"enum parquet::format::ColumnCryptoMetaData\">ColumnCryptoMetaData</a>"],["impl TSerializable for <a class=\"enum\" href=\"parquet/format/enum.BloomFilterAlgorithm.html\" title=\"enum parquet::format::BloomFilterAlgorithm\">BloomFilterAlgorithm</a>"],["impl TSerializable for <a class=\"struct\" href=\"parquet/format/struct.MicroSeconds.html\" title=\"struct parquet::format: [...]
+"parquet":[["impl TSerializable for <a class=\"struct\" href=\"parquet/format/struct.SortingColumn.html\" title=\"struct parquet::format::SortingColumn\">SortingColumn</a>"],["impl TSerializable for <a class=\"struct\" href=\"parquet/format/struct.ColumnIndex.html\" title=\"struct parquet::format::ColumnIndex\">ColumnIndex</a>"],["impl TSerializable for <a class=\"enum\" href=\"parquet/format/enum.EncryptionAlgorithm.html\" title=\"enum parquet::format::EncryptionAlgorithm\">EncryptionAl [...]
 };if (window.register_implementors) {window.register_implementors(implementors);} else {window.pending_implementors = implementors;}})()
\ No newline at end of file
diff --git a/parquet/arrow/arrow_reader/selection/struct.RowSelection.html b/parquet/arrow/arrow_reader/selection/struct.RowSelection.html
index 03a00b079..a62f1ede9 100644
--- a/parquet/arrow/arrow_reader/selection/struct.RowSelection.html
+++ b/parquet/arrow/arrow_reader/selection/struct.RowSelection.html
@@ -66,7 +66,7 @@ other:     NYNNNNNNY</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="srclink rightside" href="../../../../src/parquet/arrow/arrow_reader/selection.rs.html#441-443">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt [...]
 <a href="struct.RowSelection.html" title="struct parquet::arrow::arrow_reader::selection::RowSelection"><code>RowSelection</code></a>.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.row_count" class="method"><a class="srclink rightside" href="../../../../src/parquet/arrow/arrow_reader/selection.rs.html#446-448">source</a><h4 class="code-header">pub fn <a href="#method.row_count" class="fn">row_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the numb [...]
-</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-RowSelection" class="impl"><a class="srclink rightside" href="../../../../src/parquet/arrow/arrow_reader/selection.rs.html#87">source</a><a href="#impl-Clone-for-RowSelection" class="anchor">§ [...]
+</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-RowSelection" class="impl"><a class="srclink rightside" href="../../../../src/parquet/arrow/arrow_reader/selection.rs.html#87">source</a><a href="#impl-Clone-for-RowSelection" class="anchor">§ [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-RowSelection" class="impl"><a class="srclink rightside" href="../../../../src/parquet/arrow/arrow_reader/selection.rs.html#87">source</a><a href="#impl-Eq-for-RowSelection" 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="str [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/arrow/arrow_reader/struct.RowSelection.html b/parquet/arrow/arrow_reader/struct.RowSelection.html
index 240bea53f..b40b58ca9 100644
--- a/parquet/arrow/arrow_reader/struct.RowSelection.html
+++ b/parquet/arrow/arrow_reader/struct.RowSelection.html
@@ -66,7 +66,7 @@ other:     NYNNNNNNY</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.iter" class="method"><a class="srclink rightside" href="../../../src/parquet/arrow/arrow_reader/selection.rs.html#441-443">source</a><h4 class="code-header">pub fn <a href="#method.iter" class="fn">iter</a>(&amp;self) -&gt; impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/iter/traits/iterator/trait.Iterator.html" title="trait core::iter::traits::iterator::Iterator">Iterator</a>&lt;It [...]
 <a href="selection/struct.RowSelection.html" title="struct parquet::arrow::arrow_reader::selection::RowSelection"><code>RowSelection</code></a>.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.row_count" class="method"><a class="srclink rightside" href="../../../src/parquet/arrow/arrow_reader/selection.rs.html#446-448">source</a><h4 class="code-header">pub fn <a href="#method.row_count" class="fn">row_count</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a></h4></section></summary><div class="docblock"><p>Returns the number  [...]
-</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-RowSelection" class="impl"><a class="srclink rightside" href="../../../src/parquet/arrow/arrow_reader/selection.rs.html#87">source</a><a href="#impl-Clone-for-RowSelection" class="anchor">§</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-RowSelection" class="impl"><a class="srclink rightside" href="../../../src/parquet/arrow/arrow_reader/selection.rs.html#87">source</a><a href="#impl-Clone-for-RowSelection" class="anchor">§</a [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-RowSelection" class="impl"><a class="srclink rightside" href="../../../src/parquet/arrow/arrow_reader/selection.rs.html#87">source</a><a href="#impl-Eq-for-RowSelection" 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="select [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/arrow/record_reader/buffer/trait.ScalarValue.html b/parquet/arrow/record_reader/buffer/trait.ScalarValue.html
index bf35c7f2a..de19b4e4d 100644
--- a/parquet/arrow/record_reader/buffer/trait.ScalarValue.html
+++ b/parquet/arrow/record_reader/buffer/trait.ScalarValue.html
@@ -2,4 +2,4 @@
 <p>This means that a <code>[Self::default()]</code> of length <code>len</code> can be safely created from a
 zero-initialized <code>[u8]</code> with length <code>len * std::mem::size_of::&lt;Self&gt;()</code> and
 alignment of <code>std::mem::size_of::&lt;Self&gt;()</code></p>
-</div></details><h2 id="foreign-impls" class="small-section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§</a></h2><section id="impl-ScalarValue-for-f32" class="impl"><a class="srclink rightside" href="../../../../src/parquet/arrow/record_reader/buffer.rs.html#81">source</a><a href="#impl-ScalarValue-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ScalarValue.html" title="trait parquet::arrow::record_reader::buffer [...]
\ No newline at end of file
+</div></details><h2 id="foreign-impls" class="small-section-header">Implementations on Foreign Types<a href="#foreign-impls" class="anchor">§</a></h2><section id="impl-ScalarValue-for-u16" class="impl"><a class="srclink rightside" href="../../../../src/parquet/arrow/record_reader/buffer.rs.html#75">source</a><a href="#impl-ScalarValue-for-u16" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ScalarValue.html" title="trait parquet::arrow::record_reader::buffer [...]
\ No newline at end of file
diff --git a/parquet/basic/enum.ColumnOrder.html b/parquet/basic/enum.ColumnOrder.html
index ae29831fb..19d006d3a 100644
--- a/parquet/basic/enum.ColumnOrder.html
+++ b/parquet/basic/enum.ColumnOrder.html
@@ -19,7 +19,7 @@ Sort order is always SIGNED.</p>
     physical_type: <a class="enum" href="enum.Type.html" title="enum parquet::basic::Type">Type</a>
 ) -&gt; <a class="enum" href="enum.SortOrder.html" title="enum parquet::basic::SortOrder">SortOrder</a></h4></section><details class="toggle method-toggle" open><summary><section id="method.get_default_sort_order" class="method"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#431-447">source</a><h4 class="code-header">fn <a href="#method.get_default_sort_order" class="fn">get_default_sort_order</a>(physical_type: <a class="enum" href="enum.Type.html" title="enum parque [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.sort_order" class="method"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#450-455">source</a><h4 class="code-header">pub fn <a href="#method.sort_order" class="fn">sort_order</a>(&amp;self) -&gt; <a class="enum" href="enum.SortOrder.html" title="enum parquet::basic::SortOrder">SortOrder</a></h4></section></summary><div class="docblock"><p>Returns sort order associated with this col [...]
-</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-ColumnOrder" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#346">source</a><a href="#impl-Clone-for-ColumnOrder" class="anchor">§</a><h3 class="code-header">im [...]
+</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-ColumnOrder" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#346">source</a><a href="#impl-Clone-for-ColumnOrder" class="anchor">§</a><h3 class="code-header">im [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Copy-for-ColumnOrder" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#346">source</a><a href="#impl-Copy-for-ColumnOrder" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Copy.html" title="trait core::marker::Copy">Copy</a> for <a class="enum" href="enum.ColumnOrder.ht [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/basic/enum.Compression.html b/parquet/basic/enum.Compression.html
index 7614b972c..7d82c19a2 100644
--- a/parquet/basic/enum.Compression.html
+++ b/parquet/basic/enum.Compression.html
@@ -8,7 +8,7 @@
     ZSTD(<a class="struct" href="struct.ZstdLevel.html" title="struct parquet::basic::ZstdLevel">ZstdLevel</a>),
     LZ4_RAW,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Supported compression algorithms.</p>
-</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.UNCOMPRESSED" class="variant"><a href="#variant.UNCOMPRESSED" class="anchor">§</a><h3 class="code-header">UNCOMPRESSED</h3></section><section id="variant.SNAPPY" class="variant"><a href="#variant.SNAPPY" class="anchor">§</a><h3 class="code-header">SNAPPY</h3></section><section id="variant.GZIP" class="variant"><a href="#va [...]
+</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.UNCOMPRESSED" class="variant"><a href="#variant.UNCOMPRESSED" class="anchor">§</a><h3 class="code-header">UNCOMPRESSED</h3></section><section id="variant.SNAPPY" class="variant"><a href="#variant.SNAPPY" class="anchor">§</a><h3 class="code-header">SNAPPY</h3></section><section id="variant.GZIP" class="variant"><a href="#va [...]
 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="srclink" 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" 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-TryFrom%3CCompressionCodec%3E-for-Compression" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#827-848">source</a><a href="#impl-TryFrom%3CCompressionCodec%3E-for-Compression" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/basic/enum.ConvertedType.html b/parquet/basic/enum.ConvertedType.html
index 9bdc5d99d..1de4a0e56 100644
--- a/parquet/basic/enum.ConvertedType.html
+++ b/parquet/basic/enum.ConvertedType.html
@@ -70,7 +70,7 @@ the number of months associated with the duration, the second identifies
 the number of days associated with the duration and the third identifies
 the number of milliseconds associated with the provided duration.
 This duration of time is independent of any particular timezone or date.</p>
-</div></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-ConvertedType" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#67">source</a><a href="#impl-Clone-for-ConvertedType" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
+</div></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-ConvertedType" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#67">source</a><a href="#impl-Clone-for-ConvertedType" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
 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="srclink" 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" 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-TryFrom%3COption%3CConvertedType%3E%3E-for-ConvertedType" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#545-587">source</a><a href="#impl-TryFrom%3COption%3CConvertedType%3E%3E-for-ConvertedType" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/basic/enum.Encoding.html b/parquet/basic/enum.Encoding.html
index 743b27231..f8a8f111b 100644
--- a/parquet/basic/enum.Encoding.html
+++ b/parquet/basic/enum.Encoding.html
@@ -45,7 +45,7 @@ The individual bytes of an FP value are scattered to the corresponding stream an
 the streams are concatenated.
 This itself does not reduce the size of the data but can lead to better compression
 afterwards.</p>
-</div></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-Encoding" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#219">source</a><a href="#impl-Clone-for-Encoding" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https: [...]
+</div></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-Encoding" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#219">source</a><a href="#impl-Clone-for-Encoding" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https: [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/basic/enum.LogicalType.html b/parquet/basic/enum.LogicalType.html
index 3626cb901..b5c1bdb49 100644
--- a/parquet/basic/enum.LogicalType.html
+++ b/parquet/basic/enum.LogicalType.html
@@ -28,7 +28,7 @@
 <p>This is an <em>entirely new</em> struct as of version
 4.0.0. The struct previously named <code>LogicalType</code> was renamed to
 <a href="enum.ConvertedType.html" title="enum parquet::basic::ConvertedType"><code>ConvertedType</code></a>. Please see the README.md for more details.</p>
-</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.String" class="variant"><a href="#variant.String" class="anchor">§</a><h3 class="code-header">String</h3></section><section id="variant.Map" class="variant"><a href="#variant.Map" class="anchor">§</a><h3 class="code-header">Map</h3></section><section id="variant.List" class="variant"><a href="#variant.List" class="anchor"> [...]
+</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.String" class="variant"><a href="#variant.String" class="anchor">§</a><h3 class="code-header">String</h3></section><section id="variant.Map" class="variant"><a href="#variant.Map" class="anchor">§</a><h3 class="code-header">Map</h3></section><section id="variant.List" class="variant"><a href="#variant.List" class="anchor"> [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-LogicalType" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#169">source</a><a href="#impl-Eq-for-LogicalType" 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="enum" href="enum.LogicalType.html" title="enum  [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/basic/enum.PageType.html b/parquet/basic/enum.PageType.html
index 68cce9d96..d82fcdd39 100644
--- a/parquet/basic/enum.PageType.html
+++ b/parquet/basic/enum.PageType.html
@@ -5,7 +5,7 @@
     DATA_PAGE_V2,
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Available data pages for Parquet file format.
 Note that some of the page types may not be supported.</p>
-</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.DATA_PAGE" class="variant"><a href="#variant.DATA_PAGE" class="anchor">§</a><h3 class="code-header">DATA_PAGE</h3></section><section id="variant.INDEX_PAGE" class="variant"><a href="#variant.INDEX_PAGE" class="anchor">§</a><h3 class="code-header">INDEX_PAGE</h3></section><section id="variant.DICTIONARY_PAGE" class="variant [...]
+</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.DATA_PAGE" class="variant"><a href="#variant.DATA_PAGE" class="anchor">§</a><h3 class="code-header">DATA_PAGE</h3></section><section id="variant.INDEX_PAGE" class="variant"><a href="#variant.INDEX_PAGE" class="anchor">§</a><h3 class="code-header">INDEX_PAGE</h3></section><section id="variant.DICTIONARY_PAGE" class="variant [...]
 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="srclink" 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" 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-TryFrom%3CPageType%3E-for-PageType" class="impl"><a class="srclink rightside" href="../../src/parquet/basic.rs.html#868-880">source</a><a href="#impl-TryFrom%3CPageType%3E-for-PageType" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/convert/trait.TryFrom [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/basic/enum.Type.html b/parquet/basic/enum.Type.html
index b54801029..b1b266b88 100644
--- a/parquet/basic/enum.Type.html
+++ b/parquet/basic/enum.Type.html
@@ -12,7 +12,7 @@ These physical types are intended to be used in combination with the encodings t
 control the on disk storage format.
 For example INT16 is not included as a type since a good encoding of INT32
 would handle this.</p>
-</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.BOOLEAN" class="variant"><a href="#variant.BOOLEAN" class="anchor">§</a><h3 class="code-header">BOOLEAN</h3></section><section id="variant.INT32" class="variant"><a href="#variant.INT32" class="anchor">§</a><h3 class="code-header">INT32</h3></section><section id="variant.INT64" class="variant"><a href="#variant.INT64" clas [...]
+</div></details><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.BOOLEAN" class="variant"><a href="#variant.BOOLEAN" class="anchor">§</a><h3 class="code-header">BOOLEAN</h3></section><section id="variant.INT32" class="variant"><a href="#variant.INT32" class="anchor">§</a><h3 class="code-header">INT32</h3></section><section id="variant.INT64" class="variant"><a href="#variant.INT64" clas [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
 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="srclink" 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" cl [...]
diff --git a/parquet/data_type/private/trait.ParquetValueType.html b/parquet/data_type/private/trait.ParquetValueType.html
index b6622dc04..e0aaa95de 100644
--- a/parquet/data_type/private/trait.ParquetValueType.html
+++ b/parquet/data_type/private/trait.ParquetValueType.html
@@ -54,59 +54,59 @@ implemented for <code>f32</code> and <code>f64</code>, types that would fail orp
 </div></details><details class="toggle method-toggle" open><summary><section id="method.as_u64" class="method"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#654-658">source</a><h4 class="code-header">fn <a href="#method.as_u64" class="fn">as_u64</a>(&amp;self) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u64.html">u64</a>& [...]
 <p>This is essentially the same as <code>std::convert::TryInto&lt;u64&gt;</code> but can
 implemented for <code>f32</code> and <code>f64</code>, types that would fail orphan rules</p>
-</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-ParquetValueType-for-i32" class="impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#impl-ParquetValueType-for-i32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ParquetValueType.h [...]
+</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-ParquetValueType-for-f64" class="impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#impl-ParquetValueType-for-f64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ParquetValueType.h [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
     _: &amp;mut BitWriter
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#method.set_data" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#method.set_data" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
     decoder: &amp;mut PlainDecoderDetails,
     data: ByteBufferPtr,
     num_values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-)</h4></section><section id="method.decode" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#method.decode" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
+)</h4></section><section id="method.decode" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#method.decode" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
     buffer: &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     decoder: &amp;mut PlainDecoderDetails
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#method.skip" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decoder:  [...]
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#method.skip" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decoder:  [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
     _: &amp;mut BitWriter
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#method.set_data-1" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#812">source</a><a href="#method.set_data-1" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
     decoder: &amp;mut PlainDecoderDetails,
     data: ByteBufferPtr,
     num_values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-)</h4></section><section id="method.decode-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#method.decode-1" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
+)</h4></section><section id="method.decode-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#812">source</a><a href="#method.decode-1" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
     buffer: &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     decoder: &amp;mut PlainDecoderDetails
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#813">source</a><a href="#method.skip-1" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decod [...]
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-1" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#812">source</a><a href="#method.skip-1" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decod [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
     _: &amp;mut BitWriter
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#812">source</a><a href="#method.set_data-2" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#811">source</a><a href="#method.set_data-2" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
     decoder: &amp;mut PlainDecoderDetails,
     data: ByteBufferPtr,
     num_values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-)</h4></section><section id="method.decode-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#812">source</a><a href="#method.decode-2" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
+)</h4></section><section id="method.decode-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#811">source</a><a href="#method.decode-2" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
     buffer: &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     decoder: &amp;mut PlainDecoderDetails
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#812">source</a><a href="#method.skip-2" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decod [...]
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-2" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#811">source</a><a href="#method.skip-2" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decod [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
-    _: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
-    bit_writer: &amp;mut BitWriter
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#683-690">source</a><a href="#method.set_data-3" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">se [...]
+    writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
+    _: &amp;mut BitWriter
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#method.set_data-3" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
     decoder: &amp;mut PlainDecoderDetails,
     data: ByteBufferPtr,
     num_values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-)</h4></section><section id="method.decode-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#693-702">source</a><a href="#method.decode-3" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
+)</h4></section><section id="method.decode-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#method.decode-3" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
     buffer: &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     decoder: &amp;mut PlainDecoderDetails
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#704-710">source</a><a href="#method.skip-3" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(d [...]
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-3" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#810">source</a><a href="#method.skip-3" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decod [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
-    writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
-    _: &amp;mut BitWriter
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-4" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#811">source</a><a href="#method.set_data-4" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">set_data</a>(
+    _: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
+    bit_writer: &amp;mut BitWriter
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.unit.html">()</a>&gt;</h4></section><section id="method.set_data-4" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#683-690">source</a><a href="#method.set_data-4" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.set_data" class="fn">se [...]
     decoder: &amp;mut PlainDecoderDetails,
     data: ByteBufferPtr,
     num_values: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>
-)</h4></section><section id="method.decode-4" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#811">source</a><a href="#method.decode-4" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
+)</h4></section><section id="method.decode-4" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#693-702">source</a><a href="#method.decode-4" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.decode" class="fn">decode</a>(
     buffer: &amp;mut <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     decoder: &amp;mut PlainDecoderDetails
-) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-4" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#811">source</a><a href="#method.skip-4" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(decod [...]
\ No newline at end of file
+) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section><section id="method.skip-4" class="method trait-impl"><a class="srclink rightside" href="../../../src/parquet/data_type.rs.html#704-710">source</a><a href="#method.skip-4" class="anchor">§</a><h4 class="code-header">fn <a href="#tymethod.skip" class="fn">skip</a>(d [...]
\ No newline at end of file
diff --git a/parquet/data_type/struct.ByteArray.html b/parquet/data_type/struct.ByteArray.html
index 66f83c2cc..4b11ffc7d 100644
--- a/parquet/data_type/struct.ByteArray.html
+++ b/parquet/data_type/struct.ByteArray.html
@@ -8,7 +8,7 @@ Value is backed by a byte buffer.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.data" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#161-166">source</a><h4 class="code-header">pub fn <a href="#method.data" class="fn">data</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div class="docblo [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_data" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#170-172">source</a><h4 class="code-header">pub fn <a href="#method.set_data" class="fn">set_data</a>(&amp;mut self, data: ByteBufferPtr)</h4></section></summary><div class="docblock"><p>Set data from another byte buffer.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#176-183">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, start: <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 [...]
-</div></details><section id="method.as_utf8" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#185-191">source</a><h4 class="code-header">pub fn <a href="#method.as_utf8" class="fn">as_utf8</a>(&amp;self) -&gt; <a class="type" href="../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></div></details></div><h2 id [...]
+</div></details><section id="method.as_utf8" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#185-191">source</a><h4 class="code-header">pub fn <a href="#method.as_utf8" class="fn">as_utf8</a>(&amp;self) -&gt; <a class="type" href="../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></div></details></div><h2 id [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ParquetValueType-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#914-1005">source</a><a href="#impl-ParquetValueType-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a cl [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
@@ -26,12 +26,12 @@ sufficient, and should not be overridden without very good reason.</div></detail
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
 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%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#280-284">source</a><a href="#impl-PartialEq%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightl [...]
 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="srclink" 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" 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-PartialOrd%3CByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#121-137">source</a><a href="#impl-PartialOrd%3CByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/tra [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt-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="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt-1" class="anchor">§</a><h4 class="code-hea [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#121-137">source</a><a href="#impl-PartialOrd%3CByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/tra [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#304-308">source</a><a href="#impl-PartialOrd%3CByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="t [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt-2" class="anchor">§</a><h4 class="code-hea [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#298-302">source</a><a href="#impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="t [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#298-302">source</a><a href="#impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="t [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt-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="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt-1" class="anchor">§</a><h4 class="code-hea [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-SliceAsBytes-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#531">source</a><a href="#impl-SliceAsBytes-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.SliceAsBytes.html" title="tr [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
diff --git a/parquet/data_type/struct.FixedLenByteArray.html b/parquet/data_type/struct.FixedLenByteArray.html
index 370deda07..6cda41bfe 100644
--- a/parquet/data_type/struct.FixedLenByteArray.html
+++ b/parquet/data_type/struct.FixedLenByteArray.html
@@ -14,7 +14,7 @@ level logical types, removing the data-hazard from all decoding and encoding pat
 </div></details><details class="toggle method-toggle" open><summary><section id="method.data" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#161-166">source</a><h4 class="code-header">pub fn <a href="#method.data" class="fn">data</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u8.html">u8</a>] <a href="#" class="tooltip" data-notable-ty="&amp;[u8]">ⓘ</a></h4></section></summary><div class="docblo [...]
 </div></details><details class="toggle method-toggle" open><summary><section id="method.set_data" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#170-172">source</a><h4 class="code-header">pub fn <a href="#method.set_data" class="fn">set_data</a>(&amp;mut self, data: ByteBufferPtr)</h4></section></summary><div class="docblock"><p>Set data from another byte buffer.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.slice" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#176-183">source</a><h4 class="code-header">pub fn <a href="#method.slice" class="fn">slice</a>(&amp;self, start: <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 [...]
-</div></details><section id="method.as_utf8" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#185-191">source</a><h4 class="code-header">pub fn <a href="#method.as_utf8" class="fn">as_utf8</a>(&amp;self) -&gt; <a class="type" href="../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></div><h2 id="trait-implemen [...]
+</div></details><section id="method.as_utf8" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#185-191">source</a><h4 class="code-header">pub fn <a href="#method.as_utf8" class="fn">as_utf8</a>(&amp;self) -&gt; <a class="type" href="../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;&amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>&gt;</h4></section></div><h2 id="trait-implemen [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ParquetValueType-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#1007-1098">source</a><a href="#impl-ParquetValueType-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-h [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
@@ -28,16 +28,16 @@ level logical types, removing the data-hazard from all decoding and encoding pat
     decoder: &amp;mut PlainDecoderDetails
 ) -&gt; <a class="type" href="../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.html">usize</a>&gt;</h4></section></summary><div class='docblock'>Decode the value from a given buffer for a higher level decoder</div></details><section id="method.skip" class="method trait-impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#1062-1082">source</a><a href="#met [...]
 by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#226">source</a></span><a href="#method.ne-2" class="anchor">§</a><h4 class="code-header">fn <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialEq.html#method.ne [...]
-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%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#280-284">source</a><a href="#impl-PartialEq%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightl [...]
-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="srclink" 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" 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%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#268-272">source</a><a href="#impl-PartialEq%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust [...]
+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%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#280-284">source</a><a href="#impl-PartialEq%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightl [...]
 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="srclink" 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 [...]
-sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#304-308">source</a><a href="#impl-PartialOrd%3CByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nigh [...]
+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%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#268-272">source</a><a href="#impl-PartialEq%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust [...]
+by <code>==</code>.</div></details><details class="toggle method-toggle" open><summary><section id="method.ne" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" 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" 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-PartialOrd%3CByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#304-308">source</a><a href="#impl-PartialOrd%3CByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nigh [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt-2" class="anchor">§</a><h4 class="code-hea [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#298-302">source</a><a href="#impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="t [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt-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="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt-1" class="anchor">§</a><h4 class="code-hea [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#298-302">source</a><a href="#impl-PartialOrd%3CFixedLenByteArray%3E-for-ByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="t [...]
+operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#292-296">source</a><a href="#impl-PartialOrd%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header"> [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt" class="anchor">§</a><h4 class="code-header" [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-PartialOrd%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#292-296">source</a><a href="#impl-PartialOrd%3CFixedLenByteArray%3E-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header"> [...]
-operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.le">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.gt-2" class="method trait-impl"><span class="rightside"><span class="since" title="Stable since Rust version 1.0.0">1.0.0</span> · <a class="srclink" href="https://doc.rust-lang.org/nightly/src/core/cmp.rs.html#1100">source</a></span><a href="#method.gt-2" class="anchor">§</a><h4 class="code-hea [...]
 operator. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.PartialOrd.html#method.ge">Read more</a></div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-SliceAsBytes-for-FixedLenByteArray" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#532">source</a><a href="#impl-SliceAsBytes-for-FixedLenByteArray" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.SliceAsBytes [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
diff --git a/parquet/data_type/struct.Int96.html b/parquet/data_type/struct.Int96.html
index ff5ab589a..cad24c0c9 100644
--- a/parquet/data_type/struct.Int96.html
+++ b/parquet/data_type/struct.Int96.html
@@ -9,7 +9,7 @@ The type only takes 12 bytes, without extra padding.</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_nanos" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#67-72">source</a><h4 class="code-header">pub fn <a href="#method.to_nanos" class="fn">to_nanos</a>(&amp;self) -&gt; <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a></h4></section></summary><div class="docblock"><p>Converts this INT96 into an i64 representing the n [...]
 <p>Will wrap around on overflow</p>
 </div></details><details class="toggle method-toggle" open><summary><section id="method.to_seconds_and_nanos" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#75-83">source</a><h4 class="code-header">pub fn <a href="#method.to_seconds_and_nanos" class="fn">to_seconds_and_nanos</a>(&amp;self) -&gt; (<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i64.html">i64</a>, <a class="primitive" href="https://doc.rust-lang.org/nightly/ [...]
-</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-AsBytes-for-Int96" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#540-546">source</a><a href="#impl-AsBytes-for-Int96" class="anchor">§</a><h3 class="code-header">im [...]
+</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-AsBytes-for-Int96" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#540-546">source</a><a href="#impl-AsBytes-for-Int96" class="anchor">§</a><h3 class="code-header">im [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-ParquetValueType-for-Int96" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#815-912">source</a><a href="#impl-ParquetValueType-for-Int96" class="anchor">§</a><h3 class="code-header">impl <a class="trai [...]
     values: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a>,
     writer: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.reference.html">&amp;mut W</a>,
diff --git a/parquet/data_type/trait.AsBytes.html b/parquet/data_type/trait.AsBytes.html
index 1d01890f3..3af90d8b2 100644
--- a/parquet/data_type/trait.AsBytes.html
+++ b/parquet/data_type/trait.AsBytes.html
@@ -3,4 +3,4 @@
     fn <a href="#tymethod.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>;
 }</code></pre><details class="toggle top-doc" open><summary class="hideme"><span>Expand description</span></summary><div class="docblock"><p>Converts an instance of data type to a slice of bytes as <code>u8</code>.</p>
 </div></details><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><details class="toggle method-toggle" open><summary><section id="tymethod.as_bytes" class="method"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#444">source</a><h4 class="code-header">fn <a href="#tymethod.as_bytes" class="fn">as_bytes</a>(&amp;self) -&gt; &amp;[<a class="primitive" href="https://doc.rust [...]
-</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-AsBytes-for-Vec%3Cu8%3E" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#566-570">source</a><a href="#impl-AsBytes-for-Vec%3Cu8%3E" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.AsBytes.html" title [...]
\ No newline at end of file
+</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-AsBytes-for-u16" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#508">source</a><a href="#impl-AsBytes-for-u16" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.AsBytes.html" title="trait parquet::dat [...]
\ No newline at end of file
diff --git a/parquet/data_type/trait.SliceAsBytes.html b/parquet/data_type/trait.SliceAsBytes.html
index df4a8dadc..cae1a1463 100644
--- a/parquet/data_type/trait.SliceAsBytes.html
+++ b/parquet/data_type/trait.SliceAsBytes.html
@@ -8,4 +8,4 @@
 <h5 id="safety"><a href="#safety">Safety</a></h5>
 <p>If modified you are <em>required</em> to ensure the internal representation
 is valid and correct for the actual raw data</p>
-</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-SliceAsBytes-for-u64" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#510">source</a><a href="#impl-SliceAsBytes-for-u64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.SliceAsBytes.html" title="tra [...]
\ No newline at end of file
+</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-SliceAsBytes-for-u32" class="impl"><a class="srclink rightside" href="../../src/parquet/data_type.rs.html#509">source</a><a href="#impl-SliceAsBytes-for-u32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.SliceAsBytes.html" title="tra [...]
\ No newline at end of file
diff --git a/parquet/errors/enum.ParquetError.html b/parquet/errors/enum.ParquetError.html
index 2e2cb1311..7055d6212 100644
--- a/parquet/errors/enum.ParquetError.html
+++ b/parquet/errors/enum.ParquetError.html
@@ -16,7 +16,7 @@ decode.</p>
 </div><section id="variant.ArrowError" class="variant"><a href="#variant.ArrowError" class="anchor">§</a><h3 class="code-header">ArrowError(<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>)</h3></section><div class="docblock"><p>Arrow error.
 Returned when reading into arrow or writing from arrow.</p>
 </div><section id="variant.IndexOutOfBound" class="variant"><a href="#variant.IndexOutOfBound" class="anchor">§</a><h3 class="code-header">IndexOutOfBound(<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>)</h3></section><section id="variant.External" class="variant"><a href="#variant.External" class="anchor">§</a><h3 class="code-header">External [...]
-</div></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-ParquetError" class="impl"><a class="srclink rightside" href="../../src/parquet/errors.rs.html#29">source</a><a href="#impl-Debug-for-ParquetError" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href [...]
+</div></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-ParquetError" class="impl"><a class="srclink rightside" href="../../src/parquet/errors.rs.html#29">source</a><a href="#impl-Debug-for-ParquetError" 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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/error/trait.Error.html" title="trait core::error::Error">Error</a> + 'static,</span></h3></section></summary><div class="impl-items"><details class="toggle method-toggle" open><summary><section id="method.as_error_source" class="method trait-impl"><a href="#method.as_error_source" class="anchor">§</a><h4 class="code-header">fn <a class="fn">as_error_source</a>(&amp;self) -&gt; &amp;(dyn <a class="trait" href="https://do [...]
 to benefit from Rust’s automatic dereferencing of method
diff --git a/parquet/file/reader/trait.ChunkReader.html b/parquet/file/reader/trait.ChunkReader.html
index af2c272c4..a4f9d2c8e 100644
--- a/parquet/file/reader/trait.ChunkReader.html
+++ b/parquet/file/reader/trait.ChunkReader.html
@@ -13,4 +13,4 @@ side-effect on previously returned <a href="trait.ChunkReader.html#associatedtyp
 </div></details><details class="toggle method-toggle" open><summary><section id="tymethod.get_bytes" class="method"><a class="srclink rightside" href="../../../src/parquet/file/reader.rs.html#67">source</a><h4 class="code-header">fn <a href="#tymethod.get_bytes" class="fn">get_bytes</a>(&amp;self, start: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.u64.html">u64</a>, length: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.usize.htm [...]
 <p>Concurrent calls to <a href="trait.ChunkReader.html#tymethod.get_bytes"><code>Self::get_bytes</code></a> may result in interleaved output</p>
 <p>See <a href="https://doc.rust-lang.org/nightly/std/fs/struct.File.html#method.try_clone" title="method std::fs::File::try_clone"><code>File::try_clone</code></a> for more information</p>
-</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-ChunkReader-for-Bytes" class="impl"><a class="srclink rightside" href="../../../src/parquet/file/reader.rs.html#108-120">source</a><a href="#impl-ChunkReader-for-Bytes" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ChunkReader.html"  [...]
\ No newline at end of file
+</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-ChunkReader-for-File" class="impl"><a class="srclink rightside" href="../../../src/parquet/file/reader.rs.html#76-100">source</a><a href="#impl-ChunkReader-for-File" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.ChunkReader.html" tit [...]
\ No newline at end of file
diff --git a/parquet/file/serialized_reader/struct.SerializedFileReader.html b/parquet/file/serialized_reader/struct.SerializedFileReader.html
index cb737ef83..04a8f0863 100644
--- a/parquet/file/serialized_reader/struct.SerializedFileReader.html
+++ b/parquet/file/serialized_reader/struct.SerializedFileReader.html
@@ -9,7 +9,7 @@ Returns error if Parquet file does not exist or is corrupt.</p>
 Returns error if Parquet file does not exist or is corrupt.</p>
 </div></details><section id="method.metadata_ref" class="method"><a class="srclink rightside" href="../../../src/parquet/file/serialized_reader.rs.html#247-249">source</a><h4 class="code-header">pub(crate) fn <a href="#method.metadata_ref" class="fn">metadata_ref</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;<a class="struct" href="../metadata/struct.ParquetMetaData.html" title="s [...]
 using the full file schema over all row groups.</p>
-</div><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" class="associatedtype">Item</a> = <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a [...]
+</div><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" class="associatedtype">Item</a> = <a class="enum" href="https://doc.rust-lang.org/nightly/core/result/enum.Result.html" title="enum core::result::Result">Result</a [...]
     R: <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-SerializedFileReader%3CR%3E" class="impl"><a href="#impl-Send-for-SerializedFileReader%3CR%3E" class="anchor">§</a><h3 class="code-header">impl&lt;R&gt; <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Send.html" title="trait core:: [...]
     R: <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></div><h2 id="blanket-implementations" class="small-section-header">Blanket Implementations<a href="#blanket-implementations" class="anchor">§</a></h2><div id="blanket-implementations-list"><details class="toggle implementors-toggle"><summary><section id="impl-Any-for-SerializedFileRe [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/file/statistics/private/trait.MakeStatistics.html b/parquet/file/statistics/private/trait.MakeStatistics.html
index 63fe9b911..e0c4ba62c 100644
--- a/parquet/file/statistics/private/trait.MakeStatistics.html
+++ b/parquet/file/statistics/private/trait.MakeStatistics.html
@@ -3,9 +3,9 @@
     fn <a href="#tymethod.make_statistics" class="fn">make_statistics</a>(statistics: <a class="struct" href="../struct.ValueStatistics.html" title="struct parquet::file::statistics::ValueStatistics">ValueStatistics</a>&lt;Self&gt;) -&gt; <a class="enum" href="../enum.Statistics.html" title="enum parquet::file::statistics::Statistics">Statistics</a>
        <span class="where">where Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a></span>;
 }</code></pre><h2 id="required-methods" class="small-section-header">Required Methods<a href="#required-methods" class="anchor">§</a></h2><div class="methods"><section id="tymethod.make_statistics" class="method"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#53-55">source</a><h4 class="code-header">fn <a href="#tymethod.make_statistics" class="fn">make_statistics</a>(statistics: <a class="struct" href="../struct.ValueStatistics.html" title="struct par [...]
-    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></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-MakeStatistics-for-f32" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.htm [...]
-    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-MakeStatistics-for-bool" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#71">source</a><a href="#impl-MakeStatistics-for-bool" class="anchor">§</a><h3 class="code-header">impl <a class="trait" h [...]
+    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></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-MakeStatistics-for-bool" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.ht [...]
+    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-MakeStatistics-for-i32" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#72">source</a><a href="#impl-MakeStatistics-for-i32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-MakeStatistics-for-f64" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#76">source</a><a href="#impl-MakeStatistics-for-f64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-MakeStatistics-for-i64" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#73">source</a><a href="#impl-MakeStatistics-for-i64" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
-    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-MakeStatistics-for-i32" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#72">source</a><a href="#impl-MakeStatistics-for-i32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
+    Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><details class="toggle implementors-toggle"><summary><section id="impl-MakeStatistics-for-f32" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#75">source</a><a href="#impl-MakeStatistics-for-f32" class="anchor">§</a><h3 class="code-header">impl <a class="trait" hre [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></div></details><h2 id="implementors" class="small-section-header">Implementors<a href="#implementors" class="anchor">§</a></h2><div id="implementors-list"><section id="impl-MakeStatistics-for-ByteArray" class="impl"><a class="srclink rightside" href="../../../../src/parquet/file/statistics.rs.html#77">source</a><a href="#impl- [...]
\ No newline at end of file
diff --git a/parquet/file/statistics/struct.ValueStatistics.html b/parquet/file/statistics/struct.ValueStatistics.html
index e834bca6e..536e81042 100644
--- a/parquet/file/statistics/struct.ValueStatistics.html
+++ b/parquet/file/statistics/struct.ValueStatistics.html
@@ -49,7 +49,7 @@ which have a type-defined sort order.</p>
 <p>However, not all readers have been updated. For backwards compatibility, this method
 returns <code>true</code> if the statistics within this have a signed sort order, that is
 compatible with being stored in the deprecated <code>min</code> and <code>max</code> fields</p>
-</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-ValueStatistics%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/parquet/file/statistics.rs.html#417">source</a><a href="#impl-Clone-for-ValueStatistics%3CT%3E" class="anch [...]
+</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-ValueStatistics%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/parquet/file/statistics.rs.html#417">source</a><a href="#impl-Clone-for-ValueStatistics%3CT%3E" class="anch [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-Eq-for-ValueStatistics%3CT%3E" class="impl"><a class="srclink rightside" href="../../../src/parquet/file/statistics.rs.html#417">source</a><a href="#impl-Eq-for-ValueStatistics%3CT%3E" class="anchor">§</a><h3 class="code-header">impl&lt;T: <a class="trait" href="https://doc.rust-lang.org/nightly/core/cmp/trait.Eq.html" title="trait core::cmp::Eq">Eq</a>&gt; <a class="trait" [...]
     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-ValueStatistics%3CT%3E" class="impl"><a href="#impl-Send-for-ValueStatistics%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::Se [...]
diff --git a/parquet/format/enum.LogicalType.html b/parquet/format/enum.LogicalType.html
index 9d190b60a..3f65b5882 100644
--- a/parquet/format/enum.LogicalType.html
+++ b/parquet/format/enum.LogicalType.html
@@ -12,7 +12,7 @@
     JSON(<a class="struct" href="struct.JsonType.html" title="struct parquet::format::JsonType">JsonType</a>),
     BSON(<a class="struct" href="struct.BsonType.html" title="struct parquet::format::BsonType">BsonType</a>),
     UUID(<a class="struct" href="struct.UUIDType.html" title="struct parquet::format::UUIDType">UUIDType</a>),
-</details>}</code></pre><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.STRING" class="variant"><a href="#variant.STRING" class="anchor">§</a><h3 class="code-header">STRING(<a class="struct" href="struct.StringType.html" title="struct parquet::format::StringType">StringType</a>)</h3></section><section id="variant.MAP" class="variant"><a href="#variant.MAP" class="anchor">§</a><h3 class [...]
+</details>}</code></pre><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.STRING" class="variant"><a href="#variant.STRING" class="anchor">§</a><h3 class="code-header">STRING(<a class="struct" href="struct.StringType.html" title="struct parquet::format::StringType">StringType</a>)</h3></section><section id="variant.MAP" class="variant"><a href="#variant.MAP" class="anchor">§</a><h3 class [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/format/struct.BoundaryOrder.html b/parquet/format/struct.BoundaryOrder.html
index 20f50844c..b62718dc8 100644
--- a/parquet/format/struct.BoundaryOrder.html
+++ b/parquet/format/struct.BoundaryOrder.html
@@ -1,6 +1,6 @@
 <!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="Enum to annotate whether lists of min/max elements inside ColumnIndex are ordered and if so, in which direction."><title>BoundaryOrder in parquet::format - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac52 [...]
 are ordered and if so, in which direction.</p>
-</div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
+</div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/format/struct.CompressionCodec.html b/parquet/format/struct.CompressionCodec.html
index 2b2b5e464..533e35068 100644
--- a/parquet/format/struct.CompressionCodec.html
+++ b/parquet/format/struct.CompressionCodec.html
@@ -3,7 +3,7 @@
 Codec support may vary between readers based on the format version and
 libraries available at runtime.</p>
 <p>See Compression.md for a detailed specification of these algorithms.</p>
-</div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
+</div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/format/struct.Encoding.html b/parquet/format/struct.Encoding.html
index ecdb1f349..16a633907 100644
--- a/parquet/format/struct.Encoding.html
+++ b/parquet/format/struct.Encoding.html
@@ -30,7 +30,7 @@ The individual bytes of an FP value are scattered to the corresponding stream an
 the streams are concatenated.
 This itself does not reduce the size of the data but can lead to better compression
 afterwards.</p>
-</div></details><section id="associatedconstant.ENUM_VALUES" class="associatedconstant"><a class="srclink rightside" href="../../src/parquet/format.rs.html#386-396">source</a><h4 class="code-header">pub const <a href="#associatedconstant.ENUM_VALUES" class="constant">ENUM_VALUES</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a> = _</h4></section></div></details></div><h2 id="trait-implementations" class="small-section-head [...]
+</div></details><section id="associatedconstant.ENUM_VALUES" class="associatedconstant"><a class="srclink rightside" href="../../src/parquet/format.rs.html#386-396">source</a><h4 class="code-header">pub const <a href="#associatedconstant.ENUM_VALUES" class="constant">ENUM_VALUES</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a> = _</h4></section></div></details></div><h2 id="trait-implementations" class="small-section-head [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/format/struct.FieldRepetitionType.html b/parquet/format/struct.FieldRepetitionType.html
index 2bf3c061d..3399285c4 100644
--- a/parquet/format/struct.FieldRepetitionType.html
+++ b/parquet/format/struct.FieldRepetitionType.html
@@ -2,7 +2,7 @@
 </div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
 </div></details><details class="toggle" open><summary><section id="associatedconstant.OPTIONAL" class="associatedconstant"><a class="srclink rightside" href="../../src/parquet/format.rs.html#291">source</a><h4 class="code-header">pub const <a href="#associatedconstant.OPTIONAL" class="constant">OPTIONAL</a>: <a class="struct" href="struct.FieldRepetitionType.html" title="struct parquet::format::FieldRepetitionType">FieldRepetitionType</a> = _</h4></section></summary><div class="docblock" [...]
 </div></details><details class="toggle" open><summary><section id="associatedconstant.REPEATED" class="associatedconstant"><a class="srclink rightside" href="../../src/parquet/format.rs.html#293">source</a><h4 class="code-header">pub const <a href="#associatedconstant.REPEATED" class="constant">REPEATED</a>: <a class="struct" href="struct.FieldRepetitionType.html" title="struct parquet::format::FieldRepetitionType">FieldRepetitionType</a> = _</h4></section></summary><div class="docblock" [...]
-</div></details><section id="associatedconstant.ENUM_VALUES" class="associatedconstant"><a class="srclink rightside" href="../../src/parquet/format.rs.html#294-298">source</a><h4 class="code-header">pub const <a href="#associatedconstant.ENUM_VALUES" class="constant">ENUM_VALUES</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a> = _</h4></section></div></details></div><h2 id="trait-implementations" class="small-section-head [...]
+</div></details><section id="associatedconstant.ENUM_VALUES" class="associatedconstant"><a class="srclink rightside" href="../../src/parquet/format.rs.html#294-298">source</a><h4 class="code-header">pub const <a href="#associatedconstant.ENUM_VALUES" class="constant">ENUM_VALUES</a>: &amp;'static <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.slice.html">[Self]</a> = _</h4></section></div></details></div><h2 id="trait-implementations" class="small-section-head [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/format/struct.PageType.html b/parquet/format/struct.PageType.html
index 4c15c8894..e6035028b 100644
--- a/parquet/format/struct.PageType.html
+++ b/parquet/format/struct.PageType.html
@@ -1,4 +1,4 @@
-<!DOCTYPE html><html lang="en"><head><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 `PageType` struct in crate `parquet`."><title>PageType in parquet::format - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
+<!DOCTYPE html><html lang="en"><head><meta charset="utf-8"><meta name="viewport" content="width=device-width, initial-scale=1.0"><meta name="generator" content="rustdoc"><meta name="description" content="API documentation for the Rust `PageType` struct in crate `parquet`."><title>PageType in parquet::format - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type= [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/format/struct.Type.html b/parquet/format/struct.Type.html
index 04e51f29c..4a720588c 100644
--- a/parquet/format/struct.Type.html
+++ b/parquet/format/struct.Type.html
@@ -2,7 +2,7 @@
 with the encodings to control the on disk storage format.
 For example INT16 is not included as a type since a good encoding of INT32
 would handle this.</p>
-</div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
+</div></details><h2 id="fields" class="fields small-section-header">Tuple Fields<a href="#fields" class="anchor">§</a></h2><span id="structfield.0" class="structfield small-section-header"><a href="#structfield.0" class="anchor field">§</a><code>0: <a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.i32.html">i32</a></code></span><h2 id="implementations" class="small-section-header">Implementations<a href="#implementations" class="anchor">§</a></h2><div id="impleme [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Compares and returns the maximum of two values. <a href="https://doc.rust-lang.org/nightly/core/cmp/trait.Ord.html#method.max">Read more</a></div></details><details class="toggle method-toggle" open><summary><section id="method.min" class="method trait-impl"><span class="rightside"><span class="s [...]
diff --git a/parquet/index.html b/parquet/index.html
index 64780e076..58fe2fcb3 100644
--- a/parquet/index.html
+++ b/parquet/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="This crate contains the official Native Rust implementation of Apache Parquet, part of the Apache Arrow project."><title>parquet - 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="This crate contains the official Native Rust implementation of Apache Parquet, part of the Apache Arrow project."><title>parquet - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="pre [...]
 <a href="https://parquet.apache.org/">Apache Parquet</a>, part of
 the <a href="https://arrow.apache.org/">Apache Arrow</a> project.</p>
 <p>Please see the <a href="https://crates.io/crates/parquet">parquet crates.io</a>
diff --git a/parquet/record/api/enum.Field.html b/parquet/record/api/enum.Field.html
index d4af133e0..61527ab38 100644
--- a/parquet/record/api/enum.Field.html
+++ b/parquet/record/api/enum.Field.html
@@ -53,7 +53,7 @@ Unix epoch, 1 January 1970.</p>
     value: <a class="struct" href="../../data_type/struct.ByteArray.html" title="struct parquet::data_type::ByteArray">ByteArray</a>
 ) -&gt; <a class="type" href="../../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;Self&gt;</h4></section></summary><div class="docblock"><p>Converts Parquet BYTE_ARRAY type with converted type into either UTF8 string or
 array of bytes.</p>
-</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#678-727">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-secti [...]
+</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#678-727">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-secti [...]
 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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-StructuralPartialEq-for-Field" class="impl"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#490">source</a><a href="#impl-StructuralPartialEq-for-Field" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html" title="trait core::marker::StructuralPartialEq [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/record/api/struct.Row.html b/parquet/record/api/struct.Row.html
index 0f42c9d05..c272c8b59 100644
--- a/parquet/record/api/struct.Row.html
+++ b/parquet/record/api/struct.Row.html
@@ -14,9 +14,9 @@
 <span class="kw">for </span>(idx, (name, field)) <span class="kw">in </span>row.get_column_iter().enumerate() {
     <span class="macro">println!</span>(<span class="string">&quot;column index: {}, column name: {}, column value: {}&quot;</span>, idx, name, field);
 }</code></pre></div>
-</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#83-90">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-section [...]
+</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#83-90">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-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="srclink" 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" 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-RowAccessor-for-Row" class="impl"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#199-237">source</a><a href="#impl-RowAccessor-for-Row" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.RowAccessor.html" title="trait parquet::record::api::RowAccessor">RowAccesso [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-RowAccessor-for-Row" class="impl"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#199-237">source</a><a href="#impl-RowAccessor-for-Row" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="trait.RowAccessor.html" title="trait parquet::record::api::RowAccessor">RowAccesso [...]
 </div></details></div></details><section id="impl-StructuralPartialEq-for-Row" class="impl"><a class="srclink rightside" href="../../../src/parquet/record/api.rs.html#46">source</a><a href="#impl-StructuralPartialEq-for-Row" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html" title="trait core::marker::StructuralPartialEq">StructuralPartialEq</a> for <a class="struct" href="struct.Row.html"  [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
diff --git a/parquet/record/enum.Field.html b/parquet/record/enum.Field.html
index 222e4d669..bab0b1b4e 100644
--- a/parquet/record/enum.Field.html
+++ b/parquet/record/enum.Field.html
@@ -53,7 +53,7 @@ Unix epoch, 1 January 1970.</p>
     value: <a class="struct" href="../data_type/struct.ByteArray.html" title="struct parquet::data_type::ByteArray">ByteArray</a>
 ) -&gt; <a class="type" href="../errors/type.Result.html" title="type parquet::errors::Result">Result</a>&lt;Self&gt;</h4></section></summary><div class="docblock"><p>Converts Parquet BYTE_ARRAY type with converted type into either UTF8 string or
 array of bytes.</p>
-</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#678-727">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-section- [...]
+</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#678-727">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-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="srclink" 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" cl [...]
 sufficient, and should not be overridden without very good reason.</div></details></div></details><section id="impl-StructuralPartialEq-for-Field" class="impl"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#490">source</a><a href="#impl-StructuralPartialEq-for-Field" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html" title="trait core::marker::StructuralPartialEq">S [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
diff --git a/parquet/record/struct.Row.html b/parquet/record/struct.Row.html
index 90cb436ce..110ac0770 100644
--- a/parquet/record/struct.Row.html
+++ b/parquet/record/struct.Row.html
@@ -14,9 +14,9 @@
 <span class="kw">for </span>(idx, (name, field)) <span class="kw">in </span>row.get_column_iter().enumerate() {
     <span class="macro">println!</span>(<span class="string">&quot;column index: {}, column name: {}, column value: {}&quot;</span>, idx, name, field);
 }</code></pre></div>
-</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#83-90">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-section-he [...]
+</div></details><section id="method.to_json_value" class="method"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#83-90">source</a><h4 class="code-header">pub fn <a href="#method.to_json_value" class="fn">to_json_value</a>(&amp;self) -&gt; <a class="enum" href="https://docs.rs/serde_json/1.0.99/serde_json/value/enum.Value.html" title="enum serde_json::value::Value">Value</a></h4></section></div></details></div><h2 id="trait-implementations" class="small-section-he [...]
 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="srclink" 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" 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-RowAccessor-for-Row" class="impl"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#199-237">source</a><a href="#impl-RowAccessor-for-Row" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="api/trait.RowAccessor.html" title="trait parquet::record::api::RowAccessor">RowAccess [...]
+sufficient, and should not be overridden without very good reason.</div></details></div></details><details class="toggle implementors-toggle" open><summary><section id="impl-RowAccessor-for-Row" class="impl"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#199-237">source</a><a href="#impl-RowAccessor-for-Row" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="api/trait.RowAccessor.html" title="trait parquet::record::api::RowAccessor">RowAccess [...]
 </div></details></div></details><section id="impl-StructuralPartialEq-for-Row" class="impl"><a class="srclink rightside" href="../../src/parquet/record/api.rs.html#46">source</a><a href="#impl-StructuralPartialEq-for-Row" class="anchor">§</a><h3 class="code-header">impl <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.StructuralPartialEq.html" title="trait core::marker::StructuralPartialEq">StructuralPartialEq</a> for <a class="struct" href="api/struct.Row.html" [...]
     T: 'static + ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
diff --git a/parquet/schema/types/struct.ColumnPath.html b/parquet/schema/types/struct.ColumnPath.html
index 6f9824151..60fcf9ab3 100644
--- a/parquet/schema/types/struct.ColumnPath.html
+++ b/parquet/schema/types/struct.ColumnPath.html
@@ -18,7 +18,7 @@
 
 path.append(<span class="macro">vec!</span>[<span class="string">&quot;d&quot;</span>.to_string(), <span class="string">&quot;e&quot;</span>.to_string()]);
 <span class="macro">assert_eq!</span>(<span class="kw-2">&amp;</span>path.string(), <span class="string">&quot;a.b.c.d.e&quot;</span>);</code></pre></div>
-</div></details><section id="method.parts" class="method"><a class="srclink rightside" href="../../../src/parquet/schema/types.rs.html#701-703">source</a><h4 class="code-header">pub fn <a href="#method.parts" class="fn">parts</a>(&amp;self) -&gt; &amp;[<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>]</h4></section></div></details></div><h2 id="trait-implementations" class="small-section-header">Tra [...]
+</div></details><section id="method.parts" class="method"><a class="srclink rightside" href="../../../src/parquet/schema/types.rs.html#701-703">source</a><h4 class="code-header">pub fn <a href="#method.parts" class="fn">parts</a>(&amp;self) -&gt; &amp;[<a class="struct" href="https://doc.rust-lang.org/nightly/alloc/string/struct.String.html" title="struct alloc::string::String">String</a>]</h4></section></div></details></div><h2 id="trait-implementations" class="small-section-header">Tra [...]
     H: <a class="trait" href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher">Hasher</a>,
     Self: <a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</span></h4></section></summary><div class='docblock'>Feeds a slice of this type into the given <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hasher.html" title="trait core::hash::Hasher"><code>Hasher</code></a>. <a href="https://doc.rust-lang.org/nightly/core/hash/trait.Hash.html#method.hash_slice">Read more</a></div></details></div></ [...]
 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="srclink" 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" cl [...]
diff --git a/parquet_concat/index.html b/parquet_concat/index.html
index 4595f7843..1da49d29f 100644
--- a/parquet_concat/index.html
+++ b/parquet_concat/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="Binary that concatenates the column data of one or more parquet files"><title>parquet_concat - Rust</title><link 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="Binary that concatenates the column data of one or more parquet files"><title>parquet_concat - Rust</title><link 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 [...]
 <h2 id="install"><a href="#install">Install</a></h2>
 <p><code>parquet-concat</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_derive/index.html b/parquet_derive/index.html
index 0500513c1..e864eb1b4 100644
--- a/parquet_derive/index.html
+++ b/parquet_derive/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="API documentation for the Rust `parquet_derive` crate."><title>parquet_derive - Rust</title><link rel="preload" 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="API documentation for the Rust `parquet_derive` crate."><title>parquet_derive - Rust</title><link rel="preload" as="font" type="font/woff2" crossorigin href="../static.files/SourceSerif4-Regular-46f98efaafac5295.ttf.woff2"><link rel="preload" as="font" type="font/woff2" crossorigin href= [...]
 a struct tagged with <code>#[derive(ParquetRecordWriter)]</code> and emitting
 the correct writing code for each field of the struct. Column writers
 are generated in the order they are defined.</div></li></ul></section></div></main></body></html>
\ No newline at end of file
diff --git a/parquet_derive_test/index.html b/parquet_derive_test/index.html
index 685d1622d..0e15ba5d7 100644
--- a/parquet_derive_test/index.html
+++ b/parquet_derive_test/index.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 `parquet_derive_test` crate."><title>parquet_derive_test - Rust</title><link 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 [...]
\ 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 `parquet_derive_test` crate."><title>parquet_derive_test - Rust</title><link 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 [...]
\ No newline at end of file
diff --git a/parquet_fromcsv/enum.ParquetFromCsvError.html b/parquet_fromcsv/enum.ParquetFromCsvError.html
index d2939ad97..3b42e97b9 100644
--- a/parquet_fromcsv/enum.ParquetFromCsvError.html
+++ b/parquet_fromcsv/enum.ParquetFromCsvError.html
@@ -7,7 +7,7 @@
 }</code></pre><h2 id="variants" class="variants small-section-header">Variants<a href="#variants" class="anchor">§</a></h2><div class="variants"><section id="variant.CommandLineParseError" class="variant"><a href="#variant.CommandLineParseError" class="anchor">§</a><h3 class="code-header">CommandLineParseError(Error)</h3></section><section id="variant.IoError" class="variant"><a href="#variant.IoError" class="anchor">§</a><h3 class="code-header">IoError(<a class="struct" href="https://do [...]
     inner_error: E,
     context: &amp;<a class="primitive" href="https://doc.rust-lang.org/nightly/std/primitive.str.html">str</a>
-) -&gt; <a class="enum" href="enum.ParquetFromCsvError.html" title="enum parquet_fromcsv::ParquetFromCsvError">ParquetFromCsvError</a></h4></section></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-Debug-for-ParquetFromCsvError" class="impl"><a class="srclink rightsi [...]
+) -&gt; <a class="enum" href="enum.ParquetFromCsvError.html" title="enum parquet_fromcsv::ParquetFromCsvError">ParquetFromCsvError</a></h4></section></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-Debug-for-ParquetFromCsvError" class="impl"><a class="srclink rightsi [...]
     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="srclink rightside" href="https://doc.rust-lang.org/nightly/src/core/any.rs.html#202">source</a><a href="#method.type_id" class="anchor">§</a><h4 class="code-header">fn <a [...]
     T: ?<a class="trait" href="https://doc.rust-lang.org/nightly/core/marker/trait.Sized.html" title="trait core::marker::Sized">Sized</a>,</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="srclink 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="ht [...]
     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="srclink 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  [...]
diff --git a/parquet_fromcsv/index.html b/parquet_fromcsv/index.html
index b1a46a80f..701524c0a 100644
--- a/parquet_fromcsv/index.html
+++ b/parquet_fromcsv/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="Binary file to converts csv to Parquet file"><title>parquet_fromcsv - Rust</title><link rel="preload" 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="Binary file to converts csv to Parquet file"><title>parquet_fromcsv - Rust</title><link rel="preload" 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="install"><a href="#install">Install</a></h2>
 <p><code>parquet-fromcsv</code> can be installed using <code>cargo</code>:</p>
 <div class="example-wrap"><pre class="language-text"><code>cargo install parquet --features=cli
diff --git a/parquet_index/index.html b/parquet_index/index.html
index 4427523c7..96932287e 100644
--- a/parquet_index/index.html
+++ b/parquet_index/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="Binary that prints the [page index] of a parquet file"><title>parquet_index - Rust</title><link rel="preload" 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="Binary that prints the [page index] of a parquet file"><title>parquet_index - Rust</title><link rel="preload" 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="install"><a href="#install">Install</a></h2>
 <p><code>parquet-layout</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_layout/index.html b/parquet_layout/index.html
index fe28d9b1c..406378722 100644
--- a/parquet_layout/index.html
+++ b/parquet_layout/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="Binary that prints the physical layout of a parquet file"><title>parquet_layout - Rust</title><link rel="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="Binary that prints the physical layout of a parquet file"><title>parquet_layout - Rust</title><link rel="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 [...]
 <h2 id="install"><a href="#install">Install</a></h2>
 <p><code>parquet-layout</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_read/index.html b/parquet_read/index.html
index 46c136be9..0c529c922 100644
--- a/parquet_read/index.html
+++ b/parquet_read/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="Binary file to read data from a Parquet file."><title>parquet_read - Rust</title><link rel="preload" 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="Binary file to read data from a Parquet file."><title>parquet_read - Rust</title><link rel="preload" 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="install"><a href="#install">Install</a></h2>
 <p><code>parquet-read</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_rewrite/index.html b/parquet_rewrite/index.html
index a7d364019..dacbf060a 100644
--- a/parquet_rewrite/index.html
+++ b/parquet_rewrite/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="Binary file to rewrite parquet files."><title>parquet_rewrite - Rust</title><link rel="preload" 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="Binary file to rewrite parquet files."><title>parquet_rewrite - Rust</title><link rel="preload" 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 [...]
 <h2 id="install"><a href="#install">Install</a></h2>
 <p><code>parquet-rewrite</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_rowcount/index.html b/parquet_rowcount/index.html
index 7338b4698..689a4505d 100644
--- a/parquet_rowcount/index.html
+++ b/parquet_rowcount/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="Binary file to return the number of rows found from Parquet file(s)."><title>parquet_rowcount - Rust</title><link 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="Binary file to return the number of rows found from Parquet file(s)."><title>parquet_rowcount - Rust</title><link 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="install"><a href="#install">Install</a></h2>
 <p><code>parquet-rowcount</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_schema/index.html b/parquet_schema/index.html
index f0780947d..e29293475 100644
--- a/parquet_schema/index.html
+++ b/parquet_schema/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="Binary file to print the schema and metadata of a Parquet file."><title>parquet_schema - Rust</title><link 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="Binary file to print the schema and metadata of a Parquet file."><title>parquet_schema - Rust</title><link 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 [...]
 <h2 id="install"><a href="#install">Install</a></h2>
 <p><code>parquet-schema</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/parquet_show_bloom_filter/index.html b/parquet_show_bloom_filter/index.html
index e836fa27f..c9c99abba 100644
--- a/parquet_show_bloom_filter/index.html
+++ b/parquet_show_bloom_filter/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="Binary file to read bloom filter data from a Parquet file."><title>parquet_show_bloom_filter - Rust</title><link 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="Binary file to read bloom filter data from a Parquet file."><title>parquet_show_bloom_filter - Rust</title><link 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 [...]
 <h2 id="install"><a href="#install">Install</a></h2>
 <p><code>parquet-show-bloom-filter</code> can be installed using <code>cargo</code>:</p>
 
diff --git a/search-index.js b/search-index.js
index e9b26300c..ff2f7e542 100644
--- a/search-index.js
+++ b/search-index.js
@@ -1,21 +1,21 @@
 var searchIndex = JSON.parse('{\
-"arrow":{"doc":"A complete, safe, native Rust implementation of Apache …","t":"AAAACAOOAAACCAACAAARININIIDDGDGIINGGGGNDDDGDEESSSDGGGGGGGGGGGGNDGGGGGGGGGGGGGDDGDDGNGGGGGGGGGGGGDDDDDGDGGGSGGGGGGGGGGGGGGGGGGGGGGGGGGGGQGGGGGGGGGGNGGDGDDDQDDDISDDDGDDGGGGNDDGGGGGGGGGGGGGGGGGGGGGGGGDDGGGGGGGGGGGGGGGGDDNMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMMKKLLLLLLLLLLLLLLLLLLLLLLLLLLLKLLLLLLLLLLLLLLLLFKLLKLFLFKLLFKLFFFFLFKLLFKLFLFKLFLLLLLFLLFKLFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLL [...]
+"arrow":{"doc":"A complete, safe, native Rust implementation of Apache …","t":"AAAACAOOAAACCAACAAARININIIDDGDGIINGGGGNDDDGDEESSSDGGGGGGGGGGGGNDGGGGGGGGGGGGGDDGDDGNGGGGGGGGGGGGDDDDDGDGGGSGGGGGGGGGGGGGGGGGGGGGGGGGGGGQGGGGGGGGGGNGGDGDDDQDDDISDDDGDDGGGGNDDGGGGGGGGGGGGGGGGGGGGGGGGDDGGGGGGGGGGGGGGGGDDNMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMMKKLLLLLLLLLLLLLLLLLLLLLLLLLLLKLLLLLLLLLLLLLLLLFKLLKLFLFKLLFKLFFFFLFKLLFKLFLFKLFLLLLLFLLFKLFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLL [...]
 "arrow_arith":{"doc":"Arrow arithmetic and aggregation kernels","t":"AAAAAAFOFFFFFFFFFFFFFFFFFAFFFFDDQQIDKLLLKLLLKLLLLLLLLLLLLLLLLLLKLLLKLLLLLLMMMKLLLFLLLLLLLLLFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFIFFFFFFFFFFFFFFFFFFFFKFFKFFKKFOFFFFFFFFF","n":["aggregate","arithmetic","arity","bitwise","boolean","temporal","bit_and","bit_operation","bit_or","bit_xor","bool_and","bool_or","is_nan","max","max_array","max_binary","max_boolean","max_string" [...]
-"arrow_array":{"doc":"The central type in Apache Arrow are arrays, which are a …","t":"IISDDDIIQQSKKAAKAAKMKAKKOOOOOOOOKKKKMMKKAKKKKKKKKKKKMKKKKKKKAKKAMMAKMKKAAAAKKKISSKKKKKKLLLLLLLLLLKKKKKOOKKKKKKIIGCGDGGGGDGGGGDDGGGGDDGSGGGGGGGGGGGGGGQGGGGDDDISDDGDGGGGGGGGDDGGGGGGGGDKLLLLLLLLLLLLLLLLLAAAKLMMMMMMMMMMMAMLLMMAAKLKLFKLKLLLMLLMKLMMMMAFAMFFALLKLMMMMMMMMKLMAFAMMKLAAKLMAKMMMMMMMKMMMMMMMMGGGLLLLLLLLLLLLDLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLMSDLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLL [...]
-"arrow_buffer":{"doc":"Low-level buffer abstractions for Apache Arrow Rust","t":"IIAKAAAAAAAAKMDMAKKKKARINENALLLLLLLLRENNSSSSDSLLLLLLLLLLLLLLLLLLLLLLLLLOOLLLLLLLLLLLLLLLLLLLLLLLLLLMDLLLLLMLFLFLLLLLLFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLDDDGMMMMMMMMMMMMMDDDMMMMMMMMMMFFFFFFFFFFFDDDDDDDFFFAMMMFFFFMMAMMMMMAAMAMMAMMAMADLLLLLLMLLLLLLLLLLLLLLLLLLLLMLLLLLMLLLLLLLLLLLLDLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLMMLLLLLLLLDDLLLLLLLLLLLFMLLLLLLLLLLLLLLLLLLLLLLLMLMMMLLLLLLLLLLLLLLLLLLLLLLLDLLLMLLLLLLLLLLLLLLLLLLL [...]
-"arrow_cast":{"doc":"Cast kernel for Apache Arrow","t":"AAAADIFFFLLFFLFFFFFFFFFFFFFFFFFFFFOFFFFFFFFFFFFFFFFFFFFLLFFLFLLLLMLLKLLFFFFFFMFFFKKLLLFLFFDDNIIGNEDGQGDMFFLLLLLLLLLLLLLLLLLFMMOLOLLLLLMMLLLLLLLLLLLLLMLLLLLFFMMKOMMMOMOMMLLLLLLLLLLLLLLLLLLLLLLLLLLLKKLLFFNNNRRNRDDDENNNNGRRRRNINDNNLLLLLLLLLLLLLLLLLLLLLMLMMLLLLMLLLLLLLLLLLLMLLLLLMMMLLLKLFLFFFFFOFFFFLLLLLLFLLLLLLLLLLLLLLLLFFFFFFFF","n":["cast","display","parse","pretty","CastOptions","DecimalCast","adjust_timestamp_to_timezone","as_time_ [...]
+"arrow_array":{"doc":"The central type in Apache Arrow are arrays, which are a …","t":"IISDDDIIQQSKKAAKAAKMKAKKOOOOOOOOKKKKMMKKAKKKKKKKKKKKMKKKKKKKAKKAMMAKMKKAAAAKKKISSKKKKKKLLLLLLLLLLKKKKKOOKKKKKKIIGCGDGGGGDGGGGDDGGGGDDGSGGGGGGGGGGGGGGQGGGGDDDISDDGDGGGGGGGGDDGGGGGGGGDKLLLLLLLLLLLLLLLLLAAAKLMMMMMMMMMMMAMLLMMAAKLKLFKLKLLLMLLMKLMMMMAFAMFFALLKLMMMMMMMMKLMAFAMMKLAAKLMAKMMMMMMMKMMMMMMMMGGGLLLLLLLLLLLLDLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLMSDLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLL [...]
+"arrow_buffer":{"doc":"Low-level buffer abstractions for Apache Arrow Rust","t":"IIAKAAAAAAAAKMDMAKKKKARINENALLLLLLLLRENNSSSSDSLLLLLLLLLLLLLLLLLLLLLLLLLOOLLLLLLLLLLLLLLLLLLLLLLLLLLMDLLLLLMLFLFLLLLLLFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLDDDGMMMMMMMMMMMMMDDDMMMMMMMMMMFFFFFFFFFFFDDDDDDDFFFAMMMFFFFMMAMMMMMAAMAMMAMMAMADLLLLLLMLLLLLLLLLLLLLLLLLLLLMLLLLLMLLLLLLLLLLLLDLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLMMLLLLLLLLDDLLLLLLLLLLLFMLLLLLLLLLLLLLLLLLLLLLLLMLMMMLLLLLLLLLLLLLLLLLLLLLLLDLLLMLLLLLLLLLLLLLLLLLLL [...]
+"arrow_cast":{"doc":"Cast kernel for Apache Arrow","t":"AAAADIFFFLLFFLFFFFFFFFFFFFFFFFFFFFOFFFFFFFFFFFFFFFFFFFFLLFFLFLLLLMLLKLLFFFFFFMFFFKKLLLFLFFDDNIIGNEDGQGDMFFLLLLLLLLLLLLLLLLLFMMOLOLLLLLMMLLLLLLLLLLLLLMLLLLLFFMMKOMMMOMOMMLLLLLLLLLLLLLLLLLLLLLLLLLLLKKLLFFNNNRRNRDDDENNNNGRRRRNINDNNLLLLLLLLLLLLLLLLLLLLLMLMMLLLLMLLLLLLLLLLLLMLLLLLMMMLLLKLFLFFFFFOFFFFLLLLLLFLLLLLLLLLLLLLLLLFFFFFFFF","n":["cast","display","parse","pretty","CastOptions","DecimalCast","adjust_timestamp_to_timezone","as_time_ [...]
 "arrow_csv":{"doc":"Transfer data between the Arrow memory format and CSV …","t":"CCCCCFAAGDDDDDGDMMMLLLLLLLLLLLLMLFLFLLFLFFLLLLLLLLLLLLMLLMLMMLLLLLMLLLLLLLLLLLLLLMFFLFLLLLLLLMLLMFFMMMLMMALLLMMMLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLRRDDDLLLLLLLLLLLLMMMMMLMLLLLLLLLLLLLLLLLLLLMLMMMMMMMMLLLLLLLLLLRRRRRDDMLLLLLLLLLLMMMMLMLLLLLLLMMLLLLLMMMMMMMMLLLLLLLLLLLLLLLLM","n":["Reader","ReaderBuilder","Writer","WriterBuilder","infer_schema_from_files","map_csv_error","reader","writer","Bounds","BufReader" [...]
 "arrow_data":{"doc":"Low-level array data abstractions for Apache Arrow Rust","t":"NDDGNEDDNDNAAMMMMMMAMMAAAFMMMMMMMMAMDDDLLLLLLMMMMMMMLLLLLLLLLLLMMMLLLLLLLFLLLLLLLLLFNDDGNEDNNLLLLLLLLLLLALLMMMLLLMLLLLMMLLFFLLMMLLLLLLLLLLLLLLLLLLLLLLLFLLLLFLLMMLLFLLLLLLMLLMLLMMLLMMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMDDGLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLRRRRRRRRRFFAAFFFAAAAAAAAAAFFFFFFFRFFFFFFFFFFFFFDDFLLLLLMMMLMMLMMLLLLLLLLLLMMMLLMLLLMMMFLLLLLLNNENGGGNDNDMALLLLLLMMFFFFMLLMMMLMLMMAALLLLLLLLLLLLLLMALALMLMFAALLLLLL [...]
 "arrow_file_to_stream":{"doc":"","t":"DLLLLLLLMLLLLLLLFLLLLLL","n":["Args","augment_args","augment_args_for_update","borrow","borrow_mut","cast","command","command_for_update","file_name","fmt","from","from_arg_matches","from_arg_matches_mut","from_cast","group_id","into","main","try_from","try_into","type_id","update_from_arg_matches","update_from_arg_matches_mut","vzip"],"q":[[0,"arrow_file_to_stream"]],"d":["","","","","","","","","","","Returns the argument unchanged.","","","","","C [...]
-"arrow_flight":{"doc":"A native Rust implementation of Apache Arrow Flight for …","t":"DDGDDDCDDDDDDDDDDDDDMMMMLLLLLLAMMMALLMAMAMAMMFFAALLLLLALLLLFMLMMMMMMMMMMFAMMMMLLLLLMMMLLMMALLDLLLLLLLLLLLLLLLMLLLLLLLLMLLLLLLLDEDDDNNNLLLLLLLLLLLLLLLLMMLLLLLLLLLLLLLLLLLMMLLLLLLLLLLLLLLLLLLLMLLMLLMMLLLLLLLLLLLLLLLLLLLLLLDDDRMMLLLLLLLLLLMLMMMMLLLLMLLLLLLLFMLLLLLLLMMLLLMMLFFMLLMMFLLLLLLLLLLLLLLLLLLNNNENNGNLLLLLLLLLLLLLLLLLLLLNENNDMQQQQIDQQQMKKKKKKKMKKMMMDDDDDDDDDDDDDDDDMMMMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLL [...]
+"arrow_flight":{"doc":"A native Rust implementation of Apache Arrow Flight for …","t":"DDGDDDCDDDDDDDDDDDDDMMMMLLLLLLAMMMALLMAMAMAMMFFAALLLLLALLLLFMLMMMMMMMMMMFAMMMMLLLLLMMMLLMMALLDLLLLLLLLLLLLLLLMLLLLLLLLMLLLLLLLDEDDDNNNLLLLLLLLLLLLLLLLMMLLLLLLLLLLLLLLLLLMMLLLLLLLLLLLLLLLLLLLMLLMLLMMLLLLLLLLLLLLLLLLLLLLLLDDDRMMLLLLLLLLLLMLMMMMLLLLMLLLLLLLFMLLLLLLLMMLLLMMLFFMLLMMFLLLLLLLLLLLLLLLLLLNNNENNGNLLLLLLLLLLLLLLLLLLLLNENNDMQQQQIDQQQMKKKKKKKMKKMMMDDDDDDDDDDDDDDDDMMMMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLL [...]
 "arrow_integration_test":{"doc":"Support for the Apache Arrow JSON test data format","t":"DDDDDDDDFMMLLLLLLLLLLLLLLLLLLLLLLLLMMLLLLLLMMMFMMFFALLLLLLLLMMFLLLAFFMMLLLLLLLLLLLLLLLLLLLLLLLLLLLLMMMLLLLLLLLMMMMMMMMMFAMFFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMMLLLLLLLLFFFFDLLLLLLFLMFFLLLML","n":["ArrowJson","ArrowJsonBatch","ArrowJsonColumn","ArrowJsonDictionaryBatch","ArrowJsonField","ArrowJsonFieldDictionary","ArrowJsonSchema","DictionaryIndexType","array_from_json","batches","bit_width","borr [...]
 "arrow_integration_testing":{"doc":"Common code used in the integration test binaries","t":"RRDMMLLLAALLLLFFMLLLLAAAGGGFFGGGFFFFFFFGGFFGGAFAFADGDGGLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLMMFLLLLLLLMLLGDDGGLLLLLLMLLLLLFLLLLLLLLLLLLLLLLLLLLLFFFMFMLLLLLLLLMLLGDGGLLLLLLLLLLLLLLLLLLLLFLLLLL","n":["AUTH_PASSWORD","AUTH_USERNAME","ArrowFile","_dictionaries","batches","borrow","borrow_mut","cast","flight_client_scenarios","flight_server_scenarios","from","from_cast","into","into_request","read_gzip_json", [...]
-"arrow_ipc":{"doc":"Support for the Arrow IPC Format","t":"RRAAAAAERRNNLLLLLLFLFLFLFLLLLLLLFLLLLLDLLFLMFLLFFFLFFFLLFFMLMAAAAADDDDESSSSSMLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLMLLMLFFLLLLLLLLLLLLLLLLLLLLLLLLLLLMFFFLLLMLLLFFFMLLLLLLLLLLLLLLLLLLMSDDDDEDDSDDESSSRRRSSSRRRSSSRRRDSDDDDDESDSDDESSSSSSSSSSSSSSSSSSMMMMLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLMLLLLLMLMLLLLLLLLLLLLLLLLLLLLLLMMMMLLLLFFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLL [...]
+"arrow_ipc":{"doc":"Support for the Arrow IPC Format","t":"RRAAAAAERRNNLLLLLLFLFLFLFLLLLLLLFLLLLLDLLFLMFLLFFFLFFFLLFFMLMAAAAADDDDESSSSSMLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLMLLMLFFLLLLLLLLLLLLLLLLLLLLLLLLLLLMFFFLLLMLLLFFFMLLLLLLLLLLLLLLLLLLMSDDDDEDDSDDESSSRRRSSSRRRSSSRRRDSDDDDDESDSDDESSSSSSSSSSSSSSSSSSMMMMLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLMLLLLLMLMLLLLLLLLLLLLLLLLLLLLLLMMMMLLLLFFLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLL [...]
 "arrow_json":{"doc":"Transfer data between the Arrow memory format and JSON …","t":"CICCCCKOAAIDDDDMMALLLLLLLLLLLLMAKLMMLLLLLLLLLFFFLLLLMAFAMLLAAOLMMMALMMLAMAAAMALLLLLLLLLLLLDLLLLLLLLLLLDLLLLLLLLMMMLLLDLLLMLMLLLMLMLLLDLLLMLLLLMMLLLLMDLLLLLLLLLLLIDLLLMLLLLLKMOLLLNNENNDLLLLLLLLFFLLLLLLFFFFFFFFFFLLLMMLLLMMFLLLLLLLDDDDLLLLLLLLMLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLOLLLLLLLLLLLLLLLLMMMMLLLLLLLLLLLLLRDRLLLMLLLLLMLLLDLLLMLMLLLMLMFLLLDNENNNNNNENNNNNNNNNNDDENNNNLLLLLMLLLLLLLLLLLLLMLL [...]
 "arrow_json_integration_test":{"doc":"","t":"DNNENMFLLLLLLFLLLLLLLLLLLLLLLLMLLLLMFFMLLLLLLLLLLFLMLL","n":["Args","ArrowToJson","JsonToArrow","Mode","Validate","arrow","arrow_to_json","augment_args","augment_args_for_update","borrow","borrow","borrow_mut","borrow_mut","canonicalize_schema","cast","cast","clone","clone_into","command","command_for_update","fmt","fmt","from","from","from_arg_matches","from_arg_matches_mut","from_cast","from_cast","from_ref","group_id","integration","into"," [...]
 "arrow_ord":{"doc":"Arrow ordering kernels","t":"AAAAFFFFFFFFFFFOOFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFOFOOOOOOFFFGFFOFFFFFDLLLMFLLLLFLMFMMLLLLDGDDLLLLLLLLLLLLLFLFLMLMLLLLLLLLLLLLFLLLFFLMMLFFFFFFFFFFFFFFFFFFFFFFFLLLLLLLLLLLLM","n":["comparison","ord","partition","sort","cmp_dict","cmp_dict_binary","cmp_dict_binary_array","cmp_dict_bool","cmp_dict_boolean_array","cmp_dict_primitive","cmp_dict_string_array","cmp_dict_utf8","cmp_primitive_array [...]
 "arrow_row":{"doc":"A comparable row-oriented representation of a collection …","t":"ENNNNENNDDDDDDDDNNNNLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLLLLLLLLLLLLMMMMMLLLMMMFOOALFLMLLLLLLLLLMMALLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLALLLLLLLLLLLLLLALLLLFLLLFLMMLLLLLLMLLLMLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLMAFFFFFFOFFFSQIIKFFFFFFKFOOFKFDDDDDLLLLLLLLLLLMLLLLLLMLLLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLLLMLMMLMLLMLLLLLLLLLLLLLLLLLLLMMMFFFFFRRRRFFFFFFF","n":["Codec","Dictionary","Dictionary","DictionaryValues"," [...]
-"arrow_schema":{"doc":"Arrow logical types","t":"ENNNNNNRRRRRENNNNNNNNNNNDGDNNNNNNNNNNENNNNNNNNNNNNNNNNNNNDDNGNDNNNNENNNNNNDENNLLLLLMALMMMLLAAAAMMLLLLMMMLMMLALLLLNNRRRRRENNNNNNNNNNNNNNNNNNENNNNNNNNNNNNNNNNENNNNNNENNLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLENNNNNNNNNNNNNNNNLLLLLLLLLLLLLLLLDDDLLLLLLMMLMMLLLALMLLMLLFLLLLMMMLMLMMFLLLLLLLLLLLLLLLLLSDSSLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLDGLLLLLLLLMLLMLMLLLLLLLLLLLMLMLLLLLLLLMLLLLLLLLL [...]
+"arrow_schema":{"doc":"Arrow logical types","t":"ENNNNNNRRRRRENNNNNNNNNNNDGDNNNNNNNNNNENNNNNNNNNNNNNNNNNNNDDNGNDNNNNENNNNNNDENNLLLLLMALMMMLLAAAAMMLLLLMMMLMMLALLLLNNRRRRRENNNNNNNNNNNNNNNNNNENNNNNNNNNNNNNNNNENNNNNNENNLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLENNNNNNNNNNNNNNNNLLLLLLLLLLLLLLLLDDDLLLLLLMMLMMLLLALMLLMLLFLLLLMMMLMLMMFLLLLLLLLLLLLLLLLLSDSSLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLLDGLLLLLLLLMLLMLMLLLLLLLLLLLMLMLLLLLLLLMLLLLLLLLL [...]
 "arrow_select":{"doc":"Arrow selection kernels","t":"AAAAAAAFFFNRGDDDDNNENNDNLLLLLLLLLLLLLFLLLLLLMMMLMMLLFLMMFFFFFFFFFLLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLLLLFMLMMMMLLLLLLLLLLLLLLLLLLDMLLLLLFFFFLLMMOLLLFDLLLMLLLLLLLFFFFFFFFFFFFFFFFLLLLFF","n":["concat","filter","interleave","nullif","take","window","zip","binary_capacity","concat","concat_batches","All","FILTER_SLICES_SELECTIVITY_THRESHOLD","Filter","FilterBuilder","FilterBytes","FilterPredicate","IndexIterator","IndexIterator","Indices","Iter [...]
 "arrow_stream_to_file":{"doc":"","t":"F","n":["main"],"q":[[0,"arrow_stream_to_file"]],"d":[""],"i":[0],"f":[[[],1]],"c":[],"p":[[6,"Result"]]},\
 "arrow_string":{"doc":"Arrow string kernels","t":"AAAAAFFFFFFFFOFFFFOFFFFFFFFFOOFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFOFFFFFFFFFFFFFFF","n":["concat_elements","length","like","regexp","substring","concat_element_binary","concat_elements_bytes","concat_elements_dyn","concat_elements_utf8","concat_elements_utf8_many","bit_length","bit_length_binary","bit_length_string","kernel_dict","length","length_binary","length_list","length_string","unary_offsets","compare_op","compare_op_scalar","c [...]
@@ -23,11 +23,11 @@ var searchIndex = JSON.parse('{\
 "flight_test_integration_client":{"doc":"","t":"DNGNGELLLLLLLLLLLLLLLLLLLLLLMLLLLFMMMLLLLLLLLLLLLL","n":["Args","AuthBasicProto","Error","Middleware","Result","Scenario","augment_args","augment_args_for_update","borrow","borrow","borrow_mut","borrow_mut","cast","cast","clone","clone_into","command","command_for_update","fmt","fmt","from","from","from_arg_matches","from_arg_matches_mut","from_cast","from_cast","from_ref","group_id","host","into","into","into_request","into_request","main" [...]
 "flight_test_integration_server":{"doc":"","t":"DNGNGELLLLLLLLLLLLLLLLLLLLLLLLLLFMMLLLLLLLLLLLLL","n":["Args","AuthBasicProto","Error","Middleware","Result","Scenario","augment_args","augment_args_for_update","borrow","borrow","borrow_mut","borrow_mut","cast","cast","clone","clone_into","command","command_for_update","fmt","fmt","from","from","from_arg_matches","from_arg_matches_mut","from_cast","from_cast","from_ref","group_id","into","into","into_request","into_request","main","port"," [...]
 "gen":{"doc":"","t":"FF","n":["main","prost_config"],"q":[[0,"gen"]],"d":["",""],"i":[0,0],"f":[[[],[[3,[[2,[1]]]]]],[[],4]],"c":[],"p":[[8,"Error"],[3,"Box"],[4,"Result"],[3,"Config"]]},\
-"parquet":{"doc":"This crate contains the official Native Rust …","t":"AAAAAAOAAAARCCDCDLAFAAALLLLALLLLLLAMLLLLLLLLLLMMFFFALLLLLLLLLIDDDDGDIDDFMMMLLLLLLLLLLLLLKLKFMMAMLLLLLLLMLLLLMLMLLLLLLKMMLMKMMMMLLMMAMMMFMMLLLLLLLLLLLLLLLLLLLLLLLIDDLLLLLLKLMLLLLLLLLMKLMLLLLLLDDFLLLLLLLLLLLLLLLLLLLLLLLLLLLLFLLLLLLLMLLMLLMLLLLLLLLLLDEDDDNDNGLMLLLLLLLLLLLLMMALLLLLLLLLLMLLLLLLLLLLLLLLLLLFFLFFLFFFLMLLLLLLLLLLMAMLLLLMLLLLLLLLLLLLLLLLLLLLLLFFLLFMMDDNNDDENLMLLLLLLLLLLLLLLLFLLMOOOFLLMLLLLLMLLLLLLLLLLLLLLLLLLLM [...]
+"parquet":{"doc":"This crate contains the official Native Rust …","t":"AAAAAAOAAAARCCDCDLAFAAALLLLALLLLLLAMLLLLLLLLLLMMFFFALLLLLLLLLIDDDDGDIDDFMMMLLLLLLLLLLLLLKLKFMMAMLLLLLLLMLLLLMLMLLLLLLKMMLMKMMMMLLMMAMMMFMMLLLLLLLLLLLLLLLLLLLLLLLIDDLLLLLLKLMLLLLLLLLMKLMLLLLLLDDFLLLLLLLLLLLLLLLLLLLLLLLLLLLLFLLLLLLLMLLMLLMLLLLLLLLLLDEDDDNDNGLMLLLLLLLLLLLLMMALLLLLLLLLLMLLLLLLLLLLLLLLLLLFFLFFLFFFLMLLLLLLLLLLMAMLLLLMLLLLLLLLLLLLLLLLLLLLLLFFLLFMMDDNNDDENLMLLLLLLLLLLLLLLLFLLMOOOFLLMLLLLLMLLLLLLLLLLLLLLLLLLLM [...]
 "parquet_concat":{"doc":"Binary that concatenates the column data of one or more …","t":"DLLLLLLLLLLLLLMLFMLLLLLL","n":["Args","augment_args","augment_args_for_update","borrow","borrow_mut","cast","command","command_for_update","fmt","from","from_arg_matches","from_arg_matches_mut","from_cast","group_id","input","into","main","output","run","try_from","try_into","type_id","update_from_arg_matches","update_from_arg_matches_mut"],"q":[[0,"parquet_concat"]],"d":["Concatenates one or more pa [...]
 "parquet_derive":{"doc":"","t":"YANNNDNNNEENNNLLLLLLLLLLLLLLLLLLLLLLLLLMLLLLMLLLLLLLLLMLLLLLLMLLLL","n":["ParquetRecordWriter","parquet_field","Array","ChronoNaiveDate","ChronoNaiveDateTime","Field","Option","Reference","Slice","ThirdPartyType","Type","TypePath","Uuid","Vec","borrow","borrow","borrow","borrow_mut","borrow_mut","borrow_mut","column_writer","converted_type","copied_direct_vals","eq","eq","eq","fmt","fmt","fmt","from","from","from","from","from","from_type","from_type_array [...]
 "parquet_derive_test":{"doc":"","t":"DMMMMLLMMMMMMLMMLLMMLMMMMMMMMMMMLLLM","n":["ACompleteRecord","a_bool","a_borrowed_string","a_str","a_string","borrow","borrow_mut","borrowed_byte_vec","borrowed_maybe_a_str","borrowed_maybe_a_string","borrowed_maybe_borrowed_byte_vec","borrowed_maybe_byte_vec","byte_vec","cast","double","float","from","from_cast","i16","i32","into","isize","maybe_a_str","maybe_a_string","maybe_byte_vec","maybe_double","maybe_float","maybe_i16","maybe_u32","maybe_u8"," [...]
-"parquet_fromcsv":{"doc":"Binary file to converts csv to Parquet file","t":"DNNNNNENNNEENNFLLMLLLLLLLLLLLLLLLLLLFFFFMMMMLLMLLLLLLLLLLLLLLLLLLLLLLLLMMMMLLLLFMMMMMMLLLLLLLLLLLLLLLLLLLLLLLMF","n":["Args","ArrowError","CR","CommandLineParseError","Crlf","Csv","CsvDialect","IoError","LF","ParquetError","ParquetFromCsvError","RecordTerminator","Tsv","WithContext","arrow_schema_from_string","augment_args","augment_args_for_update","batch_size","borrow","borrow","borrow","borrow","borrow_mut","b [...]
+"parquet_fromcsv":{"doc":"Binary file to converts csv to Parquet file","t":"DNNNNNENNNEENNFLLMLLLLLLLLLLLLLLLLLLFFFFMMMMLLMLLLLLLLLLLLLLLLLLLLLLLLLMMMMLLLLFMMMMMMLLLLLLLLLLLLLLLLLLLLLLLMF","n":["Args","ArrowError","CR","CommandLineParseError","Crlf","Csv","CsvDialect","IoError","LF","ParquetError","ParquetFromCsvError","RecordTerminator","Tsv","WithContext","arrow_schema_from_string","augment_args","augment_args_for_update","batch_size","borrow","borrow","borrow","borrow","borrow_mut","b [...]
 "parquet_index":{"doc":"Binary that prints the [page index] of a parquet file","t":"DLLLLLMLLFMLLLLLLLFFLLLLLL","n":["Args","augment_args","augment_args_for_update","borrow","borrow_mut","cast","column","command","command_for_update","compute_row_counts","file","fmt","from","from_arg_matches","from_arg_matches_mut","from_cast","group_id","into","main","print_index","run","try_from","try_into","type_id","update_from_arg_matches","update_from_arg_matches_mut"],"q":[[0,"parquet_index"]],"d" [...]
 "parquet_layout":{"doc":"Binary that prints the physical layout of a parquet file","t":"DDDDDLLLLLLLLLLLLLLLLLMLLMFMFFMMLLLLLLLLLLLLLLLLLLMMMMLLLLLFMMMMMFMMLLLLLLLLLLLLLLLLLLLLMLL","n":["Args","ColumnChunk","Page","ParquetFile","RowGroup","augment_args","augment_args_for_update","borrow","borrow","borrow","borrow","borrow","borrow_mut","borrow_mut","borrow_mut","borrow_mut","borrow_mut","cast","cast","cast","cast","cast","columns","command","command_for_update","compressed_bytes","compre [...]
 "parquet_read":{"doc":"Binary file to read data from a Parquet file.","t":"DLLLLLLLMLLLLLLLMFMFLLLLL","n":["Args","augment_args","augment_args_for_update","borrow","borrow_mut","cast","command","command_for_update","file_name","fmt","from","from_arg_matches","from_arg_matches_mut","from_cast","group_id","into","json","main","num_records","print_row","try_from","try_into","type_id","update_from_arg_matches","update_from_arg_matches_mut"],"q":[[0,"parquet_read"]],"d":["","","","","","","", [...]