You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iceberg.apache.org by ao...@apache.org on 2023/05/31 21:10:03 UTC

[iceberg-docs] branch 1.3.0 updated: Javadoc for 1.3.0 (#243)

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

aokolnychyi pushed a commit to branch 1.3.0
in repository https://gitbox.apache.org/repos/asf/iceberg-docs.git


The following commit(s) were added to refs/heads/1.3.0 by this push:
     new 8bee6f6f Javadoc for 1.3.0 (#243)
8bee6f6f is described below

commit 8bee6f6f258d1bc37f762f3e2ab08e1a010fccc8
Author: Anton Okolnychyi <ao...@apple.com>
AuthorDate: Wed May 31 14:09:56 2023 -0700

    Javadoc for 1.3.0 (#243)
---
 javadoc/allclasses-frame.html                      |   50 +-
 javadoc/allclasses-noframe.html                    |   50 +-
 javadoc/constant-values.html                       | 1342 +++++++---
 javadoc/deprecated-list.html                       |  786 +++++-
 javadoc/index-all.html                             | 2596 +++++++++++++++-----
 .../AllDataFilesTable.AllDataFilesTableScan.html   |   94 +-
 ...llDeleteFilesTable.AllDeleteFilesTableScan.html |   94 +-
 .../iceberg/AllFilesTable.AllFilesTableScan.html   |   94 +-
 .../AllManifestsTable.AllManifestsTableScan.html   |   94 +-
 javadoc/org/apache/iceberg/BaseMetadataTable.html  |   27 +-
 .../org/apache/iceberg/BaseMetastoreCatalog.html   |    2 +-
 javadoc/org/apache/iceberg/BaseOverwriteFiles.html |  541 ++--
 .../org/apache/iceberg/BaseReplacePartitions.html  |  535 ++--
 .../org/apache/iceberg/BaseReplaceSortOrder.html   |   31 +-
 .../org/apache/iceberg/BaseRewriteManifests.html   |    4 +-
 javadoc/org/apache/iceberg/BatchScan.html          |    2 +-
 javadoc/org/apache/iceberg/CatalogProperties.html  |  163 +-
 javadoc/org/apache/iceberg/CatalogUtil.html        |   37 +-
 javadoc/org/apache/iceberg/ClientPoolImpl.html     |   27 +-
 javadoc/org/apache/iceberg/ContentFile.html        |   84 +-
 javadoc/org/apache/iceberg/DataFile.html           |    2 +-
 .../iceberg/DataFilesTable.DataFilesTableScan.html |   90 +-
 javadoc/org/apache/iceberg/DataTableScan.html      |  140 +-
 javadoc/org/apache/iceberg/DeleteFile.html         |    2 +-
 .../DeleteFilesTable.DeleteFilesTableScan.html     |   90 +-
 .../org/apache/iceberg/FileMetadata.Builder.html   |   15 +-
 .../apache/iceberg/FilesTable.FilesTableScan.html  |   90 +-
 .../org/apache/iceberg/IncrementalAppendScan.html  |    2 +-
 .../apache/iceberg/IncrementalChangelogScan.html   |    2 +-
 javadoc/org/apache/iceberg/IncrementalScan.html    |    2 +-
 .../MetadataUpdate.SetDefaultPartitionSpec.html    |    4 +-
 .../iceberg/MicroBatches.MicroBatchBuilder.html    |   21 +-
 javadoc/org/apache/iceberg/MicroBatches.html       |   44 +-
 javadoc/org/apache/iceberg/Partitioning.html       |   38 +-
 ...itionDeletesTable.PositionDeletesBatchScan.html |   88 +-
 .../org/apache/iceberg/PositionDeletesTable.html   |   82 +-
 javadoc/org/apache/iceberg/ReplaceSortOrder.html   |    2 +-
 javadoc/org/apache/iceberg/RewriteFiles.html       |  214 +-
 javadoc/org/apache/iceberg/Scan.html               |   42 +-
 javadoc/org/apache/iceberg/Snapshot.html           |    6 +-
 javadoc/org/apache/iceberg/SnapshotScan.html       |   92 +-
 javadoc/org/apache/iceberg/SortOrder.Builder.html  |   14 +-
 javadoc/org/apache/iceberg/SortOrderBuilder.html   |   32 +-
 javadoc/org/apache/iceberg/StreamingDelete.html    |  531 ++--
 javadoc/org/apache/iceberg/TableProperties.html    |  275 ++-
 javadoc/org/apache/iceberg/TableScan.html          |    2 +-
 javadoc/org/apache/iceberg/actions/Action.html     |    2 +-
 .../apache/iceberg/actions/ActionsProvider.html    |   20 +-
 .../actions/BaseDeleteOrphanFilesActionResult.html |   20 +-
 .../BaseDeleteReachableFilesActionResult.html      |   39 +-
 .../actions/BaseExpireSnapshotsActionResult.html   |  416 ----
 .../actions/BaseFileGroupRewriteResult.html        |   58 +-
 .../actions/BaseMigrateTableActionResult.html      |   19 +-
 .../actions/BaseRewriteDataFilesAction.html        |   29 +-
 .../actions/BaseRewriteDataFilesFileGroupInfo.html |   28 +-
 .../actions/BaseRewriteDataFilesResult.html        |   25 +-
 .../actions/BaseRewriteManifestsActionResult.html  |   27 +-
 .../actions/BaseSnapshotTableActionResult.html     |   20 +-
 .../apache/iceberg/actions/BinPackStrategy.html    |   80 +-
 .../iceberg/actions/DeleteOrphanFiles.Result.html  |    3 +-
 .../apache/iceberg/actions/DeleteOrphanFiles.html  |    3 +-
 .../actions/DeleteReachableFiles.Result.html       |    3 +-
 .../iceberg/actions/DeleteReachableFiles.html      |    3 +-
 .../iceberg/actions/ExpireSnapshots.Result.html    |    8 +-
 .../{MigrateTable.html => FileRewriter.html}       |  166 +-
 .../iceberg/actions/MigrateTable.Result.html       |    3 +-
 .../org/apache/iceberg/actions/MigrateTable.html   |    7 +-
 ...> RewriteDataFiles.FileGroupFailureResult.html} |   70 +-
 .../actions/RewriteDataFiles.FileGroupInfo.html    |    7 +-
 .../RewriteDataFiles.FileGroupRewriteResult.html   |    6 +-
 .../iceberg/actions/RewriteDataFiles.Result.html   |   48 +-
 .../apache/iceberg/actions/RewriteDataFiles.html   |   17 +-
 ...ewriteDataFilesCommitManager.CommitService.html |   67 +-
 .../apache/iceberg/actions/RewriteFileGroup.html   |   33 +-
 .../iceberg/actions/RewriteManifests.Result.html   |    3 +-
 .../apache/iceberg/actions/RewriteManifests.html   |    3 +-
 ... RewritePositionDeleteFiles.FileGroupInfo.html} |   71 +-
 ...ositionDeleteFiles.FileGroupRewriteResult.html} |   95 +-
 .../actions/RewritePositionDeleteFiles.Result.html |   82 +-
 .../actions/RewritePositionDeleteFiles.html        |  222 +-
 .../actions/RewritePositionDeleteStrategy.html     |   30 +-
 ...ositionDeletesCommitManager.CommitService.html} |  105 +-
 ...ml => RewritePositionDeletesCommitManager.html} |  201 +-
 ...Group.html => RewritePositionDeletesGroup.html} |  154 +-
 .../apache/iceberg/actions/RewriteStrategy.html    |   33 +-
 .../iceberg/actions/SizeBasedDataRewriter.html     |  454 ++++
 .../iceberg/actions/SizeBasedFileRewriter.html     |  799 ++++++
 .../actions/SizeBasedPositionDeletesRewriter.html  |  346 +++
 .../iceberg/actions/SnapshotTable.Result.html      |    3 +-
 .../org/apache/iceberg/actions/SnapshotTable.html  |    7 +-
 .../org/apache/iceberg/actions/SnapshotUpdate.html |    2 +-
 .../org/apache/iceberg/actions/SortStrategy.html   |   39 +-
 .../org/apache/iceberg/actions/package-frame.html  |   10 +-
 .../apache/iceberg/actions/package-summary.html    |  134 +-
 .../org/apache/iceberg/actions/package-tree.html   |   16 +-
 .../org/apache/iceberg/arrow/ArrowSchemaUtil.html  |    4 +-
 ...emaUtil.html => DictEncodedArrowConverter.html} |   59 +-
 .../org/apache/iceberg/arrow/package-frame.html    |    1 +
 .../org/apache/iceberg/arrow/package-summary.html  |    6 +
 javadoc/org/apache/iceberg/arrow/package-tree.html |    1 +
 .../iceberg/arrow/vectorized/ColumnVector.html     |   71 +-
 ...icArrowVectorAccessorFactory.StringFactory.html |   24 +-
 .../VectorHolder.ConstantVectorHolder.html         |    2 +-
 .../VectorHolder.DeletedVectorHolder.html          |    2 +-
 .../VectorHolder.PositionVectorHolder.html         |   10 +-
 .../iceberg/arrow/vectorized/VectorHolder.html     |   33 +-
 .../VectorizedColumnIterator.BatchReader.html      |    2 +-
 ...lumnIterator.FixedLengthDecimalBatchReader.html |   22 +-
 ...ColumnIterator.IntBackedDecimalBatchReader.html |   22 +-
 ...olumnIterator.LongBackedDecimalBatchReader.html |   22 +-
 .../VectorizedColumnIterator.LongBatchReader.html  |    4 +-
 ...dColumnIterator.TimestampInt96BatchReader.html} |   32 +-
 ...dColumnIterator.TimestampMillisBatchReader.html |    4 +-
 .../parquet/VectorizedColumnIterator.html          |   75 +-
 ...orizedDictionaryEncodedParquetValuesReader.html |   17 +-
 .../arrow/vectorized/parquet/package-summary.html  |    6 +-
 .../arrow/vectorized/parquet/package-tree.html     |    1 +
 .../org/apache/iceberg/aws/AwsClientFactory.html   |    4 +-
 .../apache/iceberg/aws/AwsClientProperties.html    |  435 ++++
 javadoc/org/apache/iceberg/aws/AwsProperties.html  | 1158 +++++++--
 .../apache/iceberg/aws/HttpClientProperties.html   |  666 +++++
 .../org/apache/iceberg/aws/RESTSigV4Signer.html    |    8 +-
 .../S3FileIOAwsClientFactories.html}               |   57 +-
 javadoc/org/apache/iceberg/aws/package-frame.html  |    3 +
 .../org/apache/iceberg/aws/package-summary.html    |   12 +
 javadoc/org/apache/iceberg/aws/package-tree.html   |    3 +
 javadoc/org/apache/iceberg/aws/s3/S3FileIO.html    |   60 +-
 .../s3/S3FileIOAwsClientFactory.html}              |   92 +-
 .../apache/iceberg/aws/s3/S3FileIOProperties.html  | 1979 +++++++++++++++
 javadoc/org/apache/iceberg/aws/s3/S3InputFile.html |   52 +-
 .../org/apache/iceberg/aws/s3/S3OutputFile.html    |   38 +-
 .../org/apache/iceberg/aws/s3/package-frame.html   |    5 +
 .../org/apache/iceberg/aws/s3/package-summary.html |   23 +-
 .../org/apache/iceberg/aws/s3/package-tree.html    |    9 +
 .../iceberg/aws/s3/signer/package-summary.html     |    4 +-
 .../apache/iceberg/aws/s3/signer/package-tree.html |    4 +-
 .../util/RetryDetector.html}                       |  112 +-
 .../org/apache/iceberg/aws/util/package-frame.html |   19 +
 .../iceberg/aws/{s3 => util}/package-summary.html  |   35 +-
 .../procedures => aws/util}/package-tree.html      |   28 +-
 javadoc/org/apache/iceberg/catalog/Catalog.html    |    4 +-
 .../apache/iceberg/catalog/SupportsNamespaces.html |    2 +-
 .../org/apache/iceberg/catalog/ViewCatalog.html    |    2 +-
 .../apache/iceberg/catalog/package-summary.html    |    4 +-
 .../org/apache/iceberg/catalog/package-tree.html   |    4 +-
 .../delta/SnapshotDeltaLakeTable.Result.html       |    3 +-
 .../iceberg/delta/SnapshotDeltaLakeTable.html      |    3 +-
 .../flink/CatalogLoader.CustomCatalogLoader.html   |   31 +-
 .../flink/CatalogLoader.HadoopCatalogLoader.html   |   31 +-
 .../flink/CatalogLoader.HiveCatalogLoader.html     |   31 +-
 .../flink/CatalogLoader.RESTCatalogLoader.html     |   31 +-
 .../org/apache/iceberg/flink/CatalogLoader.html    |   30 +-
 javadoc/org/apache/iceberg/flink/FlinkCatalog.html |    2 +-
 .../org/apache/iceberg/flink/FlinkReadConf.html    |   43 +-
 .../org/apache/iceberg/flink/FlinkReadOptions.html |   32 +-
 .../org/apache/iceberg/flink/FlinkSchemaUtil.html  |    4 +-
 .../FlinkSourceFilter.html}                        |   64 +-
 .../org/apache/iceberg/flink/FlinkTypeVisitor.html |    4 +-
 .../org/apache/iceberg/flink/FlinkWriteConf.html   |   17 +-
 .../apache/iceberg/flink/FlinkWriteOptions.html    |   15 +-
 .../flink/TableLoader.CatalogTableLoader.html      |   35 +-
 .../flink/TableLoader.HadoopTableLoader.html       |   35 +-
 javadoc/org/apache/iceberg/flink/TableLoader.html  |   30 +-
 .../flink/actions/RewriteDataFilesAction.html      |    2 +-
 .../iceberg/flink/data/RowDataProjection.html      |   95 +-
 .../org/apache/iceberg/flink/package-frame.html    |    1 +
 .../org/apache/iceberg/flink/package-summary.html  |   16 +-
 javadoc/org/apache/iceberg/flink/package-tree.html |   13 +-
 .../flink/source/IcebergSource.Builder.html        |   55 +-
 .../apache/iceberg/flink/source/IcebergSource.html |    4 +-
 .../flink/source/RowDataFileScanTaskReader.html    |   10 +-
 .../iceberg/flink/source/ScanContext.Builder.html  |   47 +-
 .../apache/iceberg/flink/source/ScanContext.html   |   41 +-
 .../flink/source/StreamingReaderOperator.html      |   11 +-
 .../enumerator/ContinuousSplitPlannerImpl.html     |    7 +-
 .../apache/iceberg/flink/source/package-tree.html  |    2 +-
 .../reader/AvroGenericRecordReaderFunction.html    |   10 +-
 .../flink/source/reader/IcebergSourceReader.html   |    2 +-
 .../flink/source/reader/RowDataReaderFunction.html |   10 +-
 .../apache/iceberg/hadoop/ConfigProperties.html    |   17 +
 .../org/apache/iceberg/hadoop/Configurable.html    |    2 +-
 .../org/apache/iceberg/hive/CachedClientPool.html  |   15 +
 .../org/apache/iceberg/hive/HiveClientPool.html    |    2 +-
 javadoc/org/apache/iceberg/hive/MetastoreUtil.html |   37 +-
 .../{aws/RESTSigV4Signer.html => hive/NoLock.html} |   96 +-
 .../apache/iceberg/hive/RuntimeMetaException.html  |    4 +-
 javadoc/org/apache/iceberg/hive/package-frame.html |    1 +
 .../org/apache/iceberg/hive/package-summary.html   |   12 +-
 javadoc/org/apache/iceberg/hive/package-tree.html  |    5 +-
 .../InMemoryCatalog.html}                          |  403 ++-
 .../InMemoryFileIO.html}                           |  225 +-
 .../InMemoryInputFile.html}                        |  140 +-
 .../iceberg/inmemory/InMemoryOutputFile.html       |  413 ++++
 .../org/apache/iceberg/inmemory/package-frame.html |   22 +
 .../{arrow => inmemory}/package-summary.html       |   32 +-
 .../iceberg/{nessie => inmemory}/package-tree.html |   30 +-
 .../apache/iceberg/io/BasePositionDeltaWriter.html |   14 +
 javadoc/org/apache/iceberg/io/FileIO.html          |    2 +-
 javadoc/org/apache/iceberg/io/InputFile.html       |    2 +-
 javadoc/org/apache/iceberg/io/OutputFile.html      |    2 +-
 javadoc/org/apache/iceberg/io/ResolvingFileIO.html |   42 +-
 javadoc/org/apache/iceberg/io/package-summary.html |    4 +-
 javadoc/org/apache/iceberg/io/package-tree.html    |    4 +-
 javadoc/org/apache/iceberg/jdbc/JdbcCatalog.html   |   27 +-
 .../org/apache/iceberg/jdbc/JdbcClientPool.html    |    2 +-
 .../apache/iceberg/metrics/MetricsReporter.html    |    4 +-
 .../MetricsReporters.html}                         |   56 +-
 .../org/apache/iceberg/metrics/ScanMetrics.html    |    4 +-
 .../org/apache/iceberg/metrics/package-frame.html  |    1 +
 .../apache/iceberg/metrics/package-summary.html    |    8 +-
 .../org/apache/iceberg/metrics/package-tree.html   |    1 +
 .../org/apache/iceberg/nessie/NessieCatalog.html   |   53 +-
 .../org/apache/iceberg/nessie/package-tree.html    |    2 +-
 javadoc/org/apache/iceberg/orc/package-tree.html   |    2 +-
 javadoc/org/apache/iceberg/package-tree.html       |   14 +-
 .../org/apache/iceberg/parquet/ParquetUtil.html    |   37 +-
 javadoc/org/apache/iceberg/rest/HTTPClient.html    |   45 +-
 javadoc/org/apache/iceberg/rest/RESTCatalog.html   |   29 +-
 .../apache/iceberg/rest/RESTSessionCatalog.html    |   27 +-
 .../iceberg/rest/auth/OAuth2Util.AuthSession.html  |   24 -
 .../requests/ReportMetricsRequest.ReportType.html  |   12 +
 .../rest/requests/ReportMetricsRequest.html        |   17 +-
 .../apache/iceberg/spark/ChangelogIterator.html    |  259 +-
 .../org/apache/iceberg/spark/CommitMetadata.html   |    4 +-
 ...logIterator.html => ComputeUpdateIterator.html} |  125 +-
 .../org/apache/iceberg/spark/ExtendedParser.html   |    4 +-
 .../iceberg/spark/FileRewriteCoordinator.html      |   42 +-
 javadoc/org/apache/iceberg/spark/IcebergSpark.html |    4 +-
 .../org/apache/iceberg/spark/PathIdentifier.html   |    4 +-
 ...html => PositionDeletesRewriteCoordinator.html} |  121 +-
 .../spark/PruneColumnsWithoutReordering.html       |    4 +-
 .../apache/iceberg/spark/RollbackStagedTable.html  |   11 +-
 javadoc/org/apache/iceberg/spark/Spark3Util.html   |   74 +-
 .../iceberg/spark/SparkCachedTableCatalog.html     |   95 +-
 javadoc/org/apache/iceberg/spark/SparkCatalog.html |   91 +-
 .../org/apache/iceberg/spark/SparkDataFile.html    |    6 +-
 .../spark/SparkDistributionAndOrderingUtil.html    |  330 ---
 .../apache/iceberg/spark/SparkExceptionUtil.html   |    4 +-
 javadoc/org/apache/iceberg/spark/SparkFilters.html |    4 +-
 .../SparkFunctionCatalog.html}                     |  168 +-
 .../org/apache/iceberg/spark/SparkReadConf.html    |   83 +-
 .../org/apache/iceberg/spark/SparkReadOptions.html |   92 +-
 .../apache/iceberg/spark/SparkSQLProperties.html   |   54 +-
 .../org/apache/iceberg/spark/SparkSchemaUtil.html  |   57 +-
 .../apache/iceberg/spark/SparkSessionCatalog.html  |  118 +-
 .../org/apache/iceberg/spark/SparkTableUtil.html   |  117 +-
 javadoc/org/apache/iceberg/spark/SparkUtil.html    |  146 +-
 .../org/apache/iceberg/spark/SparkWriteConf.html   |  140 +-
 .../apache/iceberg/spark/SparkWriteOptions.html    |   47 +-
 .../SparkWriteRequirements.html}                   |  114 +-
 .../{SparkFilters.html => SparkWriteUtil.html}     |   87 +-
 .../spark/actions/RewriteDataFilesSparkAction.html |    2 +-
 .../spark/actions/RewriteManifestsSparkAction.html |    4 +-
 ... => RewritePositionDeleteFilesSparkAction.html} |  274 +--
 .../iceberg/spark/actions/SetAccumulator.html      |    4 +-
 .../apache/iceberg/spark/actions/SparkActions.html |   29 +-
 .../spark/actions/SparkBinPackStrategy.html        |  333 ---
 .../iceberg/spark/actions/SparkSortStrategy.html   |  522 ----
 .../iceberg/spark/actions/SparkZOrderStrategy.html |  457 ----
 .../iceberg/spark/actions/package-frame.html       |    4 +-
 .../iceberg/spark/actions/package-summary.html     |   22 +-
 .../apache/iceberg/spark/actions/package-tree.html |   15 +-
 .../iceberg/spark/data/SparkOrcValueReaders.html   |   15 +-
 .../vectorized/VectorizedSparkParquetReaders.html  |   87 +-
 .../functions/DaysFunction.DateToDaysFunction.html |    4 +-
 ...> DaysFunction.TimestampNtzToDaysFunction.html} |   40 +-
 .../DaysFunction.TimestampToDaysFunction.html      |    4 +-
 .../iceberg/spark/functions/DaysFunction.html      |    4 +
 ...HoursFunction.TimestampNtzToHoursFunction.html} |   44 +-
 .../HoursFunction.TimestampToHoursFunction.html    |    4 +-
 .../iceberg/spark/functions/HoursFunction.html     |    8 +-
 .../MonthsFunction.DateToMonthsFunction.html       |    4 +-
 ...nthsFunction.TimestampNtzToMonthsFunction.html} |   44 +-
 .../MonthsFunction.TimestampToMonthsFunction.html  |    4 +-
 .../iceberg/spark/functions/MonthsFunction.html    |    4 +
 .../YearsFunction.DateToYearsFunction.html         |    4 +-
 ...YearsFunction.TimestampNtzToYearsFunction.html} |   40 +-
 .../YearsFunction.TimestampToYearsFunction.html    |    4 +-
 .../iceberg/spark/functions/YearsFunction.html     |    4 +
 .../iceberg/spark/functions/package-frame.html     |    4 +
 .../iceberg/spark/functions/package-summary.html   |   42 +-
 .../iceberg/spark/functions/package-tree.html      |    4 +
 .../org/apache/iceberg/spark/package-frame.html    |    7 +-
 .../org/apache/iceberg/spark/package-summary.html  |   89 +-
 javadoc/org/apache/iceberg/spark/package-tree.html |   12 +-
 .../procedures/RemoveOrphanFilesProcedure.html     |    4 +-
 ...ml => RewritePositionDeleteFilesProcedure.html} |   74 +-
 .../iceberg/spark/procedures/SparkProcedures.html  |    4 +-
 .../iceberg/spark/procedures/package-frame.html    |    1 +
 .../iceberg/spark/procedures/package-summary.html  |    6 +
 .../iceberg/spark/procedures/package-tree.html     |    1 +
 .../iceberg/spark/source/HasIcebergCatalog.html    |    2 +-
 .../iceberg/spark/source/SparkChangelogTable.html  |   31 +-
 .../spark/source/SparkMicroBatchStream.html        |   57 +-
 .../spark/source/SparkPartitionedWriter.html       |    4 +-
 ...arkPositionDeletesRewrite.DeleteTaskCommit.html |  207 ++
 .../SparkPositionDeletesRewrite.html}              |   72 +-
 .../SparkPositionDeletesRewriteBuilder.html}       |   91 +-
 .../iceberg/spark/source/SparkScanBuilder.html     |    6 +-
 .../apache/iceberg/spark/source/SparkTable.html    |   11 +-
 .../iceberg/spark/source/StagedSparkTable.html     |    6 +-
 .../apache/iceberg/spark/source/package-frame.html |    3 +
 .../iceberg/spark/source/package-summary.html      |   20 +-
 .../apache/iceberg/spark/source/package-tree.html  |    7 +-
 javadoc/org/apache/iceberg/util/PartitionUtil.html |   25 +-
 javadoc/org/apache/iceberg/util/StructLikeMap.html |   17 +-
 javadoc/org/apache/iceberg/util/UUIDUtil.html      |   19 +-
 .../apache/iceberg/view/SQLViewRepresentation.html |   23 +-
 javadoc/org/apache/iceberg/view/ViewVersion.html   |   74 +-
 .../analysis/NoSuchProcedureException.html         |    2 +-
 .../sql/connector/iceberg/catalog/Procedure.html   |    2 +-
 .../connector/iceberg/catalog/package-summary.html |    4 +-
 .../connector/iceberg/catalog/package-tree.html    |    4 +-
 .../connector/iceberg/write/DeltaBatchWrite.html   |  235 --
 .../sql/connector/iceberg/write/DeltaWrite.html    |  238 --
 .../sql/connector/iceberg/write/DeltaWriter.html   |  331 ---
 .../iceberg/write/DeltaWriterFactory.html          |  230 --
 .../iceberg/write/ExtendedLogicalWriteInfo.html    |  250 --
 .../sql/connector/iceberg/write/SupportsDelta.html |  267 --
 .../sql/connector/iceberg/write/package-frame.html |   25 -
 .../connector/iceberg/write/package-summary.html   |  177 --
 .../sql/connector/iceberg/write/package-tree.html  |  176 --
 javadoc/overview-frame.html                        |    3 +-
 javadoc/overview-summary.html                      |   66 +-
 javadoc/overview-tree.html                         |  123 +-
 javadoc/package-list                               |    3 +-
 javadoc/serialized-form.html                       | 1096 ++++++---
 327 files changed, 17753 insertions(+), 11302 deletions(-)

diff --git a/javadoc/allclasses-frame.html b/javadoc/allclasses-frame.html
index 2e1f8acf..2ae90ff5 100644
--- a/javadoc/allclasses-frame.html
+++ b/javadoc/allclasses-frame.html
@@ -62,6 +62,7 @@
 <li><a href="org/apache/iceberg/spark/data/AvroWithSparkSchemaVisitor.html" title="class in org.apache.iceberg.spark.data" target="classFrame">AvroWithSparkSchemaVisitor</a></li>
 <li><a href="org/apache/iceberg/aws/AwsClientFactories.html" title="class in org.apache.iceberg.aws" target="classFrame">AwsClientFactories</a></li>
 <li><a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws" target="classFrame"><span class="interfaceName">AwsClientFactory</span></a></li>
+<li><a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws" target="classFrame">AwsClientProperties</a></li>
 <li><a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws" target="classFrame">AwsProperties</a></li>
 <li><a href="org/apache/iceberg/exceptions/BadRequestException.html" title="class in org.apache.iceberg.exceptions" target="classFrame">BadRequestException</a></li>
 <li><a href="org/apache/iceberg/arrow/vectorized/BaseBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized" target="classFrame">BaseBatchReader</a></li>
@@ -69,7 +70,6 @@
 <li><a href="org/apache/iceberg/BaseCombinedScanTask.html" title="class in org.apache.iceberg" target="classFrame">BaseCombinedScanTask</a></li>
 <li><a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html" title="class in org.apache.iceberg.actions" target="classFrame">BaseDeleteOrphanFilesActionResult</a></li>
 <li><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions" target="classFrame">BaseDeleteReachableFilesActionResult</a></li>
-<li><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions" target="classFrame">BaseExpireSnapshotsActionResult</a></li>
 <li><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions" target="classFrame">BaseFileGroupRewriteResult</a></li>
 <li><a href="org/apache/iceberg/BaseFileScanTask.html" title="class in org.apache.iceberg" target="classFrame">BaseFileScanTask</a></li>
 <li><a href="org/apache/iceberg/data/BaseFileWriterFactory.html" title="class in org.apache.iceberg.data" target="classFrame">BaseFileWriterFactory</a></li>
@@ -178,6 +178,7 @@
 <li><a href="org/apache/iceberg/metrics/CommitReportParser.html" title="class in org.apache.iceberg.metrics" target="classFrame">CommitReportParser</a></li>
 <li><a href="org/apache/iceberg/exceptions/CommitStateUnknownException.html" title="class in org.apache.iceberg.exceptions" target="classFrame">CommitStateUnknownException</a></li>
 <li><a href="org/apache/iceberg/types/Comparators.html" title="class in org.apache.iceberg.types" target="classFrame">Comparators</a></li>
+<li><a href="org/apache/iceberg/spark/ComputeUpdateIterator.html" title="class in org.apache.iceberg.spark" target="classFrame">ComputeUpdateIterator</a></li>
 <li><a href="org/apache/iceberg/hadoop/ConfigProperties.html" title="class in org.apache.iceberg.hadoop" target="classFrame">ConfigProperties</a></li>
 <li><a href="org/apache/iceberg/rest/responses/ConfigResponse.html" title="class in org.apache.iceberg.rest.responses" target="classFrame">ConfigResponse</a></li>
 <li><a href="org/apache/iceberg/rest/responses/ConfigResponse.Builder.html" title="class in org.apache.iceberg.rest.responses" target="classFrame">ConfigResponse.Builder</a></li>
@@ -227,6 +228,7 @@
 <li><a href="org/apache/iceberg/transforms/Days.html" title="class in org.apache.iceberg.transforms" target="classFrame">Days</a></li>
 <li><a href="org/apache/iceberg/spark/functions/DaysFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">DaysFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">DaysFunction.DateToDaysFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">DaysFunction.TimestampNtzToDaysFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">DaysFunction.TimestampToDaysFunction</a></li>
 <li><a href="org/apache/iceberg/util/DecimalUtil.html" title="class in org.apache.iceberg.util" target="classFrame">DecimalUtil</a></li>
 <li><a href="org/apache/iceberg/arrow/vectorized/parquet/DecimalVectorUtil.html" title="class in org.apache.iceberg.arrow.vectorized.parquet" target="classFrame">DecimalVectorUtil</a></li>
@@ -259,13 +261,9 @@
 <li><a href="org/apache/iceberg/dell/DellClientFactories.html" title="class in org.apache.iceberg.dell" target="classFrame">DellClientFactories</a></li>
 <li><a href="org/apache/iceberg/dell/DellClientFactory.html" title="interface in org.apache.iceberg.dell" target="classFrame"><span class="interfaceName">DellClientFactory</span></a></li>
 <li><a href="org/apache/iceberg/dell/DellProperties.html" title="class in org.apache.iceberg.dell" target="classFrame">DellProperties</a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaBatchWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">DeltaBatchWrite</span></a></li>
 <li><a href="org/apache/iceberg/delta/DeltaLakeToIcebergMigrationActionsProvider.html" title="interface in org.apache.iceberg.delta" target="classFrame"><span class="interfaceName">DeltaLakeToIcebergMigrationActionsProvider</span></a></li>
 <li><a href="org/apache/iceberg/delta/DeltaLakeToIcebergMigrationActionsProvider.DefaultDeltaLakeToIcebergMigrationActions.html" title="class in org.apache.iceberg.delta" target="classFrame">DeltaLakeToIcebergMigrationActionsProvider.DefaultDeltaLakeToIcebergMigrationActions</a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">DeltaWrite</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriteBuilder.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">DeltaWriteBuilder</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">DeltaWriter</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriterFactory.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">DeltaWriterFactory</span></a></li>
+<li><a href="org/apache/iceberg/arrow/DictEncodedArrowConverter.html" title="class in org.apache.iceberg.arrow" target="classFrame">DictEncodedArrowConverter</a></li>
 <li><a href="org/apache/iceberg/DistributionMode.html" title="enum in org.apache.iceberg" target="classFrame">DistributionMode</a></li>
 <li><a href="org/apache/iceberg/DoubleFieldMetrics.html" title="class in org.apache.iceberg" target="classFrame">DoubleFieldMetrics</a></li>
 <li><a href="org/apache/iceberg/DoubleFieldMetrics.Builder.html" title="class in org.apache.iceberg" target="classFrame">DoubleFieldMetrics.Builder</a></li>
@@ -329,7 +327,6 @@
 <li><a href="org/apache/iceberg/expressions/ExpressionVisitors.BoundVisitor.html" title="class in org.apache.iceberg.expressions" target="classFrame">ExpressionVisitors.BoundVisitor</a></li>
 <li><a href="org/apache/iceberg/expressions/ExpressionVisitors.CustomOrderExpressionVisitor.html" title="class in org.apache.iceberg.expressions" target="classFrame">ExpressionVisitors.CustomOrderExpressionVisitor</a></li>
 <li><a href="org/apache/iceberg/expressions/ExpressionVisitors.ExpressionVisitor.html" title="class in org.apache.iceberg.expressions" target="classFrame">ExpressionVisitors.ExpressionVisitor</a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">ExtendedLogicalWriteInfo</span></a></li>
 <li><a href="org/apache/iceberg/spark/ExtendedParser.html" title="interface in org.apache.iceberg.spark" target="classFrame"><span class="interfaceName">ExtendedParser</span></a></li>
 <li><a href="org/apache/iceberg/spark/ExtendedParser.RawOrderField.html" title="class in org.apache.iceberg.spark" target="classFrame">ExtendedParser.RawOrderField</a></li>
 <li><a href="org/apache/iceberg/expressions/False.html" title="class in org.apache.iceberg.expressions" target="classFrame">False</a></li>
@@ -349,10 +346,10 @@
 <li><a href="org/apache/iceberg/FileMetadata.Builder.html" title="class in org.apache.iceberg" target="classFrame">FileMetadata.Builder</a></li>
 <li><a href="org/apache/iceberg/puffin/FileMetadataParser.html" title="class in org.apache.iceberg.puffin" target="classFrame">FileMetadataParser</a></li>
 <li><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark" target="classFrame">FileRewriteCoordinator</a></li>
+<li><a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">FileRewriter</span></a></li>
 <li><a href="org/apache/iceberg/Files.html" title="class in org.apache.iceberg" target="classFrame">Files</a></li>
 <li><a href="org/apache/iceberg/FileScanTask.html" title="interface in org.apache.iceberg" target="classFrame"><span class="interfaceName">FileScanTask</span></a></li>
 <li><a href="org/apache/iceberg/flink/source/FileScanTaskReader.html" title="interface in org.apache.iceberg.flink.source" target="classFrame"><span class="interfaceName">FileScanTaskReader</span></a></li>
-<li><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark" target="classFrame">FileScanTaskSetManager</a></li>
 <li><a href="org/apache/iceberg/FilesTable.html" title="class in org.apache.iceberg" target="classFrame">FilesTable</a></li>
 <li><a href="org/apache/iceberg/FilesTable.FilesTableScan.html" title="class in org.apache.iceberg" target="classFrame">FilesTable.FilesTableScan</a></li>
 <li><a href="org/apache/iceberg/io/FileWriter.html" title="interface in org.apache.iceberg.io" target="classFrame"><span class="interfaceName">FileWriter</span></a></li>
@@ -386,6 +383,7 @@
 <li><a href="org/apache/iceberg/flink/sink/FlinkSink.Builder.html" title="class in org.apache.iceberg.flink.sink" target="classFrame">FlinkSink.Builder</a></li>
 <li><a href="org/apache/iceberg/flink/source/FlinkSource.html" title="class in org.apache.iceberg.flink.source" target="classFrame">FlinkSource</a></li>
 <li><a href="org/apache/iceberg/flink/source/FlinkSource.Builder.html" title="class in org.apache.iceberg.flink.source" target="classFrame">FlinkSource.Builder</a></li>
+<li><a href="org/apache/iceberg/flink/FlinkSourceFilter.html" title="class in org.apache.iceberg.flink" target="classFrame">FlinkSourceFilter</a></li>
 <li><a href="org/apache/iceberg/flink/source/FlinkSplitPlanner.html" title="class in org.apache.iceberg.flink.source" target="classFrame">FlinkSplitPlanner</a></li>
 <li><a href="org/apache/iceberg/flink/FlinkTypeVisitor.html" title="class in org.apache.iceberg.flink" target="classFrame">FlinkTypeVisitor</a></li>
 <li><a href="org/apache/iceberg/flink/data/FlinkValueReaders.html" title="class in org.apache.iceberg.flink.data" target="classFrame">FlinkValueReaders</a></li>
@@ -455,9 +453,11 @@
 <li><a href="org/apache/iceberg/hive/HiveVersion.html" title="enum in org.apache.iceberg.hive" target="classFrame">HiveVersion</a></li>
 <li><a href="org/apache/iceberg/transforms/Hours.html" title="class in org.apache.iceberg.transforms" target="classFrame">Hours</a></li>
 <li><a href="org/apache/iceberg/spark/functions/HoursFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">HoursFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">HoursFunction.TimestampNtzToHoursFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">HoursFunction.TimestampToHoursFunction</a></li>
 <li><a href="org/apache/iceberg/rest/HTTPClient.html" title="class in org.apache.iceberg.rest" target="classFrame">HTTPClient</a></li>
 <li><a href="org/apache/iceberg/rest/HTTPClient.Builder.html" title="class in org.apache.iceberg.rest" target="classFrame">HTTPClient.Builder</a></li>
+<li><a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws" target="classFrame">HttpClientProperties</a></li>
 <li><a href="org/apache/iceberg/spark/data/vectorized/IcebergArrowColumnVector.html" title="class in org.apache.iceberg.spark.data.vectorized" target="classFrame">IcebergArrowColumnVector</a></li>
 <li><a href="org/apache/iceberg/mr/hive/serde/objectinspector/IcebergBinaryObjectInspector.html" title="class in org.apache.iceberg.mr.hive.serde.objectinspector" target="classFrame">IcebergBinaryObjectInspector</a></li>
 <li><a href="org/apache/iceberg/IcebergBuild.html" title="class in org.apache.iceberg" target="classFrame">IcebergBuild</a></li>
@@ -571,6 +571,10 @@
 <li><a href="org/apache/iceberg/events/IncrementalScanEvent.html" title="class in org.apache.iceberg.events" target="classFrame">IncrementalScanEvent</a></li>
 <li><a href="org/apache/iceberg/types/IndexByName.html" title="class in org.apache.iceberg.types" target="classFrame">IndexByName</a></li>
 <li><a href="org/apache/iceberg/types/IndexParents.html" title="class in org.apache.iceberg.types" target="classFrame">IndexParents</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory" target="classFrame">InMemoryCatalog</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory" target="classFrame">InMemoryFileIO</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory" target="classFrame">InMemoryInputFile</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory" target="classFrame">InMemoryOutputFile</a></li>
 <li><a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io" target="classFrame"><span class="interfaceName">InputFile</span></a></li>
 <li><a href="org/apache/iceberg/encryption/InputFilesDecryptor.html" title="class in org.apache.iceberg.encryption" target="classFrame">InputFilesDecryptor</a></li>
 <li><a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr" target="classFrame">InputFormatConfig</a></li>
@@ -667,6 +671,7 @@
 <li><a href="org/apache/iceberg/MetricsModes.Truncate.html" title="class in org.apache.iceberg" target="classFrame">MetricsModes.Truncate</a></li>
 <li><a href="org/apache/iceberg/metrics/MetricsReport.html" title="interface in org.apache.iceberg.metrics" target="classFrame"><span class="interfaceName">MetricsReport</span></a></li>
 <li><a href="org/apache/iceberg/metrics/MetricsReporter.html" title="interface in org.apache.iceberg.metrics" target="classFrame"><span class="interfaceName">MetricsReporter</span></a></li>
+<li><a href="org/apache/iceberg/metrics/MetricsReporters.html" title="class in org.apache.iceberg.metrics" target="classFrame">MetricsReporters</a></li>
 <li><a href="org/apache/iceberg/MetricsUtil.html" title="class in org.apache.iceberg" target="classFrame">MetricsUtil</a></li>
 <li><a href="org/apache/iceberg/MetricsUtil.ReadableColMetricsStruct.html" title="class in org.apache.iceberg" target="classFrame">MetricsUtil.ReadableColMetricsStruct</a></li>
 <li><a href="org/apache/iceberg/MetricsUtil.ReadableMetricColDefinition.html" title="class in org.apache.iceberg" target="classFrame">MetricsUtil.ReadableMetricColDefinition</a></li>
@@ -683,6 +688,7 @@
 <li><a href="org/apache/iceberg/transforms/Months.html" title="class in org.apache.iceberg.transforms" target="classFrame">Months</a></li>
 <li><a href="org/apache/iceberg/spark/functions/MonthsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">MonthsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">MonthsFunction.DateToMonthsFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">MonthsFunction.TimestampNtzToMonthsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">MonthsFunction.TimestampToMonthsFunction</a></li>
 <li><a href="org/apache/iceberg/expressions/NamedReference.html" title="class in org.apache.iceberg.expressions" target="classFrame">NamedReference</a></li>
 <li><a href="org/apache/iceberg/mapping/NameMapping.html" title="class in org.apache.iceberg.mapping" target="classFrame">NameMapping</a></li>
@@ -697,6 +703,7 @@
 <li><a href="org/apache/iceberg/nessie/NessieIcebergClient.html" title="class in org.apache.iceberg.nessie" target="classFrame">NessieIcebergClient</a></li>
 <li><a href="org/apache/iceberg/nessie/NessieTableOperations.html" title="class in org.apache.iceberg.nessie" target="classFrame">NessieTableOperations</a></li>
 <li><a href="org/apache/iceberg/nessie/NessieUtil.html" title="class in org.apache.iceberg.nessie" target="classFrame">NessieUtil</a></li>
+<li><a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive" target="classFrame">NoLock</a></li>
 <li><a href="org/apache/iceberg/exceptions/NoSuchIcebergTableException.html" title="class in org.apache.iceberg.exceptions" target="classFrame">NoSuchIcebergTableException</a></li>
 <li><a href="org/apache/iceberg/exceptions/NoSuchNamespaceException.html" title="class in org.apache.iceberg.exceptions" target="classFrame">NoSuchNamespaceException</a></li>
 <li><a href="org/apache/spark/sql/catalyst/analysis/NoSuchProcedureException.html" title="class in org.apache.spark.sql.catalyst.analysis" target="classFrame">NoSuchProcedureException</a></li>
@@ -812,6 +819,7 @@
 <li><a href="org/apache/iceberg/encryption/PlaintextEncryptionManager.html" title="class in org.apache.iceberg.encryption" target="classFrame">PlaintextEncryptionManager</a></li>
 <li><a href="org/apache/iceberg/deletes/PositionDelete.html" title="class in org.apache.iceberg.deletes" target="classFrame">PositionDelete</a></li>
 <li><a href="org/apache/iceberg/deletes/PositionDeleteIndex.html" title="interface in org.apache.iceberg.deletes" target="classFrame"><span class="interfaceName">PositionDeleteIndex</span></a></li>
+<li><a href="org/apache/iceberg/spark/PositionDeletesRewriteCoordinator.html" title="class in org.apache.iceberg.spark" target="classFrame">PositionDeletesRewriteCoordinator</a></li>
 <li><a href="org/apache/iceberg/PositionDeletesScanTask.html" title="interface in org.apache.iceberg" target="classFrame"><span class="interfaceName">PositionDeletesScanTask</span></a></li>
 <li><a href="org/apache/iceberg/PositionDeletesTable.html" title="class in org.apache.iceberg" target="classFrame">PositionDeletesTable</a></li>
 <li><a href="org/apache/iceberg/PositionDeletesTable.PositionDeletesBatchScan.html" title="class in org.apache.iceberg" target="classFrame">PositionDeletesTable.PositionDeletesBatchScan</a></li>
@@ -887,7 +895,9 @@
 <li><a href="org/apache/iceberg/rest/RESTSessionCatalog.html" title="class in org.apache.iceberg.rest" target="classFrame">RESTSessionCatalog</a></li>
 <li><a href="org/apache/iceberg/aws/RESTSigV4Signer.html" title="class in org.apache.iceberg.aws" target="classFrame">RESTSigV4Signer</a></li>
 <li><a href="org/apache/iceberg/rest/RESTUtil.html" title="class in org.apache.iceberg.rest" target="classFrame">RESTUtil</a></li>
+<li><a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util" target="classFrame">RetryDetector</a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteDataFiles</span></a></li>
+<li><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteDataFiles.FileGroupFailureResult</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteDataFiles.FileGroupInfo</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteDataFiles.FileGroupRewriteResult</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteDataFiles.Result</span></a></li>
@@ -903,7 +913,13 @@
 <li><a href="org/apache/iceberg/actions/RewriteManifests.Result.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteManifests.Result</span></a></li>
 <li><a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html" title="class in org.apache.iceberg.spark.actions" target="classFrame">RewriteManifestsSparkAction</a></li>
 <li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewritePositionDeleteFiles</span></a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewritePositionDeleteFiles.FileGroupInfo</span></a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewritePositionDeleteFiles.FileGroupRewriteResult</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewritePositionDeleteFiles.Result</span></a></li>
+<li><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures" target="classFrame">RewritePositionDeleteFilesProcedure</a></li>
+<li><a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions" target="classFrame">RewritePositionDeleteFilesSparkAction</a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions" target="classFrame">RewritePositionDeletesCommitManager</a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions" target="classFrame">RewritePositionDeletesGroup</a></li>
 <li><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewritePositionDeleteStrategy</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions" target="classFrame"><span class="interfaceName">RewriteStrategy</span></a></li>
 <li><a href="org/apache/iceberg/spark/RollbackStagedTable.html" title="class in org.apache.iceberg.spark" target="classFrame">RollbackStagedTable</a></li>
@@ -925,6 +941,9 @@
 <li><a href="org/apache/iceberg/exceptions/RuntimeIOException.html" title="class in org.apache.iceberg.exceptions" target="classFrame">RuntimeIOException</a></li>
 <li><a href="org/apache/iceberg/hive/RuntimeMetaException.html" title="class in org.apache.iceberg.hive" target="classFrame">RuntimeMetaException</a></li>
 <li><a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3" target="classFrame">S3FileIO</a></li>
+<li><a href="org/apache/iceberg/aws/S3FileIOAwsClientFactories.html" title="class in org.apache.iceberg.aws" target="classFrame">S3FileIOAwsClientFactories</a></li>
+<li><a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html" title="interface in org.apache.iceberg.aws.s3" target="classFrame"><span class="interfaceName">S3FileIOAwsClientFactory</span></a></li>
+<li><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3" target="classFrame">S3FileIOProperties</a></li>
 <li><a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3" target="classFrame">S3InputFile</a></li>
 <li><a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.html" title="class in org.apache.iceberg.aws.s3.signer" target="classFrame">S3ObjectMapper</a></li>
 <li><a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.S3SignRequestDeserializer.html" title="class in org.apache.iceberg.aws.s3.signer" target="classFrame">S3ObjectMapper.S3SignRequestDeserializer</a></li>
@@ -977,6 +996,9 @@
 <li><a href="org/apache/iceberg/flink/source/assigner/SimpleSplitAssigner.html" title="class in org.apache.iceberg.flink.source.assigner" target="classFrame">SimpleSplitAssigner</a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SimpleSplitAssignerFactory.html" title="class in org.apache.iceberg.flink.source.assigner" target="classFrame">SimpleSplitAssignerFactory</a></li>
 <li><a href="org/apache/iceberg/SingleValueParser.html" title="class in org.apache.iceberg" target="classFrame">SingleValueParser</a></li>
+<li><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions" target="classFrame">SizeBasedDataRewriter</a></li>
+<li><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions" target="classFrame">SizeBasedFileRewriter</a></li>
+<li><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions" target="classFrame">SizeBasedPositionDeletesRewriter</a></li>
 <li><a href="org/apache/iceberg/Snapshot.html" title="interface in org.apache.iceberg" target="classFrame"><span class="interfaceName">Snapshot</span></a></li>
 <li><a href="org/apache/iceberg/delta/SnapshotDeltaLakeTable.html" title="interface in org.apache.iceberg.delta" target="classFrame"><span class="interfaceName">SnapshotDeltaLakeTable</span></a></li>
 <li><a href="org/apache/iceberg/delta/SnapshotDeltaLakeTable.Result.html" title="interface in org.apache.iceberg.delta" target="classFrame"><span class="interfaceName">SnapshotDeltaLakeTable.Result</span></a></li>
@@ -1015,14 +1037,13 @@
 <li><a href="org/apache/iceberg/spark/SparkAggregates.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkAggregates</a></li>
 <li><a href="org/apache/iceberg/spark/data/SparkAvroReader.html" title="class in org.apache.iceberg.spark.data" target="classFrame">SparkAvroReader</a></li>
 <li><a href="org/apache/iceberg/spark/data/SparkAvroWriter.html" title="class in org.apache.iceberg.spark.data" target="classFrame">SparkAvroWriter</a></li>
-<li><a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html" title="class in org.apache.iceberg.spark.actions" target="classFrame">SparkBinPackStrategy</a></li>
 <li><a href="org/apache/iceberg/spark/SparkCachedTableCatalog.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkCachedTableCatalog</a></li>
 <li><a href="org/apache/iceberg/spark/SparkCatalog.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkCatalog</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkChangelogTable.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkChangelogTable</a></li>
 <li><a href="org/apache/iceberg/spark/SparkDataFile.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkDataFile</a></li>
-<li><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkDistributionAndOrderingUtil</a></li>
 <li><a href="org/apache/iceberg/spark/SparkExceptionUtil.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkExceptionUtil</a></li>
 <li><a href="org/apache/iceberg/spark/SparkFilters.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkFilters</a></li>
+<li><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkFunctionCatalog</a></li>
 <li><a href="org/apache/iceberg/spark/functions/SparkFunctions.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">SparkFunctions</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkMetadataColumn.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkMetadataColumn</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkMicroBatchStream</a></li>
@@ -1033,6 +1054,9 @@
 <li><a href="org/apache/iceberg/spark/data/SparkParquetWriters.html" title="class in org.apache.iceberg.spark.data" target="classFrame">SparkParquetWriters</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkPartitionedFanoutWriter.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkPartitionedFanoutWriter</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkPartitionedWriter.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkPartitionedWriter</a></li>
+<li><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkPositionDeletesRewrite</a></li>
+<li><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.DeleteTaskCommit.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkPositionDeletesRewrite.DeleteTaskCommit</a></li>
+<li><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewriteBuilder.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkPositionDeletesRewriteBuilder</a></li>
 <li><a href="org/apache/iceberg/spark/procedures/SparkProcedures.html" title="class in org.apache.iceberg.spark.procedures" target="classFrame">SparkProcedures</a></li>
 <li><a href="org/apache/iceberg/spark/procedures/SparkProcedures.ProcedureBuilder.html" title="interface in org.apache.iceberg.spark.procedures" target="classFrame"><span class="interfaceName">SparkProcedures.ProcedureBuilder</span></a></li>
 <li><a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkReadConf</a></li>
@@ -1040,7 +1064,6 @@
 <li><a href="org/apache/iceberg/spark/source/SparkScanBuilder.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkScanBuilder</a></li>
 <li><a href="org/apache/iceberg/spark/SparkSchemaUtil.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkSchemaUtil</a></li>
 <li><a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkSessionCatalog</a></li>
-<li><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions" target="classFrame">SparkSortStrategy</a></li>
 <li><a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkSQLProperties</a></li>
 <li><a href="org/apache/iceberg/spark/SparkStructLike.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkStructLike</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source" target="classFrame">SparkTable</a></li>
@@ -1054,7 +1077,8 @@
 <li><a href="org/apache/iceberg/spark/data/SparkValueWriters.html" title="class in org.apache.iceberg.spark.data" target="classFrame">SparkValueWriters</a></li>
 <li><a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkWriteConf</a></li>
 <li><a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkWriteOptions</a></li>
-<li><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions" target="classFrame">SparkZOrderStrategy</a></li>
+<li><a href="org/apache/iceberg/spark/SparkWriteRequirements.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkWriteRequirements</a></li>
+<li><a href="org/apache/iceberg/spark/SparkWriteUtil.html" title="class in org.apache.iceberg.spark" target="classFrame">SparkWriteUtil</a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SplitAssigner.html" title="interface in org.apache.iceberg.flink.source.assigner" target="classFrame"><span class="interfaceName">SplitAssigner</span></a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SplitAssignerFactory.html" title="interface in org.apache.iceberg.flink.source.assigner" target="classFrame"><span class="interfaceName">SplitAssignerFactory</span></a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SplitAssignerType.html" title="enum in org.apache.iceberg.flink.source.assigner" target="classFrame">SplitAssignerType</a></li>
@@ -1080,7 +1104,6 @@
 <li><a href="org/apache/iceberg/util/StructProjection.html" title="class in org.apache.iceberg.util" target="classFrame">StructProjection</a></li>
 <li><a href="org/apache/iceberg/flink/data/StructRowData.html" title="class in org.apache.iceberg.flink.data" target="classFrame">StructRowData</a></li>
 <li><a href="org/apache/iceberg/io/SupportsBulkOperations.html" title="interface in org.apache.iceberg.io" target="classFrame"><span class="interfaceName">SupportsBulkOperations</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html" title="interface in org.apache.spark.sql.connector.iceberg.write" target="classFrame"><span class="interfaceName">SupportsDelta</span></a></li>
 <li><a href="org/apache/iceberg/catalog/SupportsNamespaces.html" title="interface in org.apache.iceberg.catalog" target="classFrame"><span class="interfaceName">SupportsNamespaces</span></a></li>
 <li><a href="org/apache/iceberg/io/SupportsPrefixOperations.html" title="interface in org.apache.iceberg.io" target="classFrame"><span class="interfaceName">SupportsPrefixOperations</span></a></li>
 <li><a href="org/apache/iceberg/avro/SupportsRowPosition.html" title="interface in org.apache.iceberg.avro" target="classFrame"><span class="interfaceName">SupportsRowPosition</span></a></li>
@@ -1243,6 +1266,7 @@
 <li><a href="org/apache/iceberg/io/WriteResult.Builder.html" title="class in org.apache.iceberg.io" target="classFrame">WriteResult.Builder</a></li>
 <li><a href="org/apache/iceberg/spark/functions/YearsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">YearsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">YearsFunction.DateToYearsFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">YearsFunction.TimestampNtzToYearsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions" target="classFrame">YearsFunction.TimestampToYearsFunction</a></li>
 <li><a href="org/apache/iceberg/expressions/Zorder.html" title="class in org.apache.iceberg.expressions" target="classFrame">Zorder</a></li>
 <li><a href="org/apache/iceberg/util/ZOrderByteUtils.html" title="class in org.apache.iceberg.util" target="classFrame">ZOrderByteUtils</a></li>
diff --git a/javadoc/allclasses-noframe.html b/javadoc/allclasses-noframe.html
index 3f986a4f..829ccda1 100644
--- a/javadoc/allclasses-noframe.html
+++ b/javadoc/allclasses-noframe.html
@@ -62,6 +62,7 @@
 <li><a href="org/apache/iceberg/spark/data/AvroWithSparkSchemaVisitor.html" title="class in org.apache.iceberg.spark.data">AvroWithSparkSchemaVisitor</a></li>
 <li><a href="org/apache/iceberg/aws/AwsClientFactories.html" title="class in org.apache.iceberg.aws">AwsClientFactories</a></li>
 <li><a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><span class="interfaceName">AwsClientFactory</span></a></li>
+<li><a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></li>
 <li><a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></li>
 <li><a href="org/apache/iceberg/exceptions/BadRequestException.html" title="class in org.apache.iceberg.exceptions">BadRequestException</a></li>
 <li><a href="org/apache/iceberg/arrow/vectorized/BaseBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized">BaseBatchReader</a></li>
@@ -69,7 +70,6 @@
 <li><a href="org/apache/iceberg/BaseCombinedScanTask.html" title="class in org.apache.iceberg">BaseCombinedScanTask</a></li>
 <li><a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteOrphanFilesActionResult</a></li>
 <li><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></li>
-<li><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></li>
 <li><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></li>
 <li><a href="org/apache/iceberg/BaseFileScanTask.html" title="class in org.apache.iceberg">BaseFileScanTask</a></li>
 <li><a href="org/apache/iceberg/data/BaseFileWriterFactory.html" title="class in org.apache.iceberg.data">BaseFileWriterFactory</a></li>
@@ -178,6 +178,7 @@
 <li><a href="org/apache/iceberg/metrics/CommitReportParser.html" title="class in org.apache.iceberg.metrics">CommitReportParser</a></li>
 <li><a href="org/apache/iceberg/exceptions/CommitStateUnknownException.html" title="class in org.apache.iceberg.exceptions">CommitStateUnknownException</a></li>
 <li><a href="org/apache/iceberg/types/Comparators.html" title="class in org.apache.iceberg.types">Comparators</a></li>
+<li><a href="org/apache/iceberg/spark/ComputeUpdateIterator.html" title="class in org.apache.iceberg.spark">ComputeUpdateIterator</a></li>
 <li><a href="org/apache/iceberg/hadoop/ConfigProperties.html" title="class in org.apache.iceberg.hadoop">ConfigProperties</a></li>
 <li><a href="org/apache/iceberg/rest/responses/ConfigResponse.html" title="class in org.apache.iceberg.rest.responses">ConfigResponse</a></li>
 <li><a href="org/apache/iceberg/rest/responses/ConfigResponse.Builder.html" title="class in org.apache.iceberg.rest.responses">ConfigResponse.Builder</a></li>
@@ -227,6 +228,7 @@
 <li><a href="org/apache/iceberg/transforms/Days.html" title="class in org.apache.iceberg.transforms">Days</a></li>
 <li><a href="org/apache/iceberg/spark/functions/DaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.DateToDaysFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampNtzToDaysFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampToDaysFunction</a></li>
 <li><a href="org/apache/iceberg/util/DecimalUtil.html" title="class in org.apache.iceberg.util">DecimalUtil</a></li>
 <li><a href="org/apache/iceberg/arrow/vectorized/parquet/DecimalVectorUtil.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">DecimalVectorUtil</a></li>
@@ -259,13 +261,9 @@
 <li><a href="org/apache/iceberg/dell/DellClientFactories.html" title="class in org.apache.iceberg.dell">DellClientFactories</a></li>
 <li><a href="org/apache/iceberg/dell/DellClientFactory.html" title="interface in org.apache.iceberg.dell"><span class="interfaceName">DellClientFactory</span></a></li>
 <li><a href="org/apache/iceberg/dell/DellProperties.html" title="class in org.apache.iceberg.dell">DellProperties</a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaBatchWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">DeltaBatchWrite</span></a></li>
 <li><a href="org/apache/iceberg/delta/DeltaLakeToIcebergMigrationActionsProvider.html" title="interface in org.apache.iceberg.delta"><span class="interfaceName">DeltaLakeToIcebergMigrationActionsProvider</span></a></li>
 <li><a href="org/apache/iceberg/delta/DeltaLakeToIcebergMigrationActionsProvider.DefaultDeltaLakeToIcebergMigrationActions.html" title="class in org.apache.iceberg.delta">DeltaLakeToIcebergMigrationActionsProvider.DefaultDeltaLakeToIcebergMigrationActions</a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">DeltaWrite</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriteBuilder.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">DeltaWriteBuilder</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">DeltaWriter</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriterFactory.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">DeltaWriterFactory</span></a></li>
+<li><a href="org/apache/iceberg/arrow/DictEncodedArrowConverter.html" title="class in org.apache.iceberg.arrow">DictEncodedArrowConverter</a></li>
 <li><a href="org/apache/iceberg/DistributionMode.html" title="enum in org.apache.iceberg">DistributionMode</a></li>
 <li><a href="org/apache/iceberg/DoubleFieldMetrics.html" title="class in org.apache.iceberg">DoubleFieldMetrics</a></li>
 <li><a href="org/apache/iceberg/DoubleFieldMetrics.Builder.html" title="class in org.apache.iceberg">DoubleFieldMetrics.Builder</a></li>
@@ -329,7 +327,6 @@
 <li><a href="org/apache/iceberg/expressions/ExpressionVisitors.BoundVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.BoundVisitor</a></li>
 <li><a href="org/apache/iceberg/expressions/ExpressionVisitors.CustomOrderExpressionVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.CustomOrderExpressionVisitor</a></li>
 <li><a href="org/apache/iceberg/expressions/ExpressionVisitors.ExpressionVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.ExpressionVisitor</a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">ExtendedLogicalWriteInfo</span></a></li>
 <li><a href="org/apache/iceberg/spark/ExtendedParser.html" title="interface in org.apache.iceberg.spark"><span class="interfaceName">ExtendedParser</span></a></li>
 <li><a href="org/apache/iceberg/spark/ExtendedParser.RawOrderField.html" title="class in org.apache.iceberg.spark">ExtendedParser.RawOrderField</a></li>
 <li><a href="org/apache/iceberg/expressions/False.html" title="class in org.apache.iceberg.expressions">False</a></li>
@@ -349,10 +346,10 @@
 <li><a href="org/apache/iceberg/FileMetadata.Builder.html" title="class in org.apache.iceberg">FileMetadata.Builder</a></li>
 <li><a href="org/apache/iceberg/puffin/FileMetadataParser.html" title="class in org.apache.iceberg.puffin">FileMetadataParser</a></li>
 <li><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark">FileRewriteCoordinator</a></li>
+<li><a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">FileRewriter</span></a></li>
 <li><a href="org/apache/iceberg/Files.html" title="class in org.apache.iceberg">Files</a></li>
 <li><a href="org/apache/iceberg/FileScanTask.html" title="interface in org.apache.iceberg"><span class="interfaceName">FileScanTask</span></a></li>
 <li><a href="org/apache/iceberg/flink/source/FileScanTaskReader.html" title="interface in org.apache.iceberg.flink.source"><span class="interfaceName">FileScanTaskReader</span></a></li>
-<li><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">FileScanTaskSetManager</a></li>
 <li><a href="org/apache/iceberg/FilesTable.html" title="class in org.apache.iceberg">FilesTable</a></li>
 <li><a href="org/apache/iceberg/FilesTable.FilesTableScan.html" title="class in org.apache.iceberg">FilesTable.FilesTableScan</a></li>
 <li><a href="org/apache/iceberg/io/FileWriter.html" title="interface in org.apache.iceberg.io"><span class="interfaceName">FileWriter</span></a></li>
@@ -386,6 +383,7 @@
 <li><a href="org/apache/iceberg/flink/sink/FlinkSink.Builder.html" title="class in org.apache.iceberg.flink.sink">FlinkSink.Builder</a></li>
 <li><a href="org/apache/iceberg/flink/source/FlinkSource.html" title="class in org.apache.iceberg.flink.source">FlinkSource</a></li>
 <li><a href="org/apache/iceberg/flink/source/FlinkSource.Builder.html" title="class in org.apache.iceberg.flink.source">FlinkSource.Builder</a></li>
+<li><a href="org/apache/iceberg/flink/FlinkSourceFilter.html" title="class in org.apache.iceberg.flink">FlinkSourceFilter</a></li>
 <li><a href="org/apache/iceberg/flink/source/FlinkSplitPlanner.html" title="class in org.apache.iceberg.flink.source">FlinkSplitPlanner</a></li>
 <li><a href="org/apache/iceberg/flink/FlinkTypeVisitor.html" title="class in org.apache.iceberg.flink">FlinkTypeVisitor</a></li>
 <li><a href="org/apache/iceberg/flink/data/FlinkValueReaders.html" title="class in org.apache.iceberg.flink.data">FlinkValueReaders</a></li>
@@ -455,9 +453,11 @@
 <li><a href="org/apache/iceberg/hive/HiveVersion.html" title="enum in org.apache.iceberg.hive">HiveVersion</a></li>
 <li><a href="org/apache/iceberg/transforms/Hours.html" title="class in org.apache.iceberg.transforms">Hours</a></li>
 <li><a href="org/apache/iceberg/spark/functions/HoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></li>
 <li><a href="org/apache/iceberg/rest/HTTPClient.html" title="class in org.apache.iceberg.rest">HTTPClient</a></li>
 <li><a href="org/apache/iceberg/rest/HTTPClient.Builder.html" title="class in org.apache.iceberg.rest">HTTPClient.Builder</a></li>
+<li><a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></li>
 <li><a href="org/apache/iceberg/spark/data/vectorized/IcebergArrowColumnVector.html" title="class in org.apache.iceberg.spark.data.vectorized">IcebergArrowColumnVector</a></li>
 <li><a href="org/apache/iceberg/mr/hive/serde/objectinspector/IcebergBinaryObjectInspector.html" title="class in org.apache.iceberg.mr.hive.serde.objectinspector">IcebergBinaryObjectInspector</a></li>
 <li><a href="org/apache/iceberg/IcebergBuild.html" title="class in org.apache.iceberg">IcebergBuild</a></li>
@@ -571,6 +571,10 @@
 <li><a href="org/apache/iceberg/events/IncrementalScanEvent.html" title="class in org.apache.iceberg.events">IncrementalScanEvent</a></li>
 <li><a href="org/apache/iceberg/types/IndexByName.html" title="class in org.apache.iceberg.types">IndexByName</a></li>
 <li><a href="org/apache/iceberg/types/IndexParents.html" title="class in org.apache.iceberg.types">IndexParents</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></li>
+<li><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></li>
 <li><a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io"><span class="interfaceName">InputFile</span></a></li>
 <li><a href="org/apache/iceberg/encryption/InputFilesDecryptor.html" title="class in org.apache.iceberg.encryption">InputFilesDecryptor</a></li>
 <li><a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr">InputFormatConfig</a></li>
@@ -667,6 +671,7 @@
 <li><a href="org/apache/iceberg/MetricsModes.Truncate.html" title="class in org.apache.iceberg">MetricsModes.Truncate</a></li>
 <li><a href="org/apache/iceberg/metrics/MetricsReport.html" title="interface in org.apache.iceberg.metrics"><span class="interfaceName">MetricsReport</span></a></li>
 <li><a href="org/apache/iceberg/metrics/MetricsReporter.html" title="interface in org.apache.iceberg.metrics"><span class="interfaceName">MetricsReporter</span></a></li>
+<li><a href="org/apache/iceberg/metrics/MetricsReporters.html" title="class in org.apache.iceberg.metrics">MetricsReporters</a></li>
 <li><a href="org/apache/iceberg/MetricsUtil.html" title="class in org.apache.iceberg">MetricsUtil</a></li>
 <li><a href="org/apache/iceberg/MetricsUtil.ReadableColMetricsStruct.html" title="class in org.apache.iceberg">MetricsUtil.ReadableColMetricsStruct</a></li>
 <li><a href="org/apache/iceberg/MetricsUtil.ReadableMetricColDefinition.html" title="class in org.apache.iceberg">MetricsUtil.ReadableMetricColDefinition</a></li>
@@ -683,6 +688,7 @@
 <li><a href="org/apache/iceberg/transforms/Months.html" title="class in org.apache.iceberg.transforms">Months</a></li>
 <li><a href="org/apache/iceberg/spark/functions/MonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.DateToMonthsFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampNtzToMonthsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampToMonthsFunction</a></li>
 <li><a href="org/apache/iceberg/expressions/NamedReference.html" title="class in org.apache.iceberg.expressions">NamedReference</a></li>
 <li><a href="org/apache/iceberg/mapping/NameMapping.html" title="class in org.apache.iceberg.mapping">NameMapping</a></li>
@@ -697,6 +703,7 @@
 <li><a href="org/apache/iceberg/nessie/NessieIcebergClient.html" title="class in org.apache.iceberg.nessie">NessieIcebergClient</a></li>
 <li><a href="org/apache/iceberg/nessie/NessieTableOperations.html" title="class in org.apache.iceberg.nessie">NessieTableOperations</a></li>
 <li><a href="org/apache/iceberg/nessie/NessieUtil.html" title="class in org.apache.iceberg.nessie">NessieUtil</a></li>
+<li><a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive">NoLock</a></li>
 <li><a href="org/apache/iceberg/exceptions/NoSuchIcebergTableException.html" title="class in org.apache.iceberg.exceptions">NoSuchIcebergTableException</a></li>
 <li><a href="org/apache/iceberg/exceptions/NoSuchNamespaceException.html" title="class in org.apache.iceberg.exceptions">NoSuchNamespaceException</a></li>
 <li><a href="org/apache/spark/sql/catalyst/analysis/NoSuchProcedureException.html" title="class in org.apache.spark.sql.catalyst.analysis">NoSuchProcedureException</a></li>
@@ -812,6 +819,7 @@
 <li><a href="org/apache/iceberg/encryption/PlaintextEncryptionManager.html" title="class in org.apache.iceberg.encryption">PlaintextEncryptionManager</a></li>
 <li><a href="org/apache/iceberg/deletes/PositionDelete.html" title="class in org.apache.iceberg.deletes">PositionDelete</a></li>
 <li><a href="org/apache/iceberg/deletes/PositionDeleteIndex.html" title="interface in org.apache.iceberg.deletes"><span class="interfaceName">PositionDeleteIndex</span></a></li>
+<li><a href="org/apache/iceberg/spark/PositionDeletesRewriteCoordinator.html" title="class in org.apache.iceberg.spark">PositionDeletesRewriteCoordinator</a></li>
 <li><a href="org/apache/iceberg/PositionDeletesScanTask.html" title="interface in org.apache.iceberg"><span class="interfaceName">PositionDeletesScanTask</span></a></li>
 <li><a href="org/apache/iceberg/PositionDeletesTable.html" title="class in org.apache.iceberg">PositionDeletesTable</a></li>
 <li><a href="org/apache/iceberg/PositionDeletesTable.PositionDeletesBatchScan.html" title="class in org.apache.iceberg">PositionDeletesTable.PositionDeletesBatchScan</a></li>
@@ -887,7 +895,9 @@
 <li><a href="org/apache/iceberg/rest/RESTSessionCatalog.html" title="class in org.apache.iceberg.rest">RESTSessionCatalog</a></li>
 <li><a href="org/apache/iceberg/aws/RESTSigV4Signer.html" title="class in org.apache.iceberg.aws">RESTSigV4Signer</a></li>
 <li><a href="org/apache/iceberg/rest/RESTUtil.html" title="class in org.apache.iceberg.rest">RESTUtil</a></li>
+<li><a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util">RetryDetector</a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteDataFiles</span></a></li>
+<li><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteDataFiles.FileGroupFailureResult</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteDataFiles.FileGroupInfo</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteDataFiles.FileGroupRewriteResult</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteDataFiles.Result</span></a></li>
@@ -903,7 +913,13 @@
 <li><a href="org/apache/iceberg/actions/RewriteManifests.Result.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteManifests.Result</span></a></li>
 <li><a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewriteManifestsSparkAction</a></li>
 <li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewritePositionDeleteFiles</span></a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewritePositionDeleteFiles.FileGroupInfo</span></a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewritePositionDeleteFiles.FileGroupRewriteResult</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewritePositionDeleteFiles.Result</span></a></li>
+<li><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RewritePositionDeleteFilesProcedure</a></li>
+<li><a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewritePositionDeleteFilesSparkAction</a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager</a></li>
+<li><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></li>
 <li><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewritePositionDeleteStrategy</span></a></li>
 <li><a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions"><span class="interfaceName">RewriteStrategy</span></a></li>
 <li><a href="org/apache/iceberg/spark/RollbackStagedTable.html" title="class in org.apache.iceberg.spark">RollbackStagedTable</a></li>
@@ -925,6 +941,9 @@
 <li><a href="org/apache/iceberg/exceptions/RuntimeIOException.html" title="class in org.apache.iceberg.exceptions">RuntimeIOException</a></li>
 <li><a href="org/apache/iceberg/hive/RuntimeMetaException.html" title="class in org.apache.iceberg.hive">RuntimeMetaException</a></li>
 <li><a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></li>
+<li><a href="org/apache/iceberg/aws/S3FileIOAwsClientFactories.html" title="class in org.apache.iceberg.aws">S3FileIOAwsClientFactories</a></li>
+<li><a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html" title="interface in org.apache.iceberg.aws.s3"><span class="interfaceName">S3FileIOAwsClientFactory</span></a></li>
+<li><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></li>
 <li><a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3">S3InputFile</a></li>
 <li><a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.html" title="class in org.apache.iceberg.aws.s3.signer">S3ObjectMapper</a></li>
 <li><a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.S3SignRequestDeserializer.html" title="class in org.apache.iceberg.aws.s3.signer">S3ObjectMapper.S3SignRequestDeserializer</a></li>
@@ -977,6 +996,9 @@
 <li><a href="org/apache/iceberg/flink/source/assigner/SimpleSplitAssigner.html" title="class in org.apache.iceberg.flink.source.assigner">SimpleSplitAssigner</a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SimpleSplitAssignerFactory.html" title="class in org.apache.iceberg.flink.source.assigner">SimpleSplitAssignerFactory</a></li>
 <li><a href="org/apache/iceberg/SingleValueParser.html" title="class in org.apache.iceberg">SingleValueParser</a></li>
+<li><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></li>
+<li><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></li>
+<li><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedPositionDeletesRewriter</a></li>
 <li><a href="org/apache/iceberg/Snapshot.html" title="interface in org.apache.iceberg"><span class="interfaceName">Snapshot</span></a></li>
 <li><a href="org/apache/iceberg/delta/SnapshotDeltaLakeTable.html" title="interface in org.apache.iceberg.delta"><span class="interfaceName">SnapshotDeltaLakeTable</span></a></li>
 <li><a href="org/apache/iceberg/delta/SnapshotDeltaLakeTable.Result.html" title="interface in org.apache.iceberg.delta"><span class="interfaceName">SnapshotDeltaLakeTable.Result</span></a></li>
@@ -1015,14 +1037,13 @@
 <li><a href="org/apache/iceberg/spark/SparkAggregates.html" title="class in org.apache.iceberg.spark">SparkAggregates</a></li>
 <li><a href="org/apache/iceberg/spark/data/SparkAvroReader.html" title="class in org.apache.iceberg.spark.data">SparkAvroReader</a></li>
 <li><a href="org/apache/iceberg/spark/data/SparkAvroWriter.html" title="class in org.apache.iceberg.spark.data">SparkAvroWriter</a></li>
-<li><a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkBinPackStrategy</a></li>
 <li><a href="org/apache/iceberg/spark/SparkCachedTableCatalog.html" title="class in org.apache.iceberg.spark">SparkCachedTableCatalog</a></li>
 <li><a href="org/apache/iceberg/spark/SparkCatalog.html" title="class in org.apache.iceberg.spark">SparkCatalog</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkChangelogTable.html" title="class in org.apache.iceberg.spark.source">SparkChangelogTable</a></li>
 <li><a href="org/apache/iceberg/spark/SparkDataFile.html" title="class in org.apache.iceberg.spark">SparkDataFile</a></li>
-<li><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark">SparkDistributionAndOrderingUtil</a></li>
 <li><a href="org/apache/iceberg/spark/SparkExceptionUtil.html" title="class in org.apache.iceberg.spark">SparkExceptionUtil</a></li>
 <li><a href="org/apache/iceberg/spark/SparkFilters.html" title="class in org.apache.iceberg.spark">SparkFilters</a></li>
+<li><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark">SparkFunctionCatalog</a></li>
 <li><a href="org/apache/iceberg/spark/functions/SparkFunctions.html" title="class in org.apache.iceberg.spark.functions">SparkFunctions</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkMetadataColumn.html" title="class in org.apache.iceberg.spark.source">SparkMetadataColumn</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html" title="class in org.apache.iceberg.spark.source">SparkMicroBatchStream</a></li>
@@ -1033,6 +1054,9 @@
 <li><a href="org/apache/iceberg/spark/data/SparkParquetWriters.html" title="class in org.apache.iceberg.spark.data">SparkParquetWriters</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkPartitionedFanoutWriter.html" title="class in org.apache.iceberg.spark.source">SparkPartitionedFanoutWriter</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkPartitionedWriter.html" title="class in org.apache.iceberg.spark.source">SparkPartitionedWriter</a></li>
+<li><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.html" title="class in org.apache.iceberg.spark.source">SparkPositionDeletesRewrite</a></li>
+<li><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.DeleteTaskCommit.html" title="class in org.apache.iceberg.spark.source">SparkPositionDeletesRewrite.DeleteTaskCommit</a></li>
+<li><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewriteBuilder.html" title="class in org.apache.iceberg.spark.source">SparkPositionDeletesRewriteBuilder</a></li>
 <li><a href="org/apache/iceberg/spark/procedures/SparkProcedures.html" title="class in org.apache.iceberg.spark.procedures">SparkProcedures</a></li>
 <li><a href="org/apache/iceberg/spark/procedures/SparkProcedures.ProcedureBuilder.html" title="interface in org.apache.iceberg.spark.procedures"><span class="interfaceName">SparkProcedures.ProcedureBuilder</span></a></li>
 <li><a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark">SparkReadConf</a></li>
@@ -1040,7 +1064,6 @@
 <li><a href="org/apache/iceberg/spark/source/SparkScanBuilder.html" title="class in org.apache.iceberg.spark.source">SparkScanBuilder</a></li>
 <li><a href="org/apache/iceberg/spark/SparkSchemaUtil.html" title="class in org.apache.iceberg.spark">SparkSchemaUtil</a></li>
 <li><a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></li>
-<li><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></li>
 <li><a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></li>
 <li><a href="org/apache/iceberg/spark/SparkStructLike.html" title="class in org.apache.iceberg.spark">SparkStructLike</a></li>
 <li><a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source">SparkTable</a></li>
@@ -1054,7 +1077,8 @@
 <li><a href="org/apache/iceberg/spark/data/SparkValueWriters.html" title="class in org.apache.iceberg.spark.data">SparkValueWriters</a></li>
 <li><a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></li>
 <li><a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></li>
-<li><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></li>
+<li><a href="org/apache/iceberg/spark/SparkWriteRequirements.html" title="class in org.apache.iceberg.spark">SparkWriteRequirements</a></li>
+<li><a href="org/apache/iceberg/spark/SparkWriteUtil.html" title="class in org.apache.iceberg.spark">SparkWriteUtil</a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SplitAssigner.html" title="interface in org.apache.iceberg.flink.source.assigner"><span class="interfaceName">SplitAssigner</span></a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SplitAssignerFactory.html" title="interface in org.apache.iceberg.flink.source.assigner"><span class="interfaceName">SplitAssignerFactory</span></a></li>
 <li><a href="org/apache/iceberg/flink/source/assigner/SplitAssignerType.html" title="enum in org.apache.iceberg.flink.source.assigner">SplitAssignerType</a></li>
@@ -1080,7 +1104,6 @@
 <li><a href="org/apache/iceberg/util/StructProjection.html" title="class in org.apache.iceberg.util">StructProjection</a></li>
 <li><a href="org/apache/iceberg/flink/data/StructRowData.html" title="class in org.apache.iceberg.flink.data">StructRowData</a></li>
 <li><a href="org/apache/iceberg/io/SupportsBulkOperations.html" title="interface in org.apache.iceberg.io"><span class="interfaceName">SupportsBulkOperations</span></a></li>
-<li><a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="interfaceName">SupportsDelta</span></a></li>
 <li><a href="org/apache/iceberg/catalog/SupportsNamespaces.html" title="interface in org.apache.iceberg.catalog"><span class="interfaceName">SupportsNamespaces</span></a></li>
 <li><a href="org/apache/iceberg/io/SupportsPrefixOperations.html" title="interface in org.apache.iceberg.io"><span class="interfaceName">SupportsPrefixOperations</span></a></li>
 <li><a href="org/apache/iceberg/avro/SupportsRowPosition.html" title="interface in org.apache.iceberg.avro"><span class="interfaceName">SupportsRowPosition</span></a></li>
@@ -1243,6 +1266,7 @@
 <li><a href="org/apache/iceberg/io/WriteResult.Builder.html" title="class in org.apache.iceberg.io">WriteResult.Builder</a></li>
 <li><a href="org/apache/iceberg/spark/functions/YearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.DateToYearsFunction</a></li>
+<li><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampNtzToYearsFunction</a></li>
 <li><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampToYearsFunction</a></li>
 <li><a href="org/apache/iceberg/expressions/Zorder.html" title="class in org.apache.iceberg.expressions">Zorder</a></li>
 <li><a href="org/apache/iceberg/util/ZOrderByteUtils.html" title="class in org.apache.iceberg.util">ZOrderByteUtils</a></li>
diff --git a/javadoc/constant-values.html b/javadoc/constant-values.html
index 86abc0ab..952019cf 100644
--- a/javadoc/constant-values.html
+++ b/javadoc/constant-values.html
@@ -136,25 +136,25 @@
 <td class="colLast"><code>"app-id"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.AUTH_DEFAULT_REFRESH_ENABLED">
+<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.AUTH_SESSION_TIMEOUT_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/CatalogProperties.html#AUTH_DEFAULT_REFRESH_ENABLED">AUTH_DEFAULT_REFRESH_ENABLED</a></code></td>
-<td class="colLast"><code>"auth.default-refresh-enabled"</code></td>
+<td><code><a href="org/apache/iceberg/CatalogProperties.html#AUTH_SESSION_TIMEOUT_MS">AUTH_SESSION_TIMEOUT_MS</a></code></td>
+<td class="colLast"><code>"auth.session-timeout-ms"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT">
+<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.CACHE_CASE_SENSITIVE">
 <!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
-<td><code><a href="org/apache/iceberg/CatalogProperties.html#AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT">AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT</a></code></td>
-<td class="colLast"><code>false</code></td>
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/CatalogProperties.html#CACHE_CASE_SENSITIVE">CACHE_CASE_SENSITIVE</a></code></td>
+<td class="colLast"><code>"cache.case-sensitive"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.AUTH_SESSION_TIMEOUT_MS">
+<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.CACHE_CASE_SENSITIVE_DEFAULT">
 <!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/CatalogProperties.html#AUTH_SESSION_TIMEOUT_MS">AUTH_SESSION_TIMEOUT_MS</a></code></td>
-<td class="colLast"><code>"auth.session-timeout-ms"</code></td>
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/CatalogProperties.html#CACHE_CASE_SENSITIVE_DEFAULT">CACHE_CASE_SENSITIVE_DEFAULT</a></code></td>
+<td class="colLast"><code>true</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.CACHE_ENABLED">
@@ -199,167 +199,174 @@
 <td class="colLast"><code>"client.pool.cache.eviction-interval-ms"</code></td>
 </tr>
 <tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.CLIENT_POOL_CACHE_KEYS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_CACHE_KEYS">CLIENT_POOL_CACHE_KEYS</a></code></td>
+<td class="colLast"><code>"client-pool-cache-keys"</code></td>
+</tr>
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.CLIENT_POOL_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_SIZE">CLIENT_POOL_SIZE</a></code></td>
 <td class="colLast"><code>"clients"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.CLIENT_POOL_SIZE_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_SIZE_DEFAULT">CLIENT_POOL_SIZE_DEFAULT</a></code></td>
 <td class="colLast"><code>2</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.FILE_IO_IMPL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#FILE_IO_IMPL">FILE_IO_IMPL</a></code></td>
 <td class="colLast"><code>"io-impl"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_ENABLED">IO_MANIFEST_CACHE_ENABLED</a></code></td>
 <td class="colLast"><code>"io.manifest.cache-enabled"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_ENABLED_DEFAULT">IO_MANIFEST_CACHE_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_EXPIRATION_INTERVAL_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_EXPIRATION_INTERVAL_MS">IO_MANIFEST_CACHE_EXPIRATION_INTERVAL_MS</a></code></td>
 <td class="colLast"><code>"io.manifest.cache.expiration-interval-ms"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_MAX_CONTENT_LENGTH">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_MAX_CONTENT_LENGTH">IO_MANIFEST_CACHE_MAX_CONTENT_LENGTH</a></code></td>
 <td class="colLast"><code>"io.manifest.cache.max-content-length"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_MAX_CONTENT_LENGTH_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_MAX_CONTENT_LENGTH_DEFAULT">IO_MANIFEST_CACHE_MAX_CONTENT_LENGTH_DEFAULT</a></code></td>
 <td class="colLast"><code>8388608L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_MAX_TOTAL_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_MAX_TOTAL_BYTES">IO_MANIFEST_CACHE_MAX_TOTAL_BYTES</a></code></td>
 <td class="colLast"><code>"io.manifest.cache.max-total-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.IO_MANIFEST_CACHE_MAX_TOTAL_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#IO_MANIFEST_CACHE_MAX_TOTAL_BYTES_DEFAULT">IO_MANIFEST_CACHE_MAX_TOTAL_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>104857600L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_ACQUIRE_INTERVAL_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_ACQUIRE_INTERVAL_MS">LOCK_ACQUIRE_INTERVAL_MS</a></code></td>
 <td class="colLast"><code>"lock.acquire-interval-ms"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_ACQUIRE_TIMEOUT_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_ACQUIRE_TIMEOUT_MS">LOCK_ACQUIRE_TIMEOUT_MS</a></code></td>
 <td class="colLast"><code>"lock.acquire-timeout-ms"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_HEARTBEAT_INTERVAL_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_HEARTBEAT_INTERVAL_MS">LOCK_HEARTBEAT_INTERVAL_MS</a></code></td>
 <td class="colLast"><code>"lock.heartbeat-interval-ms"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_HEARTBEAT_THREADS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_HEARTBEAT_THREADS">LOCK_HEARTBEAT_THREADS</a></code></td>
 <td class="colLast"><code>"lock.heartbeat-threads"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_HEARTBEAT_THREADS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_HEARTBEAT_THREADS_DEFAULT">LOCK_HEARTBEAT_THREADS_DEFAULT</a></code></td>
 <td class="colLast"><code>4</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_HEARTBEAT_TIMEOUT_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_HEARTBEAT_TIMEOUT_MS">LOCK_HEARTBEAT_TIMEOUT_MS</a></code></td>
 <td class="colLast"><code>"lock.heartbeat-timeout-ms"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_IMPL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_IMPL">LOCK_IMPL</a></code></td>
 <td class="colLast"><code>"lock-impl"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.LOCK_TABLE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#LOCK_TABLE">LOCK_TABLE</a></code></td>
 <td class="colLast"><code>"lock.table"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.METRICS_REPORTER_IMPL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#METRICS_REPORTER_IMPL">METRICS_REPORTER_IMPL</a></code></td>
 <td class="colLast"><code>"metrics-reporter-impl"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.TABLE_DEFAULT_PREFIX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#TABLE_DEFAULT_PREFIX">TABLE_DEFAULT_PREFIX</a></code></td>
 <td class="colLast"><code>"table-default."</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.TABLE_OVERRIDE_PREFIX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#TABLE_OVERRIDE_PREFIX">TABLE_OVERRIDE_PREFIX</a></code></td>
 <td class="colLast"><code>"table-override."</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.URI">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#URI">URI</a></code></td>
 <td class="colLast"><code>"uri"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.USER">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/CatalogProperties.html#USER">USER</a></code></td>
 <td class="colLast"><code>"user"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.CatalogProperties.WAREHOUSE_LOCATION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
@@ -632,6 +639,39 @@
 </li>
 <li class="blockList">
 <table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.<a href="org/apache/iceberg/PositionDeletesTable.html" title="class in org.apache.iceberg">PositionDeletesTable</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.PositionDeletesTable.DELETE_FILE_PATH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/PositionDeletesTable.html#DELETE_FILE_PATH">DELETE_FILE_PATH</a></code></td>
+<td class="colLast"><code>"delete_file_path"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.PositionDeletesTable.PARTITION">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/PositionDeletesTable.html#PARTITION">PARTITION</a></code></td>
+<td class="colLast"><code>"partition"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.PositionDeletesTable.SPEC_ID">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/PositionDeletesTable.html#SPEC_ID">SPEC_ID</a></code></td>
+<td class="colLast"><code>"spec_id"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
 <caption><span>org.apache.iceberg.<a href="org/apache/iceberg/SnapshotRef.html" title="class in org.apache.iceberg">SnapshotRef</a></span><span class="tabEnd">&nbsp;</span></caption>
 <tr>
 <th class="colFirst" scope="col">Modifier and Type</th>
@@ -1327,762 +1367,769 @@
 <td class="colLast"><code>true</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.TableProperties.HMS_TABLE_OWNER">
+<td class="colFirst"><a name="org.apache.iceberg.TableProperties.HIVE_LOCK_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/TableProperties.html#HMS_TABLE_OWNER">HMS_TABLE_OWNER</a></code></td>
-<td class="colLast"><code>"hive.metastore.table.owner"</code></td>
+<td><code><a href="org/apache/iceberg/TableProperties.html#HIVE_LOCK_ENABLED">HIVE_LOCK_ENABLED</a></code></td>
+<td class="colLast"><code>"engine.hive.lock-enabled"</code></td>
 </tr>
 <tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.TableProperties.HIVE_LOCK_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/TableProperties.html#HIVE_LOCK_ENABLED_DEFAULT">HIVE_LOCK_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>true</code></td>
+</tr>
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_LISTS_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_LISTS_ENABLED">MANIFEST_LISTS_ENABLED</a></code></td>
 <td class="colLast"><code>"write.manifest-lists.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_LISTS_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_LISTS_ENABLED_DEFAULT">MANIFEST_LISTS_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>true</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_MERGE_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_MERGE_ENABLED">MANIFEST_MERGE_ENABLED</a></code></td>
 <td class="colLast"><code>"commit.manifest-merge.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_MERGE_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_MERGE_ENABLED_DEFAULT">MANIFEST_MERGE_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>true</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_MIN_MERGE_COUNT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_MIN_MERGE_COUNT">MANIFEST_MIN_MERGE_COUNT</a></code></td>
 <td class="colLast"><code>"commit.manifest.min-count-to-merge"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_MIN_MERGE_COUNT_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_MIN_MERGE_COUNT_DEFAULT">MANIFEST_MIN_MERGE_COUNT_DEFAULT</a></code></td>
 <td class="colLast"><code>100</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_TARGET_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_TARGET_SIZE_BYTES">MANIFEST_TARGET_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"commit.manifest.target-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MANIFEST_TARGET_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MANIFEST_TARGET_SIZE_BYTES_DEFAULT">MANIFEST_TARGET_SIZE_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>8388608L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MAX_REF_AGE_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MAX_REF_AGE_MS">MAX_REF_AGE_MS</a></code></td>
 <td class="colLast"><code>"history.expire.max-ref-age-ms"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MAX_REF_AGE_MS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MAX_REF_AGE_MS_DEFAULT">MAX_REF_AGE_MS_DEFAULT</a></code></td>
 <td class="colLast"><code>9223372036854775807L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MAX_SNAPSHOT_AGE_MS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MAX_SNAPSHOT_AGE_MS">MAX_SNAPSHOT_AGE_MS</a></code></td>
 <td class="colLast"><code>"history.expire.max-snapshot-age-ms"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MAX_SNAPSHOT_AGE_MS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MAX_SNAPSHOT_AGE_MS_DEFAULT">MAX_SNAPSHOT_AGE_MS_DEFAULT</a></code></td>
 <td class="colLast"><code>432000000L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MERGE_CARDINALITY_CHECK_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MERGE_CARDINALITY_CHECK_ENABLED">MERGE_CARDINALITY_CHECK_ENABLED</a></code></td>
 <td class="colLast"><code>"write.merge.cardinality-check.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MERGE_CARDINALITY_CHECK_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MERGE_CARDINALITY_CHECK_ENABLED_DEFAULT">MERGE_CARDINALITY_CHECK_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>true</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MERGE_DISTRIBUTION_MODE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MERGE_DISTRIBUTION_MODE">MERGE_DISTRIBUTION_MODE</a></code></td>
 <td class="colLast"><code>"write.merge.distribution-mode"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MERGE_ISOLATION_LEVEL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MERGE_ISOLATION_LEVEL">MERGE_ISOLATION_LEVEL</a></code></td>
 <td class="colLast"><code>"write.merge.isolation-level"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MERGE_ISOLATION_LEVEL_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MERGE_ISOLATION_LEVEL_DEFAULT">MERGE_ISOLATION_LEVEL_DEFAULT</a></code></td>
 <td class="colLast"><code>"serializable"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MERGE_MODE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MERGE_MODE">MERGE_MODE</a></code></td>
 <td class="colLast"><code>"write.merge.mode"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_COMPRESSION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_COMPRESSION">METADATA_COMPRESSION</a></code></td>
 <td class="colLast"><code>"write.metadata.compression-codec"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_COMPRESSION_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_COMPRESSION_DEFAULT">METADATA_COMPRESSION_DEFAULT</a></code></td>
 <td class="colLast"><code>"none"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_DELETE_AFTER_COMMIT_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_DELETE_AFTER_COMMIT_ENABLED">METADATA_DELETE_AFTER_COMMIT_ENABLED</a></code></td>
 <td class="colLast"><code>"write.metadata.delete-after-commit.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_DELETE_AFTER_COMMIT_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_DELETE_AFTER_COMMIT_ENABLED_DEFAULT">METADATA_DELETE_AFTER_COMMIT_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_PREVIOUS_VERSIONS_MAX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_PREVIOUS_VERSIONS_MAX">METADATA_PREVIOUS_VERSIONS_MAX</a></code></td>
 <td class="colLast"><code>"write.metadata.previous-versions-max"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_PREVIOUS_VERSIONS_MAX_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_PREVIOUS_VERSIONS_MAX_DEFAULT">METADATA_PREVIOUS_VERSIONS_MAX_DEFAULT</a></code></td>
 <td class="colLast"><code>100</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_SPLIT_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_SPLIT_SIZE">METADATA_SPLIT_SIZE</a></code></td>
 <td class="colLast"><code>"read.split.metadata-target-size"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METADATA_SPLIT_SIZE_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METADATA_SPLIT_SIZE_DEFAULT">METADATA_SPLIT_SIZE_DEFAULT</a></code></td>
 <td class="colLast"><code>33554432L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METRICS_MAX_INFERRED_COLUMN_DEFAULTS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METRICS_MAX_INFERRED_COLUMN_DEFAULTS">METRICS_MAX_INFERRED_COLUMN_DEFAULTS</a></code></td>
 <td class="colLast"><code>"write.metadata.metrics.max-inferred-column-defaults"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METRICS_MAX_INFERRED_COLUMN_DEFAULTS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METRICS_MAX_INFERRED_COLUMN_DEFAULTS_DEFAULT">METRICS_MAX_INFERRED_COLUMN_DEFAULTS_DEFAULT</a></code></td>
 <td class="colLast"><code>100</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.METRICS_MODE_COLUMN_CONF_PREFIX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#METRICS_MODE_COLUMN_CONF_PREFIX">METRICS_MODE_COLUMN_CONF_PREFIX</a></code></td>
 <td class="colLast"><code>"write.metadata.metrics.column."</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MIN_SNAPSHOTS_TO_KEEP">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MIN_SNAPSHOTS_TO_KEEP">MIN_SNAPSHOTS_TO_KEEP</a></code></td>
 <td class="colLast"><code>"history.expire.min-snapshots-to-keep"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.MIN_SNAPSHOTS_TO_KEEP_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#MIN_SNAPSHOTS_TO_KEEP_DEFAULT">MIN_SNAPSHOTS_TO_KEEP_DEFAULT</a></code></td>
 <td class="colLast"><code>1</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.OBJECT_STORE_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#OBJECT_STORE_ENABLED">OBJECT_STORE_ENABLED</a></code></td>
 <td class="colLast"><code>"write.object-storage.enabled"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.OBJECT_STORE_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#OBJECT_STORE_ENABLED_DEFAULT">OBJECT_STORE_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.OBJECT_STORE_PATH">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#OBJECT_STORE_PATH">OBJECT_STORE_PATH</a></code></td>
 <td class="colLast"><code>"write.object-storage.path"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BATCH_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BATCH_SIZE">ORC_BATCH_SIZE</a></code></td>
 <td class="colLast"><code>"read.orc.vectorization.batch-size"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BATCH_SIZE_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BATCH_SIZE_DEFAULT">ORC_BATCH_SIZE_DEFAULT</a></code></td>
 <td class="colLast"><code>5000</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BLOCK_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BLOCK_SIZE_BYTES">ORC_BLOCK_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"write.orc.block-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BLOCK_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BLOCK_SIZE_BYTES_DEFAULT">ORC_BLOCK_SIZE_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>268435456L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BLOOM_FILTER_COLUMNS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BLOOM_FILTER_COLUMNS">ORC_BLOOM_FILTER_COLUMNS</a></code></td>
 <td class="colLast"><code>"write.orc.bloom.filter.columns"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BLOOM_FILTER_COLUMNS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BLOOM_FILTER_COLUMNS_DEFAULT">ORC_BLOOM_FILTER_COLUMNS_DEFAULT</a></code></td>
 <td class="colLast"><code>""</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BLOOM_FILTER_FPP">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BLOOM_FILTER_FPP">ORC_BLOOM_FILTER_FPP</a></code></td>
 <td class="colLast"><code>"write.orc.bloom.filter.fpp"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_BLOOM_FILTER_FPP_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;double</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_BLOOM_FILTER_FPP_DEFAULT">ORC_BLOOM_FILTER_FPP_DEFAULT</a></code></td>
 <td class="colLast"><code>0.05</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_COMPRESSION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_COMPRESSION">ORC_COMPRESSION</a></code></td>
 <td class="colLast"><code>"write.orc.compression-codec"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_COMPRESSION_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_COMPRESSION_DEFAULT">ORC_COMPRESSION_DEFAULT</a></code></td>
 <td class="colLast"><code>"zlib"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_COMPRESSION_STRATEGY">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_COMPRESSION_STRATEGY">ORC_COMPRESSION_STRATEGY</a></code></td>
 <td class="colLast"><code>"write.orc.compression-strategy"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_COMPRESSION_STRATEGY_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_COMPRESSION_STRATEGY_DEFAULT">ORC_COMPRESSION_STRATEGY_DEFAULT</a></code></td>
 <td class="colLast"><code>"speed"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_STRIPE_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_STRIPE_SIZE_BYTES">ORC_STRIPE_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"write.orc.stripe-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_STRIPE_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_STRIPE_SIZE_BYTES_DEFAULT">ORC_STRIPE_SIZE_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>67108864L</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_VECTORIZATION_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_VECTORIZATION_ENABLED">ORC_VECTORIZATION_ENABLED</a></code></td>
 <td class="colLast"><code>"read.orc.vectorization.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_VECTORIZATION_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_VECTORIZATION_ENABLED_DEFAULT">ORC_VECTORIZATION_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_WRITE_BATCH_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_WRITE_BATCH_SIZE">ORC_WRITE_BATCH_SIZE</a></code></td>
 <td class="colLast"><code>"write.orc.vectorized.batch-size"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.ORC_WRITE_BATCH_SIZE_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#ORC_WRITE_BATCH_SIZE_DEFAULT">ORC_WRITE_BATCH_SIZE_DEFAULT</a></code></td>
 <td class="colLast"><code>1024</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_BATCH_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_BATCH_SIZE">PARQUET_BATCH_SIZE</a></code></td>
 <td class="colLast"><code>"read.parquet.vectorization.batch-size"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_BATCH_SIZE_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_BATCH_SIZE_DEFAULT">PARQUET_BATCH_SIZE_DEFAULT</a></code></td>
 <td class="colLast"><code>5000</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_BLOOM_FILTER_COLUMN_ENABLED_PREFIX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_BLOOM_FILTER_COLUMN_ENABLED_PREFIX">PARQUET_BLOOM_FILTER_COLUMN_ENABLED_PREFIX</a></code></td>
 <td class="colLast"><code>"write.parquet.bloom-filter-enabled.column."</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_BLOOM_FILTER_MAX_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_BLOOM_FILTER_MAX_BYTES">PARQUET_BLOOM_FILTER_MAX_BYTES</a></code></td>
 <td class="colLast"><code>"write.parquet.bloom-filter-max-bytes"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_BLOOM_FILTER_MAX_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_BLOOM_FILTER_MAX_BYTES_DEFAULT">PARQUET_BLOOM_FILTER_MAX_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>1048576</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_COMPRESSION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_COMPRESSION">PARQUET_COMPRESSION</a></code></td>
 <td class="colLast"><code>"write.parquet.compression-codec"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_COMPRESSION_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_COMPRESSION_DEFAULT">PARQUET_COMPRESSION_DEFAULT</a></code></td>
 <td class="colLast"><code>"gzip"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_COMPRESSION_LEVEL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_COMPRESSION_LEVEL">PARQUET_COMPRESSION_LEVEL</a></code></td>
 <td class="colLast"><code>"write.parquet.compression-level"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_DICT_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_DICT_SIZE_BYTES">PARQUET_DICT_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"write.parquet.dict-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_DICT_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_DICT_SIZE_BYTES_DEFAULT">PARQUET_DICT_SIZE_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>2097152</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_PAGE_ROW_LIMIT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_PAGE_ROW_LIMIT">PARQUET_PAGE_ROW_LIMIT</a></code></td>
 <td class="colLast"><code>"write.parquet.page-row-limit"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_PAGE_ROW_LIMIT_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_PAGE_ROW_LIMIT_DEFAULT">PARQUET_PAGE_ROW_LIMIT_DEFAULT</a></code></td>
 <td class="colLast"><code>20000</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_PAGE_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_PAGE_SIZE_BYTES">PARQUET_PAGE_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"write.parquet.page-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_PAGE_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_PAGE_SIZE_BYTES_DEFAULT">PARQUET_PAGE_SIZE_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>1048576</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_ROW_GROUP_CHECK_MAX_RECORD_COUNT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_ROW_GROUP_CHECK_MAX_RECORD_COUNT">PARQUET_ROW_GROUP_CHECK_MAX_RECORD_COUNT</a></code></td>
 <td class="colLast"><code>"write.parquet.row-group-check-max-record-count"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_ROW_GROUP_CHECK_MAX_RECORD_COUNT_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_ROW_GROUP_CHECK_MAX_RECORD_COUNT_DEFAULT">PARQUET_ROW_GROUP_CHECK_MAX_RECORD_COUNT_DEFAULT</a></code></td>
 <td class="colLast"><code>10000</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_ROW_GROUP_CHECK_MIN_RECORD_COUNT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_ROW_GROUP_CHECK_MIN_RECORD_COUNT">PARQUET_ROW_GROUP_CHECK_MIN_RECORD_COUNT</a></code></td>
 <td class="colLast"><code>"write.parquet.row-group-check-min-record-count"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_ROW_GROUP_CHECK_MIN_RECORD_COUNT_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_ROW_GROUP_CHECK_MIN_RECORD_COUNT_DEFAULT">PARQUET_ROW_GROUP_CHECK_MIN_RECORD_COUNT_DEFAULT</a></code></td>
 <td class="colLast"><code>100</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_ROW_GROUP_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_ROW_GROUP_SIZE_BYTES">PARQUET_ROW_GROUP_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"write.parquet.row-group-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_ROW_GROUP_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_ROW_GROUP_SIZE_BYTES_DEFAULT">PARQUET_ROW_GROUP_SIZE_BYTES_DEFAULT</a></code></td>
 <td class="colLast"><code>134217728</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_VECTORIZATION_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_VECTORIZATION_ENABLED">PARQUET_VECTORIZATION_ENABLED</a></code></td>
 <td class="colLast"><code>"read.parquet.vectorization.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.PARQUET_VECTORIZATION_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#PARQUET_VECTORIZATION_ENABLED_DEFAULT">PARQUET_VECTORIZATION_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>true</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SNAPSHOT_COUNT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SNAPSHOT_COUNT">SNAPSHOT_COUNT</a></code></td>
 <td class="colLast"><code>"snapshot-count"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SNAPSHOT_ID_INHERITANCE_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SNAPSHOT_ID_INHERITANCE_ENABLED">SNAPSHOT_ID_INHERITANCE_ENABLED</a></code></td>
 <td class="colLast"><code>"compatibility.snapshot-id-inheritance.enabled"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SNAPSHOT_ID_INHERITANCE_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SNAPSHOT_ID_INHERITANCE_ENABLED_DEFAULT">SNAPSHOT_ID_INHERITANCE_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPARK_WRITE_ACCEPT_ANY_SCHEMA">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPARK_WRITE_ACCEPT_ANY_SCHEMA">SPARK_WRITE_ACCEPT_ANY_SCHEMA</a></code></td>
 <td class="colLast"><code>"write.spark.accept-any-schema"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPARK_WRITE_ACCEPT_ANY_SCHEMA_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPARK_WRITE_ACCEPT_ANY_SCHEMA_DEFAULT">SPARK_WRITE_ACCEPT_ANY_SCHEMA_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPARK_WRITE_PARTITIONED_FANOUT_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPARK_WRITE_PARTITIONED_FANOUT_ENABLED">SPARK_WRITE_PARTITIONED_FANOUT_ENABLED</a></code></td>
 <td class="colLast"><code>"write.spark.fanout.enabled"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPARK_WRITE_PARTITIONED_FANOUT_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPARK_WRITE_PARTITIONED_FANOUT_ENABLED_DEFAULT">SPARK_WRITE_PARTITIONED_FANOUT_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPLIT_LOOKBACK">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPLIT_LOOKBACK">SPLIT_LOOKBACK</a></code></td>
 <td class="colLast"><code>"read.split.planning-lookback"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPLIT_LOOKBACK_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPLIT_LOOKBACK_DEFAULT">SPLIT_LOOKBACK_DEFAULT</a></code></td>
 <td class="colLast"><code>10</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPLIT_OPEN_FILE_COST">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPLIT_OPEN_FILE_COST">SPLIT_OPEN_FILE_COST</a></code></td>
 <td class="colLast"><code>"read.split.open-file-cost"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPLIT_OPEN_FILE_COST_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPLIT_OPEN_FILE_COST_DEFAULT">SPLIT_OPEN_FILE_COST_DEFAULT</a></code></td>
 <td class="colLast"><code>4194304L</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPLIT_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPLIT_SIZE">SPLIT_SIZE</a></code></td>
 <td class="colLast"><code>"read.split.target-size"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.SPLIT_SIZE_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#SPLIT_SIZE_DEFAULT">SPLIT_SIZE_DEFAULT</a></code></td>
 <td class="colLast"><code>134217728L</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UPDATE_DISTRIBUTION_MODE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UPDATE_DISTRIBUTION_MODE">UPDATE_DISTRIBUTION_MODE</a></code></td>
 <td class="colLast"><code>"write.update.distribution-mode"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UPDATE_ISOLATION_LEVEL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UPDATE_ISOLATION_LEVEL">UPDATE_ISOLATION_LEVEL</a></code></td>
 <td class="colLast"><code>"write.update.isolation-level"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UPDATE_ISOLATION_LEVEL_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UPDATE_ISOLATION_LEVEL_DEFAULT">UPDATE_ISOLATION_LEVEL_DEFAULT</a></code></td>
 <td class="colLast"><code>"serializable"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UPDATE_MODE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UPDATE_MODE">UPDATE_MODE</a></code></td>
 <td class="colLast"><code>"write.update.mode"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UPSERT_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UPSERT_ENABLED">UPSERT_ENABLED</a></code></td>
 <td class="colLast"><code>"write.upsert.enabled"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UPSERT_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UPSERT_ENABLED_DEFAULT">UPSERT_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.UUID">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#UUID">UUID</a></code></td>
 <td class="colLast"><code>"uuid"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_AUDIT_PUBLISH_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_AUDIT_PUBLISH_ENABLED">WRITE_AUDIT_PUBLISH_ENABLED</a></code></td>
 <td class="colLast"><code>"write.wap.enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_AUDIT_PUBLISH_ENABLED_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_AUDIT_PUBLISH_ENABLED_DEFAULT">WRITE_AUDIT_PUBLISH_ENABLED_DEFAULT</a></code></td>
 <td class="colLast"><code>"false"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_DATA_LOCATION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_DATA_LOCATION">WRITE_DATA_LOCATION</a></code></td>
 <td class="colLast"><code>"write.data.path"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_DISTRIBUTION_MODE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_DISTRIBUTION_MODE">WRITE_DISTRIBUTION_MODE</a></code></td>
 <td class="colLast"><code>"write.distribution-mode"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_DISTRIBUTION_MODE_HASH">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_DISTRIBUTION_MODE_HASH">WRITE_DISTRIBUTION_MODE_HASH</a></code></td>
 <td class="colLast"><code>"hash"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_DISTRIBUTION_MODE_NONE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_DISTRIBUTION_MODE_NONE">WRITE_DISTRIBUTION_MODE_NONE</a></code></td>
 <td class="colLast"><code>"none"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_DISTRIBUTION_MODE_RANGE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_DISTRIBUTION_MODE_RANGE">WRITE_DISTRIBUTION_MODE_RANGE</a></code></td>
 <td class="colLast"><code>"range"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_FOLDER_STORAGE_LOCATION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_FOLDER_STORAGE_LOCATION">WRITE_FOLDER_STORAGE_LOCATION</a></code></td>
 <td class="colLast"><code>"write.folder-storage.path"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_LOCATION_PROVIDER_IMPL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_LOCATION_PROVIDER_IMPL">WRITE_LOCATION_PROVIDER_IMPL</a></code></td>
 <td class="colLast"><code>"write.location-provider.impl"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_METADATA_LOCATION">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_METADATA_LOCATION">WRITE_METADATA_LOCATION</a></code></td>
 <td class="colLast"><code>"write.metadata.path"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_PARTITION_SUMMARY_LIMIT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_PARTITION_SUMMARY_LIMIT">WRITE_PARTITION_SUMMARY_LIMIT</a></code></td>
 <td class="colLast"><code>"write.summary.partition-limit"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_PARTITION_SUMMARY_LIMIT_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_PARTITION_SUMMARY_LIMIT_DEFAULT">WRITE_PARTITION_SUMMARY_LIMIT_DEFAULT</a></code></td>
 <td class="colLast"><code>0</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_TARGET_FILE_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/TableProperties.html#WRITE_TARGET_FILE_SIZE_BYTES">WRITE_TARGET_FILE_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"write.target-file-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.TableProperties.WRITE_TARGET_FILE_SIZE_BYTES_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
@@ -2197,7 +2244,7 @@
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
 <td><code><a href="org/apache/iceberg/actions/RewriteDataFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT">MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT</a></code></td>
-<td class="colLast"><code>1</code></td>
+<td class="colLast"><code>5</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.actions.RewriteDataFiles.MAX_FILE_GROUP_SIZE_BYTES">
@@ -2272,6 +2319,182 @@
 </tbody>
 </table>
 </li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.MAX_CONCURRENT_FILE_GROUP_REWRITES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES">MAX_CONCURRENT_FILE_GROUP_REWRITES</a></code></td>
+<td class="colLast"><code>"max-concurrent-file-group-rewrites"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT">MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT</a></code></td>
+<td class="colLast"><code>5</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.PARTIAL_PROGRESS_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_ENABLED">PARTIAL_PROGRESS_ENABLED</a></code></td>
+<td class="colLast"><code>"partial-progress.enabled"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.PARTIAL_PROGRESS_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_ENABLED_DEFAULT">PARTIAL_PROGRESS_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.PARTIAL_PROGRESS_MAX_COMMITS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_MAX_COMMITS">PARTIAL_PROGRESS_MAX_COMMITS</a></code></td>
+<td class="colLast"><code>"partial-progress.max-commits"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT">PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT</a></code></td>
+<td class="colLast"><code>10</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.RewritePositionDeleteFiles.REWRITE_JOB_ORDER">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#REWRITE_JOB_ORDER">REWRITE_JOB_ORDER</a></code></td>
+<td class="colLast"><code>"rewrite-job-order"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedDataRewriter.DELETE_FILE_THRESHOLD">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#DELETE_FILE_THRESHOLD">DELETE_FILE_THRESHOLD</a></code></td>
+<td class="colLast"><code>"delete-file-threshold"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedDataRewriter.DELETE_FILE_THRESHOLD_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#DELETE_FILE_THRESHOLD_DEFAULT">DELETE_FILE_THRESHOLD_DEFAULT</a></code></td>
+<td class="colLast"><code>2147483647</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a>&lt;<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="type parameter in SizeBasedFileRewriter">T</a> extends <a href="org/apache/iceberg/ContentScanTask.html" title="interface in org.apache.iceberg">ContentScanTask</a>&lt;<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="typ [...]
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MAX_FILE_GROUP_SIZE_BYTES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_GROUP_SIZE_BYTES">MAX_FILE_GROUP_SIZE_BYTES</a></code></td>
+<td class="colLast"><code>"max-file-group-size-bytes"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MAX_FILE_GROUP_SIZE_BYTES_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;long</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_GROUP_SIZE_BYTES_DEFAULT">MAX_FILE_GROUP_SIZE_BYTES_DEFAULT</a></code></td>
+<td class="colLast"><code>107374182400L</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MAX_FILE_SIZE_BYTES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_SIZE_BYTES">MAX_FILE_SIZE_BYTES</a></code></td>
+<td class="colLast"><code>"max-file-size-bytes"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MAX_FILE_SIZE_DEFAULT_RATIO">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;double</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_SIZE_DEFAULT_RATIO">MAX_FILE_SIZE_DEFAULT_RATIO</a></code></td>
+<td class="colLast"><code>1.8</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MIN_FILE_SIZE_BYTES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_FILE_SIZE_BYTES">MIN_FILE_SIZE_BYTES</a></code></td>
+<td class="colLast"><code>"min-file-size-bytes"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MIN_FILE_SIZE_DEFAULT_RATIO">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;double</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_FILE_SIZE_DEFAULT_RATIO">MIN_FILE_SIZE_DEFAULT_RATIO</a></code></td>
+<td class="colLast"><code>0.75</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MIN_INPUT_FILES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_INPUT_FILES">MIN_INPUT_FILES</a></code></td>
+<td class="colLast"><code>"min-input-files"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.MIN_INPUT_FILES_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_INPUT_FILES_DEFAULT">MIN_INPUT_FILES_DEFAULT</a></code></td>
+<td class="colLast"><code>5</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.REWRITE_ALL">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#REWRITE_ALL">REWRITE_ALL</a></code></td>
+<td class="colLast"><code>"rewrite-all"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.REWRITE_ALL_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#REWRITE_ALL_DEFAULT">REWRITE_ALL_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.actions.SizeBasedFileRewriter.TARGET_FILE_SIZE_BYTES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#TARGET_FILE_SIZE_BYTES">TARGET_FILE_SIZE_BYTES</a></code></td>
+<td class="colLast"><code>"target-file-size-bytes"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
 </ul>
 <ul class="blockList">
 <li class="blockList">
@@ -2402,6 +2625,32 @@
 <ul class="blockList">
 <li class="blockList">
 <table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsClientProperties.CLIENT_CREDENTIALS_PROVIDER">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsClientProperties.html#CLIENT_CREDENTIALS_PROVIDER">CLIENT_CREDENTIALS_PROVIDER</a></code></td>
+<td class="colLast"><code>"client.credentials-provider"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsClientProperties.CLIENT_REGION">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsClientProperties.html#CLIENT_REGION">CLIENT_REGION</a></code></td>
+<td class="colLast"><code>"client.region"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
 <caption><span>org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></span><span class="tabEnd">&nbsp;</span></caption>
 <tr>
 <th class="colFirst" scope="col">Modifier and Type</th>
@@ -2645,7 +2894,7 @@
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_DEFAULT">HTTP_CLIENT_TYPE_DEFAULT</a></code></td>
-<td class="colLast"><code>"urlconnection"</code></td>
+<td class="colLast"><code>"apache"</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_TYPE_URLCONNECTION">
@@ -2956,130 +3205,604 @@
 <td class="colLast"><code>5242880</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_THRESHOLD_FACTOR">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_THRESHOLD_FACTOR">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR">S3FILEIO_MULTIPART_THRESHOLD_FACTOR</a></code></td>
+<td class="colLast"><code>"s3.multipart.threshold"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;double</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT">S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT</a></code></td>
+<td class="colLast"><code>1.5</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_UPLOAD_THREADS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_UPLOAD_THREADS">S3FILEIO_MULTIPART_UPLOAD_THREADS</a></code></td>
+<td class="colLast"><code>"s3.multipart.num-threads"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_PATH_STYLE_ACCESS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS">S3FILEIO_PATH_STYLE_ACCESS</a></code></td>
+<td class="colLast"><code>"s3.path-style-access"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_PATH_STYLE_ACCESS_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS_DEFAULT">S3FILEIO_PATH_STYLE_ACCESS_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SECRET_ACCESS_KEY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SECRET_ACCESS_KEY">S3FILEIO_SECRET_ACCESS_KEY</a></code></td>
+<td class="colLast"><code>"s3.secret-access-key"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SESSION_TOKEN">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SESSION_TOKEN">S3FILEIO_SESSION_TOKEN</a></code></td>
+<td class="colLast"><code>"s3.session-token"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_KEY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_KEY">S3FILEIO_SSE_KEY</a></code></td>
+<td class="colLast"><code>"s3.sse.key"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_MD5">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_MD5">S3FILEIO_SSE_MD5</a></code></td>
+<td class="colLast"><code>"s3.sse.md5"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE">S3FILEIO_SSE_TYPE</a></code></td>
+<td class="colLast"><code>"s3.sse.type"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_CUSTOM">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_CUSTOM">S3FILEIO_SSE_TYPE_CUSTOM</a></code></td>
+<td class="colLast"><code>"custom"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_KMS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_KMS">S3FILEIO_SSE_TYPE_KMS</a></code></td>
+<td class="colLast"><code>"kms"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_NONE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_NONE">S3FILEIO_SSE_TYPE_NONE</a></code></td>
+<td class="colLast"><code>"none"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_S3">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_S3">S3FILEIO_SSE_TYPE_S3</a></code></td>
+<td class="colLast"><code>"s3"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_STAGING_DIRECTORY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_STAGING_DIRECTORY">S3FILEIO_STAGING_DIRECTORY</a></code></td>
+<td class="colLast"><code>"s3.staging-dir"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS">APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS</a></code></td>
+<td class="colLast"><code>"http-client.apache.connection-acquisition-timeout-ms"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_CONNECTION_MAX_IDLE_TIME_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_MAX_IDLE_TIME_MS">APACHE_CONNECTION_MAX_IDLE_TIME_MS</a></code></td>
+<td class="colLast"><code>"http-client.apache.connection-max-idle-time-ms"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_CONNECTION_TIME_TO_LIVE_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_TIME_TO_LIVE_MS">APACHE_CONNECTION_TIME_TO_LIVE_MS</a></code></td>
+<td class="colLast"><code>"http-client.apache.connection-time-to-live-ms"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_CONNECTION_TIMEOUT_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_TIMEOUT_MS">APACHE_CONNECTION_TIMEOUT_MS</a></code></td>
+<td class="colLast"><code>"http-client.apache.connection-timeout-ms"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_EXPECT_CONTINUE_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_EXPECT_CONTINUE_ENABLED">APACHE_EXPECT_CONTINUE_ENABLED</a></code></td>
+<td class="colLast"><code>"http-client.apache.expect-continue-enabled"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_MAX_CONNECTIONS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_MAX_CONNECTIONS">APACHE_MAX_CONNECTIONS</a></code></td>
+<td class="colLast"><code>"http-client.apache.max-connections"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_SOCKET_TIMEOUT_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_SOCKET_TIMEOUT_MS">APACHE_SOCKET_TIMEOUT_MS</a></code></td>
+<td class="colLast"><code>"http-client.apache.socket-timeout-ms"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_TCP_KEEP_ALIVE_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_TCP_KEEP_ALIVE_ENABLED">APACHE_TCP_KEEP_ALIVE_ENABLED</a></code></td>
+<td class="colLast"><code>"http-client.apache.tcp-keep-alive-enabled"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED">APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED</a></code></td>
+<td class="colLast"><code>"http-client.apache.use-idle-connection-reaper-enabled"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.CLIENT_TYPE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE">CLIENT_TYPE</a></code></td>
+<td class="colLast"><code>"http-client.type"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.CLIENT_TYPE_APACHE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE_APACHE">CLIENT_TYPE_APACHE</a></code></td>
+<td class="colLast"><code>"apache"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.CLIENT_TYPE_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE_DEFAULT">CLIENT_TYPE_DEFAULT</a></code></td>
+<td class="colLast"><code>"apache"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.CLIENT_TYPE_URLCONNECTION">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE_URLCONNECTION">CLIENT_TYPE_URLCONNECTION</a></code></td>
+<td class="colLast"><code>"urlconnection"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.URLCONNECTION_CONNECTION_TIMEOUT_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#URLCONNECTION_CONNECTION_TIMEOUT_MS">URLCONNECTION_CONNECTION_TIMEOUT_MS</a></code></td>
+<td class="colLast"><code>"http-client.urlconnection.connection-timeout-ms"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.HttpClientProperties.URLCONNECTION_SOCKET_TIMEOUT_MS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/HttpClientProperties.html#URLCONNECTION_SOCKET_TIMEOUT_MS">URLCONNECTION_SOCKET_TIMEOUT_MS</a></code></td>
+<td class="colLast"><code>"http-client.urlconnection.socket-timeout-ms"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+<ul class="blockList">
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.aws.lakeformation.<a href="org/apache/iceberg/aws/lakeformation/LakeFormationAwsClientFactory.html" title="class in org.apache.iceberg.aws.lakeformation">LakeFormationAwsClientFactory</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.lakeformation.LakeFormationAwsClientFactory.LF_AUTHORIZED_CALLER">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/lakeformation/LakeFormationAwsClientFactory.html#LF_AUTHORIZED_CALLER">LF_AUTHORIZED_CALLER</a></code></td>
+<td class="colLast"><code>"LakeFormationAuthorizedCaller"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+<ul class="blockList">
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.ACCELERATION_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCELERATION_ENABLED">ACCELERATION_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.acceleration-enabled"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.ACCELERATION_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCELERATION_ENABLED_DEFAULT">ACCELERATION_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.ACCESS_KEY_ID">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCESS_KEY_ID">ACCESS_KEY_ID</a></code></td>
+<td class="colLast"><code>"s3.access-key-id"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.ACCESS_POINTS_PREFIX">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCESS_POINTS_PREFIX">ACCESS_POINTS_PREFIX</a></code></td>
+<td class="colLast"><code>"s3.access-points."</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.ACL">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACL">ACL</a></code></td>
+<td class="colLast"><code>"s3.acl"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.CHECKSUM_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CHECKSUM_ENABLED">CHECKSUM_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.checksum-enabled"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.CHECKSUM_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CHECKSUM_ENABLED_DEFAULT">CHECKSUM_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.CLIENT_FACTORY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CLIENT_FACTORY">CLIENT_FACTORY</a></code></td>
+<td class="colLast"><code>"s3.client-factory-impl"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_BATCH_SIZE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_BATCH_SIZE">DELETE_BATCH_SIZE</a></code></td>
+<td class="colLast"><code>"s3.delete.batch-size"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_BATCH_SIZE_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_BATCH_SIZE_DEFAULT">DELETE_BATCH_SIZE_DEFAULT</a></code></td>
+<td class="colLast"><code>250</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_BATCH_SIZE_MAX">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_BATCH_SIZE_MAX">DELETE_BATCH_SIZE_MAX</a></code></td>
+<td class="colLast"><code>1000</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_ENABLED">DELETE_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.delete-enabled"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_ENABLED_DEFAULT">DELETE_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>true</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_TAGS_PREFIX">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_TAGS_PREFIX">DELETE_TAGS_PREFIX</a></code></td>
+<td class="colLast"><code>"s3.delete.tags."</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DELETE_THREADS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_THREADS">DELETE_THREADS</a></code></td>
+<td class="colLast"><code>"s3.delete.num-threads"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DUALSTACK_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DUALSTACK_ENABLED">DUALSTACK_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.dualstack-enabled"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.DUALSTACK_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DUALSTACK_ENABLED_DEFAULT">DUALSTACK_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.ENDPOINT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ENDPOINT">ENDPOINT</a></code></td>
+<td class="colLast"><code>"s3.endpoint"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.MULTIPART_SIZE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_SIZE">MULTIPART_SIZE</a></code></td>
+<td class="colLast"><code>"s3.multipart.part-size-bytes"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.MULTIPART_SIZE_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_SIZE_DEFAULT">MULTIPART_SIZE_DEFAULT</a></code></td>
+<td class="colLast"><code>33554432</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.MULTIPART_SIZE_MIN">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;int</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_SIZE_MIN">MULTIPART_SIZE_MIN</a></code></td>
+<td class="colLast"><code>5242880</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.MULTIPART_THRESHOLD_FACTOR">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_THRESHOLD_FACTOR">MULTIPART_THRESHOLD_FACTOR</a></code></td>
+<td class="colLast"><code>"s3.multipart.threshold"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.MULTIPART_THRESHOLD_FACTOR_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;double</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_THRESHOLD_FACTOR_DEFAULT">MULTIPART_THRESHOLD_FACTOR_DEFAULT</a></code></td>
+<td class="colLast"><code>1.5</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.MULTIPART_UPLOAD_THREADS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_UPLOAD_THREADS">MULTIPART_UPLOAD_THREADS</a></code></td>
+<td class="colLast"><code>"s3.multipart.num-threads"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.PATH_STYLE_ACCESS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PATH_STYLE_ACCESS">PATH_STYLE_ACCESS</a></code></td>
+<td class="colLast"><code>"s3.path-style-access"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.PATH_STYLE_ACCESS_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PATH_STYLE_ACCESS_DEFAULT">PATH_STYLE_ACCESS_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.PRELOAD_CLIENT_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PRELOAD_CLIENT_ENABLED">PRELOAD_CLIENT_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.preload-client-enabled"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.PRELOAD_CLIENT_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PRELOAD_CLIENT_ENABLED_DEFAULT">PRELOAD_CLIENT_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.REMOTE_SIGNING_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#REMOTE_SIGNING_ENABLED">REMOTE_SIGNING_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.remote-signing-enabled"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.REMOTE_SIGNING_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#REMOTE_SIGNING_ENABLED_DEFAULT">REMOTE_SIGNING_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.S3_TAG_ICEBERG_NAMESPACE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#S3_TAG_ICEBERG_NAMESPACE">S3_TAG_ICEBERG_NAMESPACE</a></code></td>
+<td class="colLast"><code>"iceberg.namespace"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.S3_TAG_ICEBERG_TABLE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#S3_TAG_ICEBERG_TABLE">S3_TAG_ICEBERG_TABLE</a></code></td>
+<td class="colLast"><code>"iceberg.table"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SECRET_ACCESS_KEY">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR">S3FILEIO_MULTIPART_THRESHOLD_FACTOR</a></code></td>
-<td class="colLast"><code>"s3.multipart.threshold"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SECRET_ACCESS_KEY">SECRET_ACCESS_KEY</a></code></td>
+<td class="colLast"><code>"s3.secret-access-key"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SESSION_TOKEN">
 <!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;double</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT">S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT</a></code></td>
-<td class="colLast"><code>1.5</code></td>
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SESSION_TOKEN">SESSION_TOKEN</a></code></td>
+<td class="colLast"><code>"s3.session-token"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_UPLOAD_THREADS">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_KEY">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_UPLOAD_THREADS">S3FILEIO_MULTIPART_UPLOAD_THREADS</a></code></td>
-<td class="colLast"><code>"s3.multipart.num-threads"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_KEY">SSE_KEY</a></code></td>
+<td class="colLast"><code>"s3.sse.key"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_PATH_STYLE_ACCESS">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_MD5">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS">S3FILEIO_PATH_STYLE_ACCESS</a></code></td>
-<td class="colLast"><code>"s3.path-style-access"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_MD5">SSE_MD5</a></code></td>
+<td class="colLast"><code>"s3.sse.md5"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_PATH_STYLE_ACCESS_DEFAULT">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_TYPE">
 <!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS_DEFAULT">S3FILEIO_PATH_STYLE_ACCESS_DEFAULT</a></code></td>
-<td class="colLast"><code>false</code></td>
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE">SSE_TYPE</a></code></td>
+<td class="colLast"><code>"s3.sse.type"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SECRET_ACCESS_KEY">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_TYPE_CUSTOM">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SECRET_ACCESS_KEY">S3FILEIO_SECRET_ACCESS_KEY</a></code></td>
-<td class="colLast"><code>"s3.secret-access-key"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_CUSTOM">SSE_TYPE_CUSTOM</a></code></td>
+<td class="colLast"><code>"custom"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SESSION_TOKEN">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_TYPE_KMS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SESSION_TOKEN">S3FILEIO_SESSION_TOKEN</a></code></td>
-<td class="colLast"><code>"s3.session-token"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_KMS">SSE_TYPE_KMS</a></code></td>
+<td class="colLast"><code>"kms"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_KEY">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_TYPE_NONE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_KEY">S3FILEIO_SSE_KEY</a></code></td>
-<td class="colLast"><code>"s3.sse.key"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_NONE">SSE_TYPE_NONE</a></code></td>
+<td class="colLast"><code>"none"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_MD5">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.SSE_TYPE_S3">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_MD5">S3FILEIO_SSE_MD5</a></code></td>
-<td class="colLast"><code>"s3.sse.md5"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_S3">SSE_TYPE_S3</a></code></td>
+<td class="colLast"><code>"s3"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.STAGING_DIRECTORY">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE">S3FILEIO_SSE_TYPE</a></code></td>
-<td class="colLast"><code>"s3.sse.type"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#STAGING_DIRECTORY">STAGING_DIRECTORY</a></code></td>
+<td class="colLast"><code>"s3.staging-dir"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_CUSTOM">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.USE_ARN_REGION_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_CUSTOM">S3FILEIO_SSE_TYPE_CUSTOM</a></code></td>
-<td class="colLast"><code>"custom"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#USE_ARN_REGION_ENABLED">USE_ARN_REGION_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.use-arn-region-enabled"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_KMS">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.USE_ARN_REGION_ENABLED_DEFAULT">
 <!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_KMS">S3FILEIO_SSE_TYPE_KMS</a></code></td>
-<td class="colLast"><code>"kms"</code></td>
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#USE_ARN_REGION_ENABLED_DEFAULT">USE_ARN_REGION_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_NONE">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.WRITE_NAMESPACE_TAG_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_NONE">S3FILEIO_SSE_TYPE_NONE</a></code></td>
-<td class="colLast"><code>"none"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_NAMESPACE_TAG_ENABLED">WRITE_NAMESPACE_TAG_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.write.namespace-tag-enabled"</code></td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_S3">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.WRITE_NAMESPACE_TAG_ENABLED_DEFAULT">
 <!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_S3">S3FILEIO_SSE_TYPE_S3</a></code></td>
-<td class="colLast"><code>"s3"</code></td>
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_NAMESPACE_TAG_ENABLED_DEFAULT">WRITE_NAMESPACE_TAG_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.AwsProperties.S3FILEIO_STAGING_DIRECTORY">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.WRITE_TABLE_TAG_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_STAGING_DIRECTORY">S3FILEIO_STAGING_DIRECTORY</a></code></td>
-<td class="colLast"><code>"s3.staging-dir"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TABLE_TAG_ENABLED">WRITE_TABLE_TAG_ENABLED</a></code></td>
+<td class="colLast"><code>"s3.write.table-tag-enabled"</code></td>
 </tr>
-</tbody>
-</table>
-</li>
-</ul>
-<ul class="blockList">
-<li class="blockList">
-<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
-<caption><span>org.apache.iceberg.aws.lakeformation.<a href="org/apache/iceberg/aws/lakeformation/LakeFormationAwsClientFactory.html" title="class in org.apache.iceberg.aws.lakeformation">LakeFormationAwsClientFactory</a></span><span class="tabEnd">&nbsp;</span></caption>
-<tr>
-<th class="colFirst" scope="col">Modifier and Type</th>
-<th scope="col">Constant Field</th>
-<th class="colLast" scope="col">Value</th>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.WRITE_TABLE_TAG_ENABLED_DEFAULT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TABLE_TAG_ENABLED_DEFAULT">WRITE_TABLE_TAG_ENABLED_DEFAULT</a></code></td>
+<td class="colLast"><code>false</code></td>
 </tr>
-<tbody>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.aws.lakeformation.LakeFormationAwsClientFactory.LF_AUTHORIZED_CALLER">
+<td class="colFirst"><a name="org.apache.iceberg.aws.s3.S3FileIOProperties.WRITE_TAGS_PREFIX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/aws/lakeformation/LakeFormationAwsClientFactory.html#LF_AUTHORIZED_CALLER">LF_AUTHORIZED_CALLER</a></code></td>
-<td class="colLast"><code>"LakeFormationAuthorizedCaller"</code></td>
+<td><code><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TAGS_PREFIX">WRITE_TAGS_PREFIX</a></code></td>
+<td class="colLast"><code>"s3.write.tags."</code></td>
 </tr>
 </tbody>
 </table>
@@ -3297,48 +4020,55 @@
 <td class="colLast"><code>"limit"</code></td>
 </tr>
 <tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.MAX_ALLOWED_PLANNING_FAILURES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#MAX_ALLOWED_PLANNING_FAILURES">MAX_ALLOWED_PLANNING_FAILURES</a></code></td>
+<td class="colLast"><code>"max-allowed-planning-failures"</code></td>
+</tr>
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.MAX_PLANNING_SNAPSHOT_COUNT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#MAX_PLANNING_SNAPSHOT_COUNT">MAX_PLANNING_SNAPSHOT_COUNT</a></code></td>
 <td class="colLast"><code>"max-planning-snapshot-count"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.MONITOR_INTERVAL">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#MONITOR_INTERVAL">MONITOR_INTERVAL</a></code></td>
 <td class="colLast"><code>"monitor-interval"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.SPLIT_FILE_OPEN_COST">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#SPLIT_FILE_OPEN_COST">SPLIT_FILE_OPEN_COST</a></code></td>
 <td class="colLast"><code>"split-file-open-cost"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.SPLIT_LOOKBACK">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#SPLIT_LOOKBACK">SPLIT_LOOKBACK</a></code></td>
 <td class="colLast"><code>"split-lookback"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.SPLIT_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#SPLIT_SIZE">SPLIT_SIZE</a></code></td>
 <td class="colLast"><code>"split-size"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.STARTING_STRATEGY">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/flink/FlinkReadOptions.html#STARTING_STRATEGY">STARTING_STRATEGY</a></code></td>
 <td class="colLast"><code>"starting-strategy"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.flink.FlinkReadOptions.STREAMING">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
@@ -3443,6 +4173,13 @@
 <td><code><a href="org/apache/iceberg/hadoop/ConfigProperties.html#KEEP_HIVE_STATS">KEEP_HIVE_STATS</a></code></td>
 <td class="colLast"><code>"iceberg.hive.keep.stats"</code></td>
 </tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.hadoop.ConfigProperties.LOCK_HIVE_ENABLED">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/hadoop/ConfigProperties.html#LOCK_HIVE_ENABLED">LOCK_HIVE_ENABLED</a></code></td>
+<td class="colLast"><code>"iceberg.engine.hive.lock-enabled"</code></td>
+</tr>
 </tbody>
 </table>
 </li>
@@ -4604,139 +5341,146 @@
 <td class="colLast"><code>"file-open-cost"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.FILE_SCAN_TASK_SET_ID">
-<!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#FILE_SCAN_TASK_SET_ID">FILE_SCAN_TASK_SET_ID</a></code></td>
-<td class="colLast"><code>"file-scan-task-set-id"</code></td>
-</tr>
-<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></code></td>
 <td class="colLast"><code>"handle-timestamp-without-timezone"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.LOCALITY">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#LOCALITY">LOCALITY</a></code></td>
 <td class="colLast"><code>"locality"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.LOOKBACK">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#LOOKBACK">LOOKBACK</a></code></td>
 <td class="colLast"><code>"lookback"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.PATH">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#PATH">PATH</a></code></td>
 <td class="colLast"><code>"path"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.SCAN_TASK_SET_ID">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#SCAN_TASK_SET_ID">SCAN_TASK_SET_ID</a></code></td>
 <td class="colLast"><code>"scan-task-set-id"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.SNAPSHOT_ID">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#SNAPSHOT_ID">SNAPSHOT_ID</a></code></td>
 <td class="colLast"><code>"snapshot-id"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.SPLIT_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#SPLIT_SIZE">SPLIT_SIZE</a></code></td>
 <td class="colLast"><code>"split-size"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.START_SNAPSHOT_ID">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#START_SNAPSHOT_ID">START_SNAPSHOT_ID</a></code></td>
 <td class="colLast"><code>"start-snapshot-id"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.START_TIMESTAMP">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#START_TIMESTAMP">START_TIMESTAMP</a></code></td>
 <td class="colLast"><code>"start-timestamp"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAM_FROM_TIMESTAMP">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAM_FROM_TIMESTAMP">STREAM_FROM_TIMESTAMP</a></code></td>
 <td class="colLast"><code>"stream-from-timestamp"</code></td>
 </tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAMING_MAX_FILES_PER_MICRO_BATCH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_MAX_FILES_PER_MICRO_BATCH">STREAMING_MAX_FILES_PER_MICRO_BATCH</a></code></td>
+<td class="colLast"><code>"streaming-max-files-per-micro-batch"</code></td>
+</tr>
 <tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAMING_MAX_ROWS_PER_MICRO_BATCH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_MAX_ROWS_PER_MICRO_BATCH">STREAMING_MAX_ROWS_PER_MICRO_BATCH</a></code></td>
+<td class="colLast"><code>"streaming-max-rows-per-micro-batch"</code></td>
+</tr>
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAMING_SKIP_DELETE_SNAPSHOTS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_SKIP_DELETE_SNAPSHOTS">STREAMING_SKIP_DELETE_SNAPSHOTS</a></code></td>
 <td class="colLast"><code>"streaming-skip-delete-snapshots"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAMING_SKIP_DELETE_SNAPSHOTS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_SKIP_DELETE_SNAPSHOTS_DEFAULT">STREAMING_SKIP_DELETE_SNAPSHOTS_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAMING_SKIP_OVERWRITE_SNAPSHOTS">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_SKIP_OVERWRITE_SNAPSHOTS">STREAMING_SKIP_OVERWRITE_SNAPSHOTS</a></code></td>
 <td class="colLast"><code>"streaming-skip-overwrite-snapshots"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.STREAMING_SKIP_OVERWRITE_SNAPSHOTS_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_SKIP_OVERWRITE_SNAPSHOTS_DEFAULT">STREAMING_SKIP_OVERWRITE_SNAPSHOTS_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.TAG">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#TAG">TAG</a></code></td>
 <td class="colLast"><code>"tag"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.TIMESTAMP_AS_OF">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#TIMESTAMP_AS_OF">TIMESTAMP_AS_OF</a></code></td>
 <td class="colLast"><code>"timestampAsOf"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.VECTORIZATION_BATCH_SIZE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#VECTORIZATION_BATCH_SIZE">VECTORIZATION_BATCH_SIZE</a></code></td>
 <td class="colLast"><code>"batch-size"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.VECTORIZATION_ENABLED">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkReadOptions.html#VECTORIZATION_ENABLED">VECTORIZATION_ENABLED</a></code></td>
 <td class="colLast"><code>"vectorization-enabled"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkReadOptions.VERSION_AS_OF">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
@@ -4812,40 +5556,26 @@
 <td class="colLast"><code>"spark.sql.iceberg.handle-timestamp-without-timezone"</code></td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.spark.SparkSQLProperties.HANDLE_TIMESTAMP_WITHOUT_TIMEZONE_DEFAULT">
-<!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
-<td><code><a href="org/apache/iceberg/spark/SparkSQLProperties.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE_DEFAULT">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE_DEFAULT</a></code></td>
-<td class="colLast"><code>false</code></td>
-</tr>
-<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkSQLProperties.PRESERVE_DATA_GROUPING">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkSQLProperties.html#PRESERVE_DATA_GROUPING">PRESERVE_DATA_GROUPING</a></code></td>
 <td class="colLast"><code>"spark.sql.iceberg.planning.preserve-data-grouping"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkSQLProperties.PRESERVE_DATA_GROUPING_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkSQLProperties.html#PRESERVE_DATA_GROUPING_DEFAULT">PRESERVE_DATA_GROUPING_DEFAULT</a></code></td>
 <td class="colLast"><code>false</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkSQLProperties.USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkSQLProperties.html#USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES">USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES</a></code></td>
 <td class="colLast"><code>"spark.sql.iceberg.use-timestamp-without-timezone-in-new-tables"</code></td>
 </tr>
-<tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.spark.SparkSQLProperties.USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES_DEFAULT">
-<!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
-<td><code><a href="org/apache/iceberg/spark/SparkSQLProperties.html#USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES_DEFAULT">USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES_DEFAULT</a></code></td>
-<td class="colLast"><code>false</code></td>
-</tr>
 <tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkSQLProperties.VECTORIZATION_ENABLED">
 <!--   -->
@@ -4943,69 +5673,76 @@
 <td class="colLast"><code>false</code></td>
 </tr>
 <tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.OUTPUT_SPEC_ID">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#OUTPUT_SPEC_ID">OUTPUT_SPEC_ID</a></code></td>
+<td class="colLast"><code>"output-spec-id"</code></td>
+</tr>
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.OVERWRITE_MODE">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#OVERWRITE_MODE">OVERWRITE_MODE</a></code></td>
 <td class="colLast"><code>"overwrite-mode"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.REWRITTEN_FILE_SCAN_TASK_SET_ID">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#REWRITTEN_FILE_SCAN_TASK_SET_ID">REWRITTEN_FILE_SCAN_TASK_SET_ID</a></code></td>
 <td class="colLast"><code>"rewritten-file-scan-task-set-id"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.SNAPSHOT_PROPERTY_PREFIX">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#SNAPSHOT_PROPERTY_PREFIX">SNAPSHOT_PROPERTY_PREFIX</a></code></td>
 <td class="colLast"><code>"snapshot-property"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.SPARK_MERGE_SCHEMA">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#SPARK_MERGE_SCHEMA">SPARK_MERGE_SCHEMA</a></code></td>
 <td class="colLast"><code>"mergeSchema"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.TARGET_DELETE_FILE_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#TARGET_DELETE_FILE_SIZE_BYTES">TARGET_DELETE_FILE_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"target-delete-file-size-bytes"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.TARGET_FILE_SIZE_BYTES">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#TARGET_FILE_SIZE_BYTES">TARGET_FILE_SIZE_BYTES</a></code></td>
 <td class="colLast"><code>"target-file-size-bytes"</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.USE_TABLE_DISTRIBUTION_AND_ORDERING">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#USE_TABLE_DISTRIBUTION_AND_ORDERING">USE_TABLE_DISTRIBUTION_AND_ORDERING</a></code></td>
 <td class="colLast"><code>"use-table-distribution-and-ordering"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.USE_TABLE_DISTRIBUTION_AND_ORDERING_DEFAULT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;boolean</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#USE_TABLE_DISTRIBUTION_AND_ORDERING_DEFAULT">USE_TABLE_DISTRIBUTION_AND_ORDERING_DEFAULT</a></code></td>
 <td class="colLast"><code>true</code></td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.VALIDATE_FROM_SNAPSHOT_ID">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
 <td><code><a href="org/apache/iceberg/spark/SparkWriteOptions.html#VALIDATE_FROM_SNAPSHOT_ID">VALIDATE_FROM_SNAPSHOT_ID</a></code></td>
 <td class="colLast"><code>"validate-from-snapshot-id"</code></td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a name="org.apache.iceberg.spark.SparkWriteOptions.WRITE_FORMAT">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
@@ -5399,6 +6136,60 @@
 </li>
 <li class="blockList">
 <table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewritePositionDeleteFilesSparkAction</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.actions.RewritePositionDeleteFilesSparkAction.FILE_PATH">
+<!--   -->
+</a><code>protected&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code>FILE_PATH</code></td>
+<td class="colLast"><code>"file_path"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.actions.RewritePositionDeleteFilesSparkAction.LAST_MODIFIED">
+<!--   -->
+</a><code>protected&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code>LAST_MODIFIED</code></td>
+<td class="colLast"><code>"last_modified"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.actions.RewritePositionDeleteFilesSparkAction.MANIFEST">
+<!--   -->
+</a><code>protected&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code>MANIFEST</code></td>
+<td class="colLast"><code>"Manifest"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.actions.RewritePositionDeleteFilesSparkAction.MANIFEST_LIST">
+<!--   -->
+</a><code>protected&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code>MANIFEST_LIST</code></td>
+<td class="colLast"><code>"Manifest List"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.actions.RewritePositionDeleteFilesSparkAction.OTHERS">
+<!--   -->
+</a><code>protected&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code>OTHERS</code></td>
+<td class="colLast"><code>"Others"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.iceberg.spark.actions.RewritePositionDeleteFilesSparkAction.STATISTICS_FILES">
+<!--   -->
+</a><code>protected&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
+<td><code>STATISTICS_FILES</code></td>
+<td class="colLast"><code>"Statistics Files"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
 <caption><span>org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html" title="class in org.apache.iceberg.spark.actions">SnapshotTableSparkAction</a></span><span class="tabEnd">&nbsp;</span></caption>
 <tr>
 <th class="colFirst" scope="col">Modifier and Type</th>
@@ -5465,25 +6256,6 @@
 </tbody>
 </table>
 </li>
-<li class="blockList">
-<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
-<caption><span>org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></span><span class="tabEnd">&nbsp;</span></caption>
-<tr>
-<th class="colFirst" scope="col">Modifier and Type</th>
-<th scope="col">Constant Field</th>
-<th class="colLast" scope="col">Value</th>
-</tr>
-<tbody>
-<tr class="altColor">
-<td class="colFirst"><a name="org.apache.iceberg.spark.actions.SparkSortStrategy.COMPRESSION_FACTOR">
-<!--   -->
-</a><code>public&nbsp;static&nbsp;final&nbsp;java.lang.String</code></td>
-<td><code><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#COMPRESSION_FACTOR">COMPRESSION_FACTOR</a></code></td>
-<td class="colLast"><code>"compression-factor"</code></td>
-</tr>
-</tbody>
-</table>
-</li>
 </ul>
 <ul class="blockList">
 <li class="blockList">
diff --git a/javadoc/deprecated-list.html b/javadoc/deprecated-list.html
index d6a9984c..5d8d98af 100644
--- a/javadoc/deprecated-list.html
+++ b/javadoc/deprecated-list.html
@@ -76,7 +76,6 @@
 <li><a href="#exception">Deprecated Exceptions</a></li>
 <li><a href="#field">Deprecated Fields</a></li>
 <li><a href="#method">Deprecated Methods</a></li>
-<li><a href="#constructor">Deprecated Constructors</a></li>
 </ul>
 </div>
 <div class="contentContainer"><a name="interface">
@@ -100,6 +99,16 @@
 <div class="block"><span class="deprecationComment">will be removed in 2.0.0, use <a href="org/apache/iceberg/metrics/Counter.html" title="interface in org.apache.iceberg.metrics"><code>Counter</code></a> instead.</span></div>
 </td>
 </tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">org.apache.iceberg.actions.RewritePositionDeleteStrategy</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; Use <a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><code>SizeBasedFileRewriter</code></a> instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">org.apache.iceberg.actions.RewriteStrategy</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; use <a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions"><code>FileRewriter</code></a> instead.</span></div>
+</td>
+</tr>
 </tbody>
 </table>
 </li>
@@ -116,20 +125,80 @@
 </tr>
 <tbody>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseExpireSnapshotsActionResult</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseDeleteOrphanFilesActionResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableDeleteOrphanFiles.Result.builder()</code>
+     instead.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseDeleteReachableFilesActionResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableDeleteReachableFiles.Result.builder()</code>
+     instead.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseFileGroupRewriteResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteDataFiles.FileGroupRewriteResult.builder()</code> instead.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseMigrateTableActionResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseMigrateTableActionResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableMigrateTable.Result.builder()</code> instead.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseRewriteDataFilesFileGroupInfo</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteDataFiles.FileGroupInfo.builder()</code> instead.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseRewriteDataFilesResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteDataFiles.Result.builder()</code>
+     instead.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseRewriteManifestsActionResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteManifests.Result.builder()</code>
+     instead.</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">org.apache.iceberg.spark.FileScanTaskSetManager</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark"><code>ScanTaskSetManager</code></a> instead</span></div>
+<td class="colOne"><a href="org/apache/iceberg/actions/BaseSnapshotTableActionResult.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BaseSnapshotTableActionResult</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableSnapshotTable.Result.builder()</code>
+     instead.</span></div>
 </td>
 </tr>
 <tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.BinPackStrategy</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; use <a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><code>SizeBasedFileRewriter</code></a> instead.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
 <td class="colOne"><a href="org/apache/iceberg/parquet/ParquetWriteAdapter.html" title="class in org.apache.iceberg.parquet">org.apache.iceberg.parquet.ParquetWriteAdapter</a>
 <div class="block"><span class="deprecationComment">use <code>ParquetWriter</code></span></div>
 </td>
 </tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">org.apache.iceberg.actions.SortStrategy</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; use <a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><code>SizeBasedFileRewriter</code></a> instead.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedLengthDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator.FixedLengthDecimalBatchReader</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntBackedDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator.IntBackedDecimalBatchReader</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBackedDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator.LongBackedDecimalBatchReader</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</td>
+</tr>
 </tbody>
 </table>
 </li>
@@ -167,25 +236,114 @@
 </tr>
 <tbody>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/CatalogProperties.html#AUTH_DEFAULT_REFRESH_ENABLED">org.apache.iceberg.CatalogProperties.AUTH_DEFAULT_REFRESH_ENABLED</a>
-<div class="block"><span class="deprecationComment">Will be removed in 1.3.0; Use <a href="org/apache/iceberg/rest/auth/OAuth2Properties.html#TOKEN_REFRESH_ENABLED"><code>OAuth2Properties.TOKEN_REFRESH_ENABLED</code></a> to control token
-     refresh behavior.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_CREDENTIALS_PROVIDER">org.apache.iceberg.aws.AwsProperties.CLIENT_CREDENTIALS_PROVIDER</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><code>AwsClientProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/CatalogProperties.html#AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT">org.apache.iceberg.CatalogProperties.AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT</a>
-<div class="block"><span class="deprecationComment">Will be removed in 1.3.0; Use <a href="org/apache/iceberg/rest/auth/OAuth2Properties.html#TOKEN_REFRESH_ENABLED_DEFAULT"><code>OAuth2Properties.TOKEN_REFRESH_ENABLED_DEFAULT</code></a> to control
-     default token refresh behavior.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_REGION">org.apache.iceberg.aws.AwsProperties.CLIENT_REGION</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><code>AwsClientProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/SparkReadOptions.html#FILE_SCAN_TASK_SET_ID">org.apache.iceberg.spark.SparkReadOptions.FILE_SCAN_TASK_SET_ID</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use SCAN_TASK_SET_ID instead</span></div>
+<td class="colOne"><a href="org/apache/iceberg/spark/SparkReadOptions.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">org.apache.iceberg.spark.SparkReadOptions.HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">org.apache.iceberg.spark.SparkSQLProperties.HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">org.apache.iceberg.spark.SparkWriteOptions.HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_MAX_IDLE_TIME_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_CONNECTION_MAX_IDLE_TIME_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/TableProperties.html#HMS_TABLE_OWNER">org.apache.iceberg.TableProperties.HMS_TABLE_OWNER</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use the HMS_TABLE_OWNER constant from HiveCatalog</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_TIME_TO_LIVE_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_CONNECTION_TIME_TO_LIVE_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_TIMEOUT_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_CONNECTION_TIMEOUT_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_EXPECT_CONTINUE_ENABLED">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_EXPECT_CONTINUE_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_MAX_CONNECTIONS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_MAX_CONNECTIONS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_SOCKET_TIMEOUT_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_SOCKET_TIMEOUT_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_TCP_KEEP_ALIVE_ENABLED">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_TCP_KEEP_ALIVE_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_TYPE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_APACHE">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_TYPE_APACHE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_DEFAULT">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_TYPE_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_URLCONNECTION">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_TYPE_URLCONNECTION</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_URLCONNECTION_CONNECTION_TIMEOUT_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_URLCONNECTION_CONNECTION_TIMEOUT_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_URLCONNECTION_SOCKET_TIMEOUT_MS">org.apache.iceberg.aws.AwsProperties.HTTP_CLIENT_URLCONNECTION_SOCKET_TIMEOUT_MS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
@@ -216,6 +374,294 @@
 </td>
 </tr>
 <tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_ACCELERATION_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_ACCELERATION_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_ACCELERATION_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_ACCELERATION_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_ACCESS_POINTS_PREFIX">org.apache.iceberg.aws.AwsProperties.S3_ACCESS_POINTS_PREFIX</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_CHECKSUM_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_CHECKSUM_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_CHECKSUM_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_CHECKSUM_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DELETE_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_DELETE_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DELETE_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_DELETE_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DELETE_TAGS_PREFIX">org.apache.iceberg.aws.AwsProperties.S3_DELETE_TAGS_PREFIX</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DUALSTACK_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_DUALSTACK_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DUALSTACK_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_DUALSTACK_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_PRELOAD_CLIENT_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_PRELOAD_CLIENT_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_PRELOAD_CLIENT_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_PRELOAD_CLIENT_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_REMOTE_SIGNING_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_REMOTE_SIGNING_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_REMOTE_SIGNING_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_REMOTE_SIGNING_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_TAG_ICEBERG_NAMESPACE">org.apache.iceberg.aws.AwsProperties.S3_TAG_ICEBERG_NAMESPACE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_TAG_ICEBERG_TABLE">org.apache.iceberg.aws.AwsProperties.S3_TAG_ICEBERG_TABLE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_USE_ARN_REGION_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_USE_ARN_REGION_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_USE_ARN_REGION_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_USE_ARN_REGION_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_NAMESPACE_TAG_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_WRITE_NAMESPACE_TAG_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_NAMESPACE_TAG_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_WRITE_NAMESPACE_TAG_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TABLE_TAG_ENABLED">org.apache.iceberg.aws.AwsProperties.S3_WRITE_TABLE_TAG_ENABLED</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TABLE_TAG_ENABLED_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3_WRITE_TABLE_TAG_ENABLED_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TAGS_PREFIX">org.apache.iceberg.aws.AwsProperties.S3_WRITE_TAGS_PREFIX</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_ACCESS_KEY_ID">org.apache.iceberg.aws.AwsProperties.S3FILEIO_ACCESS_KEY_ID</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_ACL">org.apache.iceberg.aws.AwsProperties.S3FILEIO_ACL</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_BATCH_SIZE">org.apache.iceberg.aws.AwsProperties.S3FILEIO_DELETE_BATCH_SIZE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_BATCH_SIZE_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3FILEIO_DELETE_BATCH_SIZE_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_BATCH_SIZE_MAX">org.apache.iceberg.aws.AwsProperties.S3FILEIO_DELETE_BATCH_SIZE_MAX</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_THREADS">org.apache.iceberg.aws.AwsProperties.S3FILEIO_DELETE_THREADS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_ENDPOINT">org.apache.iceberg.aws.AwsProperties.S3FILEIO_ENDPOINT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_SIZE">org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_SIZE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_SIZE_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_SIZE_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_SIZE_MIN">org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_SIZE_MIN</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR">org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_THRESHOLD_FACTOR</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_UPLOAD_THREADS">org.apache.iceberg.aws.AwsProperties.S3FILEIO_MULTIPART_UPLOAD_THREADS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS">org.apache.iceberg.aws.AwsProperties.S3FILEIO_PATH_STYLE_ACCESS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS_DEFAULT">org.apache.iceberg.aws.AwsProperties.S3FILEIO_PATH_STYLE_ACCESS_DEFAULT</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SECRET_ACCESS_KEY">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SECRET_ACCESS_KEY</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SESSION_TOKEN">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SESSION_TOKEN</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_KEY">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_KEY</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_MD5">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_MD5</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_CUSTOM">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_CUSTOM</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_KMS">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_KMS</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_NONE">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_NONE</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_S3">org.apache.iceberg.aws.AwsProperties.S3FILEIO_SSE_TYPE_S3</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_STAGING_DIRECTORY">org.apache.iceberg.aws.AwsProperties.S3FILEIO_STAGING_DIRECTORY</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
 <td class="colOne"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#tokenNames">org.apache.spark.sql.catalyst.parser.extensions.IcebergSqlExtensionsParser.tokenNames</a>
 <div class="block"><span class="deprecationComment">Use <a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#VOCABULARY"><code>IcebergSqlExtensionsParser.VOCABULARY</code></a> instead.</span></div>
 </td>
@@ -226,6 +672,9 @@
 </td>
 </tr>
 <tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES">org.apache.iceberg.spark.SparkSQLProperties.USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES</a></td>
+</tr>
+<tr class="altColor">
 <td class="colOne"><a href="org/apache/iceberg/TableProperties.html#WRITE_FOLDER_STORAGE_LOCATION">org.apache.iceberg.TableProperties.WRITE_FOLDER_STORAGE_LOCATION</a>
 <div class="block"><span class="deprecationComment">Use <a href="org/apache/iceberg/TableProperties.html#WRITE_DATA_LOCATION"><code>TableProperties.WRITE_DATA_LOCATION</code></a> instead.</span></div>
 </td>
@@ -263,31 +712,44 @@
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#bucket-org.apache.iceberg.types.Type-int-">org.apache.iceberg.transforms.Transforms.bucket(Type, int)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#bucket-int-"><code>Transforms.bucket(int)</code></a> instead; will be removed in 2.0.0</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#applyClientRegionConfiguration-T-">org.apache.iceberg.aws.AwsProperties.applyClientRegionConfiguration(T)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><code>AwsClientProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/rest/HTTPClient.html#builder--">org.apache.iceberg.rest.HTTPClient.builder()</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/HTTPClient.html#builder-java.util.Map-"><code>HTTPClient.builder(Map)</code></a></span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#applyHttpClientConfigurations-T-">org.apache.iceberg.aws.AwsProperties.applyHttpClientConfigurations(T)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-boolean-">org.apache.iceberg.spark.data.vectorized.VectorizedSparkParquetReaders.buildReader(Schema, MessageType, boolean)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-"><code>VectorizedSparkParquetReaders.buildReader(Schema, MessageType, Map,
-     DeleteFilter)</code></a> instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3CredentialConfigurations-T-">org.apache.iceberg.aws.AwsProperties.applyS3CredentialConfigurations(T)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-boolean-java.util.Map-">org.apache.iceberg.spark.data.vectorized.VectorizedSparkParquetReaders.buildReader(Schema, MessageType, boolean, Map&lt;Integer, ?&gt;)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-"><code>VectorizedSparkParquetReaders.buildReader(Schema, MessageType, Map,
-     DeleteFilter)</code></a> instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3EndpointConfigurations-T-">org.apache.iceberg.aws.AwsProperties.applyS3EndpointConfigurations(T)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-boolean-java.util.Map-org.apache.iceberg.data.DeleteFilter-">org.apache.iceberg.spark.data.vectorized.VectorizedSparkParquetReaders.buildReader(Schema, MessageType, boolean, Map&lt;Integer, ?&gt;, DeleteFilter&lt;InternalRow&gt;)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-"><code>VectorizedSparkParquetReaders.buildReader(Schema, MessageType, Map,
-     DeleteFilter)</code></a> instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3ServiceConfigurations-T-">org.apache.iceberg.aws.AwsProperties.applyS3ServiceConfigurations(T)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3SignerConfiguration-T-">org.apache.iceberg.aws.AwsProperties.applyS3SignerConfiguration(T)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#bucket-org.apache.iceberg.types.Type-int-">org.apache.iceberg.transforms.Transforms.bucket(Type, int)</a>
+<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#bucket-int-"><code>Transforms.bucket(int)</code></a> instead; will be removed in 2.0.0</span></div>
 </td>
 </tr>
 <tr class="altColor">
@@ -323,8 +785,8 @@
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/SparkReadConf.html#fileScanTaskSetId--">org.apache.iceberg.spark.SparkReadConf.fileScanTaskSetId()</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/SparkReadConf.html#scanTaskSetId--"><code>SparkReadConf.scanTaskSetId()</code></a> instead</span></div>
+<td class="colOne"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#fixedLengthDecimalBatchReader--">org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator.fixedLengthDecimalBatchReader()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
 </td>
 </tr>
 <tr class="rowColor">
@@ -333,21 +795,10 @@
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/Spark3Util.html#getPartitions-org.apache.spark.sql.SparkSession-org.apache.hadoop.fs.Path-java.lang.String-java.util.Map-">org.apache.iceberg.spark.Spark3Util.getPartitions(SparkSession, Path, String, Map&lt;String, String&gt;)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/spark/Spark3Util.html#getPartitions-org.apache.spark.sql.SparkSession-org.apache.hadoop.fs.Path-java.lang.String-java.util.Map-org.apache.iceberg.PartitionSpec-"><code>Spark3Util.getPartitions(SparkSession, Path, String, Map,
-     PartitionSpec)</code></a></span></div>
-</td>
-</tr>
-<tr class="rowColor">
 <td class="colOne"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#getTokenNames--">org.apache.spark.sql.catalyst.parser.extensions.IcebergSqlExtensionsParser.getTokenNames()</a></td>
 </tr>
-<tr class="altColor">
-<td class="colOne"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#getTokenNames--">org.apache.spark.sql.catalyst.parser.extensions.IcebergSqlExtensionsLexer.getTokenNames()</a></td>
-</tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/Partitioning.html#groupingKeyType-java.util.Collection-">org.apache.iceberg.Partitioning.groupingKeyType(Collection&lt;PartitionSpec&gt;)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/Partitioning.html#groupingKeyType-org.apache.iceberg.Schema-java.util.Collection-"><code>Partitioning.groupingKeyType(Schema, Collection)</code></a> instead; will be removed in 1.3.0</span></div>
-</td>
+<td class="colOne"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#getTokenNames--">org.apache.spark.sql.catalyst.parser.extensions.IcebergSqlExtensionsLexer.getTokenNames()</a></td>
 </tr>
 <tr class="altColor">
 <td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#hour-org.apache.iceberg.types.Type-">org.apache.iceberg.transforms.Transforms.hour(Type)</a>
@@ -360,120 +811,267 @@
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/SparkTableUtil.html#listPartition-org.apache.iceberg.spark.SparkTableUtil.SparkPartition-org.apache.iceberg.PartitionSpec-org.apache.iceberg.hadoop.SerializableConfiguration-org.apache.iceberg.MetricsConfig-">org.apache.iceberg.spark.SparkTableUtil.listPartition(SparkTableUtil.SparkPartition, PartitionSpec, SerializableConfiguration, MetricsConfig)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/data/TableMigrationUtil.html#listPartition-java.util.Map-java.lang.String-java.lang.String-org.apache.iceberg.PartitionSpec-org.apache.hadoop.conf.Configuration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-"><code>TableMigrationUtil.listPartition(Map, String, String, PartitionSpec,
-     Configuration, MetricsConfig, NameMapping)</code></a></span></div>
+<td class="colOne"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#intBackedDecimalBatchReader--">org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator.intBackedDecimalBatchReader()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/SparkTableUtil.html#listPartition-org.apache.iceberg.spark.SparkTableUtil.SparkPartition-org.apache.iceberg.PartitionSpec-org.apache.iceberg.hadoop.SerializableConfiguration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-">org.apache.iceberg.spark.SparkTableUtil.listPartition(SparkTableUtil.SparkPartition, PartitionSpec, SerializableConfiguration, MetricsConfig, NameMapping)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/data/TableMigrationUtil.html#listPartition-java.util.Map-java.lang.String-java.lang.String-org.apache.iceberg.PartitionSpec-org.apache.hadoop.conf.Configuration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-"><code>TableMigrationUtil.listPartition(Map, String, String, PartitionSpec,
-     Configuration, MetricsConfig, NameMapping)</code></a></span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#isS3ChecksumEnabled--">org.apache.iceberg.aws.AwsProperties.isS3ChecksumEnabled()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/spark/SparkTableUtil.html#loadCatalogMetadataTable-org.apache.spark.sql.SparkSession-org.apache.iceberg.Table-org.apache.iceberg.MetadataTableType-">org.apache.iceberg.spark.SparkTableUtil.loadCatalogMetadataTable(SparkSession, Table, MetadataTableType)</a>
-<div class="block"><span class="deprecationComment">since 0.14.0, will be removed in 0.15.0; use <a href="org/apache/iceberg/spark/SparkTableUtil.html#loadMetadataTable-org.apache.spark.sql.SparkSession-org.apache.iceberg.Table-org.apache.iceberg.MetadataTableType-"><code>SparkTableUtil.loadMetadataTable(SparkSession, Table, MetadataTableType)</code></a>.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#isS3DeleteEnabled--">org.apache.iceberg.aws.AwsProperties.isS3DeleteEnabled()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#longBackedDecimalBatchReader--">org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator.longBackedDecimalBatchReader()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</td>
+</tr>
+<tr class="altColor">
 <td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#month-org.apache.iceberg.types.Type-">org.apache.iceberg.transforms.Transforms.month(Type)</a>
 <div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#month--"><code>Transforms.month()</code></a> instead; will be removed in 2.0.0</span></div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colOne"><a href="org/apache/iceberg/BaseMetadataTable.html#operations--">org.apache.iceberg.BaseMetadataTable.operations()</a>
-<div class="block"><span class="deprecationComment">will be removed in 2.0.0; do not use metadata table TableOperations</span></div>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; do not use metadata table TableOperations</span></div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colOne"><a href="org/apache/iceberg/flink/source/FlinkSource.Builder.html#properties-java.util.Map-">org.apache.iceberg.flink.source.FlinkSource.Builder.properties(Map&lt;String, String&gt;)</a>
 <div class="block"><span class="deprecationComment">Use <a href="org/apache/iceberg/flink/source/FlinkSource.Builder.html#setAll-java.util.Map-"><code>FlinkSource.Builder.setAll(java.util.Map&lt;java.lang.String, java.lang.String&gt;)</code></a> instead.</span></div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colOne"><a href="org/apache/iceberg/flink/source/IcebergSource.Builder.html#properties-java.util.Map-">org.apache.iceberg.flink.source.IcebergSource.Builder.properties(Map&lt;String, String&gt;)</a>
 <div class="block"><span class="deprecationComment">Use <a href="org/apache/iceberg/flink/source/IcebergSource.Builder.html#setAll-java.util.Map-"><code>IcebergSource.Builder.setAll(java.util.Map&lt;java.lang.String, java.lang.String&gt;)</code></a> instead.</span></div>
 </td>
 </tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/RewriteFiles.html#rewriteFiles-java.util.Set-java.util.Set-">org.apache.iceberg.RewriteFiles.rewriteFiles(Set&lt;DataFile&gt;, Set&lt;DataFile&gt;)</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 2.0.0</span></div>
+</td>
+</tr>
 <tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/RewriteFiles.html#rewriteFiles-java.util.Set-java.util.Set-long-">org.apache.iceberg.RewriteFiles.rewriteFiles(Set&lt;DataFile&gt;, Set&lt;DataFile&gt;, long)</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 2.0.0</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/RewriteFiles.html#rewriteFiles-java.util.Set-java.util.Set-java.util.Set-java.util.Set-">org.apache.iceberg.RewriteFiles.rewriteFiles(Set&lt;DataFile&gt;, Set&lt;DeleteFile&gt;, Set&lt;DataFile&gt;, Set&lt;DeleteFile&gt;)</a>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 2.0.0</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3BucketToAccessPointMapping--">org.apache.iceberg.aws.AwsProperties.s3BucketToAccessPointMapping()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
 <td class="colOne"><a href="org/apache/iceberg/aws/AwsClientFactories.html#s3Configuration-java.lang.Boolean-java.lang.Boolean-">org.apache.iceberg.aws.AwsClientFactories.s3Configuration(Boolean, Boolean)</a>
 <div class="block"><span class="deprecationComment">Not for public use. To build an S3Configuration object, use
      S3Configuration.builder() directly. It will be removed in 2.0.0</span></div>
 </td>
 </tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3DeleteTags--">org.apache.iceberg.aws.AwsProperties.s3DeleteTags()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">org.apache.iceberg.jdbc.JdbcCatalog.setConf(Configuration)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/jdbc/JdbcCatalog.html#setConf-java.lang.Object-"><code>JdbcCatalog.setConf(Object)</code></a></span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoAcl--">org.apache.iceberg.aws.AwsProperties.s3FileIoAcl()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/rest/RESTSessionCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">org.apache.iceberg.rest.RESTSessionCatalog.setConf(Configuration)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/RESTSessionCatalog.html#setConf-java.lang.Object-"><code>RESTSessionCatalog.setConf(Object)</code></a></span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoDeleteBatchSize--">org.apache.iceberg.aws.AwsProperties.s3FileIoDeleteBatchSize()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/rest/RESTCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">org.apache.iceberg.rest.RESTCatalog.setConf(Configuration)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/RESTCatalog.html#setConf-java.lang.Object-"><code>RESTCatalog.setConf(Object)</code></a></span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoDeleteThreads--">org.apache.iceberg.aws.AwsProperties.s3FileIoDeleteThreads()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/transforms/Transform.html#toHumanString-T-">org.apache.iceberg.transforms.Transform.toHumanString(T)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transform.html#toHumanString-org.apache.iceberg.types.Type-T-"><code>Transform.toHumanString(Type, Object)</code></a> instead; will be removed in 2.0.0</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoMultiPartSize--">org.apache.iceberg.aws.AwsProperties.s3FileIoMultiPartSize()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#truncate-org.apache.iceberg.types.Type-int-">org.apache.iceberg.transforms.Transforms.truncate(Type, int)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#truncate-int-"><code>Transforms.truncate(int)</code></a> instead; will be removed in 2.0.0</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIOMultipartThresholdFactor--">org.apache.iceberg.aws.AwsProperties.s3FileIOMultipartThresholdFactor()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#year-org.apache.iceberg.types.Type-">org.apache.iceberg.transforms.Transforms.year(Type)</a>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#year--"><code>Transforms.year()</code></a> instead; will be removed in 2.0.0</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoMultipartUploadThreads--">org.apache.iceberg.aws.AwsProperties.s3FileIoMultipartUploadThreads()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
-</tbody>
-</table>
-</li>
-</ul>
-<a name="constructor">
-<!--   -->
-</a>
-<ul class="blockList">
-<li class="blockList">
-<table class="deprecatedSummary" border="0" cellpadding="3" cellspacing="0" summary="Deprecated Constructors table, listing deprecated constructors, and an explanation">
-<caption><span>Deprecated Constructors</span><span class="tabEnd">&nbsp;</span></caption>
-<tr>
-<th class="colOne" scope="col">Constructor and Description</th>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseKey--">org.apache.iceberg.aws.AwsProperties.s3FileIoSseKey()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseMd5--">org.apache.iceberg.aws.AwsProperties.s3FileIoSseMd5()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
 </tr>
-<tbody>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html#AuthSession-java.util.Map-java.lang.String-java.lang.String-">org.apache.iceberg.rest.auth.OAuth2Util.AuthSession(Map&lt;String, String&gt;, String, String)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html#AuthSession-java.util.Map-java.lang.String-java.lang.String-java.lang.String-java.lang.String-"><code>AuthSession(Map, String, String,
-     String, String)</code></a> instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseType--">org.apache.iceberg.aws.AwsProperties.s3FileIoSseType()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#BaseFileGroupRewriteResult-org.apache.iceberg.actions.RewriteDataFiles.FileGroupInfo-int-int-">org.apache.iceberg.actions.BaseFileGroupRewriteResult(RewriteDataFiles.FileGroupInfo, int, int)</a>
-<div class="block"><span class="deprecationComment">Will be removed in 1.3.0; use <code>BaseFileGroupRewriteResult#BaseFileGroupRewriteResult(FileGroupInfo, int, int, long)</code>
-     instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3fileIoStagingDirectory--">org.apache.iceberg.aws.AwsProperties.s3fileIoStagingDirectory()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/BaseMetadataTable.html#BaseMetadataTable-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-java.lang.String-">org.apache.iceberg.BaseMetadataTable(TableOperations, Table, String)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use BaseMetadataTable(Table, String) instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3PreloadClientEnabled--">org.apache.iceberg.aws.AwsProperties.s3PreloadClientEnabled()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><a href="org/apache/iceberg/DataTableScan.html#DataTableScan-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-">org.apache.iceberg.DataTableScan(TableOperations, Table)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use DataTableScan(Table, Schema, TableScanContext)
-     instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3WriteNamespaceTagEnabled--">org.apache.iceberg.aws.AwsProperties.s3WriteNamespaceTagEnabled()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
 </td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><a href="org/apache/iceberg/DataTableScan.html#DataTableScan-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-org.apache.iceberg.Schema-org.apache.iceberg.TableScanContext-">org.apache.iceberg.DataTableScan(TableOperations, Table, Schema, TableScanContext)</a>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use DataTableScan(Table, Schema, TableScanContext)
-     instead.</span></div>
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3WriteTableTagEnabled--">org.apache.iceberg.aws.AwsProperties.s3WriteTableTagEnabled()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#s3WriteTags--">org.apache.iceberg.aws.AwsProperties.s3WriteTags()</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3ChecksumEnabled-boolean-">org.apache.iceberg.aws.AwsProperties.setS3ChecksumEnabled(boolean)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3DeleteEnabled-boolean-">org.apache.iceberg.aws.AwsProperties.setS3DeleteEnabled(boolean)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoAcl-software.amazon.awssdk.services.s3.model.ObjectCannedACL-">org.apache.iceberg.aws.AwsProperties.setS3FileIoAcl(ObjectCannedACL)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoDeleteBatchSize-int-">org.apache.iceberg.aws.AwsProperties.setS3FileIoDeleteBatchSize(int)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoDeleteThreads-int-">org.apache.iceberg.aws.AwsProperties.setS3FileIoDeleteThreads(int)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoMultiPartSize-int-">org.apache.iceberg.aws.AwsProperties.setS3FileIoMultiPartSize(int)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoMultipartThresholdFactor-double-">org.apache.iceberg.aws.AwsProperties.setS3FileIoMultipartThresholdFactor(double)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoMultipartUploadThreads-int-">org.apache.iceberg.aws.AwsProperties.setS3FileIoMultipartUploadThreads(int)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoSseKey-java.lang.String-">org.apache.iceberg.aws.AwsProperties.setS3FileIoSseKey(String)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoSseMd5-java.lang.String-">org.apache.iceberg.aws.AwsProperties.setS3FileIoSseMd5(String)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoSseType-java.lang.String-">org.apache.iceberg.aws.AwsProperties.setS3FileIoSseType(String)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3fileIoStagingDirectory-java.lang.String-">org.apache.iceberg.aws.AwsProperties.setS3fileIoStagingDirectory(String)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3PreloadClientEnabled-boolean-">org.apache.iceberg.aws.AwsProperties.setS3PreloadClientEnabled(boolean)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3WriteNamespaceTagEnabled-boolean-">org.apache.iceberg.aws.AwsProperties.setS3WriteNamespaceTagEnabled(boolean)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3WriteTableTagEnabled-boolean-">org.apache.iceberg.aws.AwsProperties.setS3WriteTableTagEnabled(boolean)</a>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/transforms/Transform.html#toHumanString-T-">org.apache.iceberg.transforms.Transform.toHumanString(T)</a>
+<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transform.html#toHumanString-org.apache.iceberg.types.Type-T-"><code>Transform.toHumanString(Type, Object)</code></a> instead; will be removed in 2.0.0</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#truncate-org.apache.iceberg.types.Type-int-">org.apache.iceberg.transforms.Transforms.truncate(Type, int)</a>
+<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#truncate-int-"><code>Transforms.truncate(int)</code></a> instead; will be removed in 2.0.0</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/iceberg/transforms/Transforms.html#year-org.apache.iceberg.types.Type-">org.apache.iceberg.transforms.Transforms.year(Type)</a>
+<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/transforms/Transforms.html#year--"><code>Transforms.year()</code></a> instead; will be removed in 2.0.0</span></div>
 </td>
 </tr>
 </tbody>
diff --git a/javadoc/index-all.html b/javadoc/index-all.html
index a8ca4384..c002cbf8 100644
--- a/javadoc/index-all.html
+++ b/javadoc/index-all.html
@@ -72,6 +72,11 @@
 </a>
 <h2 class="title">A</h2>
 <dl>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html#abort-org.apache.iceberg.actions.RewritePositionDeletesGroup-">abort(RewritePositionDeletesGroup)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager</a></dt>
+<dd>
+<div class="block">Clean up a specified file set by removing any files created for that operation, should not
+ throw any exceptions.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BaseTaskWriter.html#abort--">abort()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BaseTaskWriter.html" title="class in org.apache.iceberg.io">BaseTaskWriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/TaskWriter.html#abort--">abort()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/TaskWriter.html" title="interface in org.apache.iceberg.io">TaskWriter</a></dt>
@@ -83,6 +88,10 @@
 <div class="block">Clean up a specified file set by removing any files created for that operation, should not
  throw any exceptions</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#abortFileGroup-org.apache.iceberg.actions.RewriteFileGroup-">abortFileGroup(RewriteFileGroup)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager.CommitService</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.CommitService.html#abortFileGroup-org.apache.iceberg.actions.RewritePositionDeletesGroup-">abortFileGroup(RewritePositionDeletesGroup)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager.CommitService</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/hive/HiveIcebergOutputCommitter.html#abortJob-org.apache.hadoop.mapred.JobContext-int-">abortJob(JobContext, int)</a></span> - Method in class org.apache.iceberg.mr.hive.<a href="org/apache/iceberg/mr/hive/HiveIcebergOutputCommitter.html" title="class in org.apache.iceberg.mr.hive">HiveIcebergOutputCommitter</a></dt>
 <dd>
 <div class="block">Removes the generated data files if there is a commit file already generated for them.</div>
@@ -101,6 +110,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/mapred/AbstractMapredIcebergRecordReader.html#AbstractMapredIcebergRecordReader-org.apache.iceberg.mr.mapreduce.IcebergInputFormat-org.apache.iceberg.mr.mapreduce.IcebergSplit-org.apache.hadoop.mapred.JobConf-org.apache.hadoop.mapred.Reporter-">AbstractMapredIcebergRecordReader(IcebergInputFormat&lt;?&gt;, IcebergSplit, JobConf, Reporter)</a></span> - Constructor for class org.apache.iceberg.mr.mapred.<a href="org/apache/ice [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCELERATION_ENABLED">ACCELERATION_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Determines if S3 client will use the Acceleration Mode, default to false.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCELERATION_ENABLED_DEFAULT">ACCELERATION_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HiddenPathFilter.html#accept-org.apache.hadoop.fs.Path-">accept(Path)</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HiddenPathFilter.html" title="class in org.apache.iceberg.hadoop">HiddenPathFilter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.AddPartitionFieldContext.html#accept-org.antlr.v4.runtime.tree.ParseTreeVisitor-">accept(ParseTreeVisitor&lt;? extends T&gt;)</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.AddPartitionFieldContext.html" title="class in org.apache.spark.sql.catalyst.parser.exte [...]
@@ -217,10 +232,20 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.WriteSpecContext.html#accept-org.antlr.v4.runtime.tree.ParseTreeVisitor-">accept(ParseTreeVisitor&lt;? extends T&gt;)</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.WriteSpecContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergS [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCESS_KEY_ID">ACCESS_KEY_ID</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure the static access key ID used to access S3FileIO.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACCESS_POINTS_PREFIX">ACCESS_POINTS_PREFIX</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Used by <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a>, prefix used for bucket access point configuration.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/auth/OAuth2Properties.html#ACCESS_TOKEN_TYPE">ACCESS_TOKEN_TYPE</a></span> - Static variable in class org.apache.iceberg.rest.auth.<a href="org/apache/iceberg/rest/auth/OAuth2Properties.html" title="class in org.apache.iceberg.rest.auth">OAuth2Properties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/AliyunProperties.html#accessKeyId--">accessKeyId()</a></span> - Method in class org.apache.iceberg.aliyun.<a href="org/apache/iceberg/aliyun/AliyunProperties.html" title="class in org.apache.iceberg.aliyun">AliyunProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#accessKeyId--">accessKeyId()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/AliyunProperties.html#accessKeySecret--">accessKeySecret()</a></span> - Method in class org.apache.iceberg.aliyun.<a href="org/apache/iceberg/aliyun/AliyunProperties.html" title="class in org.apache.iceberg.aliyun">AliyunProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/Accessor.html" title="interface in org.apache.iceberg"><span class="typeNameLink">Accessor</span></a>&lt;<a href="org/apache/iceberg/Accessor.html" title="type parameter in Accessor">T</a>&gt; - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -237,6 +262,12 @@
 <dd>
 <div class="block">Position2Accessor and Position3Accessor here is an optimization.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ACL">ACL</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Used to configure canned access control list (ACL) for S3 client to use during write.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#acl--">acl()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/dynamodb/DynamoDbLockManager.html#acquire-java.lang.String-java.lang.String-">acquire(String, String)</a></span> - Method in class org.apache.iceberg.aws.dynamodb.<a href="org/apache/iceberg/aws/dynamodb/DynamoDbLockManager.html" title="class in org.apache.iceberg.aws.dynamodb">DynamoDbLockManager</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/LockManager.html#acquire-java.lang.String-java.lang.String-">acquire(String, String)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/LockManager.html" title="interface in org.apache.iceberg">LockManager</a></dt>
@@ -395,6 +426,16 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManifestFile.html#ADDED_ROWS_COUNT">ADDED_ROWS_COUNT</a></span> - Static variable in interface org.apache.iceberg.<a href="org/apache/iceberg/ManifestFile.html" title="interface in org.apache.iceberg">ManifestFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#addedBytes--">addedBytes()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html#addedBytesCount--">addedBytesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupRewriteResult</a></dt>
+<dd>
+<div class="block">Returns the number of bytes of newly added position delete files in this group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html#addedBytesCount--">addedBytesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.Result</a></dt>
+<dd>
+<div class="block">Returns the number of bytes of newly added position delete files</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesActionResult.html#addedDataFiles--">addedDataFiles()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesActionResult.html" title="class in org.apache.iceberg.actions">RewriteDataFilesActionResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/metrics/CommitMetricsResult.html#addedDataFiles--">addedDataFiles()</a></span> - Method in interface org.apache.iceberg.metrics.<a href="org/apache/iceberg/metrics/CommitMetricsResult.html" title="interface in org.apache.iceberg.metrics">CommitMetricsResult</a></dt>
@@ -404,20 +445,28 @@
 <div class="block">Return all data files added to the table in this snapshot.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#addedDataFilesCount--">addedDataFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html#addedDataFilesCount--">addedDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupRewriteResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html#addedDataFilesCount--">addedDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.Result</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#addedDeleteFiles--">addedDeleteFiles()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/metrics/CommitMetricsResult.html#addedDeleteFiles--">addedDeleteFiles()</a></span> - Method in interface org.apache.iceberg.metrics.<a href="org/apache/iceberg/metrics/CommitMetricsResult.html" title="interface in org.apache.iceberg.metrics">CommitMetricsResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Snapshot.html#addedDeleteFiles-org.apache.iceberg.io.FileIO-">addedDeleteFiles(FileIO)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Snapshot.html" title="interface in org.apache.iceberg">Snapshot</a></dt>
 <dd>
 <div class="block">Return all delete files added to the table in this snapshot.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html#addedDeleteFilesCount--">addedDeleteFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupRewriteResult</a></dt>
+<dd>
+<div class="block">Returns the count of the added position delete files in this group.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html#addedDeleteFilesCount--">addedDeleteFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.Result</a></dt>
 <dd>
-<div class="block">Returns the count of the added delete files.</div>
+<div class="block">Returns the count of the added position delete files.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DeletedRowsScanTask.html#addedDeletes--">addedDeletes()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/DeletedRowsScanTask.html" title="interface in org.apache.iceberg">DeletedRowsScanTask</a></dt>
 <dd>
@@ -446,7 +495,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotSummary.Builder.html#addedManifest-org.apache.iceberg.ManifestFile-">addedManifest(ManifestFile)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotSummary.Builder.html" title="class in org.apache.iceberg">SnapshotSummary.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html#addedManifests--">addedManifests()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html" title="class in org.apache.iceberg.actions">BaseRewriteManifestsActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteManifests.Result.html#addedManifests--">addedManifests()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteManifests.Result.html" title="interface in org.apache.iceberg.actions">RewriteManifests.Result</a></dt>
 <dd>
 <div class="block">Returns added manifests.</div>
@@ -500,6 +551,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseReplacePartitions.html#addFile-org.apache.iceberg.DataFile-">addFile(DataFile)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseReplacePartitions.html" title="class in org.apache.iceberg">BaseReplacePartitions</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#addFile-java.lang.String-byte:A-">addFile(String, byte[])</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/OverwriteFiles.html#addFile-org.apache.iceberg.DataFile-">addFile(DataFile)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/OverwriteFiles.html" title="interface in org.apache.iceberg">OverwriteFiles</a></dt>
 <dd>
 <div class="block">Add a <a href="org/apache/iceberg/DataFile.html" title="interface in org.apache.iceberg"><code>DataFile</code></a> to the table.</div>
@@ -508,6 +561,18 @@
 <dd>
 <div class="block">Add a <a href="org/apache/iceberg/DataFile.html" title="interface in org.apache.iceberg"><code>DataFile</code></a> to the table.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#addFile-org.apache.iceberg.DataFile-">addFile(DataFile)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
+<dd>
+<div class="block">Add a new data file.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#addFile-org.apache.iceberg.DeleteFile-">addFile(DeleteFile)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
+<dd>
+<div class="block">Add a new delete file.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#addFile-org.apache.iceberg.DeleteFile-long-">addFile(DeleteFile, long)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
+<dd>
+<div class="block">Add a new delete file with the given data sequence number.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseRewriteManifests.html#addManifest-org.apache.iceberg.ManifestFile-">addManifest(ManifestFile)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseRewriteManifests.html" title="class in org.apache.iceberg">BaseRewriteManifests</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteManifests.html#addManifest-org.apache.iceberg.ManifestFile-">addManifest(ManifestFile)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteManifests.html" title="interface in org.apache.iceberg">RewriteManifests</a></dt>
@@ -817,6 +882,10 @@
 <dd>
 <div class="block">Calls alter_table method using the metastore client.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/MetastoreUtil.html#alterTable-org.apache.hadoop.hive.metastore.IMetaStoreClient-java.lang.String-java.lang.String-org.apache.hadoop.hive.metastore.api.Table-java.util.Map-">alterTable(IMetaStoreClient, String, String, Table, Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/MetastoreUtil.html" title="class in org.apache.iceberg.hive">MetastoreUtil</a></dt>
+<dd>
+<div class="block">Calls alter_table method using the metastore client.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkCachedTableCatalog.html#alterTable-org.apache.spark.sql.connector.catalog.Identifier-org.apache.spark.sql.connector.catalog.TableChange...-">alterTable(Identifier, TableChange...)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkCachedTableCatalog.html" title="class in org.apache.iceberg.spark">SparkCachedTableCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkCatalog.html#alterTable-org.apache.spark.sql.connector.catalog.Identifier-org.apache.spark.sql.connector.catalog.TableChange...-">alterTable(Identifier, TableChange...)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkCatalog.html" title="class in org.apache.iceberg.spark">SparkCatalog</a></dt>
@@ -871,11 +940,47 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/ExpressionVisitors.ExpressionVisitor.html#and-R-R-">and(R, R)</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/ExpressionVisitors.ExpressionVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.ExpressionVisitor</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS">APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the connection acquisition timeout in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_MAX_IDLE_TIME_MS">APACHE_CONNECTION_MAX_IDLE_TIME_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the connection max idle time in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_TIME_TO_LIVE_MS">APACHE_CONNECTION_TIME_TO_LIVE_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the connection time to live in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_CONNECTION_TIMEOUT_MS">APACHE_CONNECTION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the connection timeout in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/StandardBlobTypes.html#APACHE_DATASKETCHES_THETA_V1">APACHE_DATASKETCHES_THETA_V1</a></span> - Static variable in class org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/StandardBlobTypes.html" title="class in org.apache.iceberg.puffin">StandardBlobTypes</a></dt>
 <dd>
 <div class="block">A serialized form of a "compact" Theta sketch produced by the <a
  href="https://datasketches.apache.org/">Apache DataSketches</a> library</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_EXPECT_CONTINUE_ENABLED">APACHE_EXPECT_CONTINUE_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure whether to enable the expect continue setting for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_MAX_CONNECTIONS">APACHE_MAX_CONNECTIONS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the max connections number for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_SOCKET_TIMEOUT_MS">APACHE_SOCKET_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the socket timeout in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_TCP_KEEP_ALIVE_ENABLED">APACHE_TCP_KEEP_ALIVE_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure whether to enable the tcp keep alive setting for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED">APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure whether to use idle connection reaper for <code>ApacheHttpClient.Builder</code>.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#APP_ID">APP_ID</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DataOperations.html#APPEND">APPEND</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/DataOperations.html" title="class in org.apache.iceberg">DataOperations</a></dt>
@@ -956,14 +1061,27 @@
 <dd>
 <div class="block">Configure the credential provider for AWS clients.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyClientRegionConfiguration-T-">applyClientRegionConfiguration(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#applyClientRegionConfiguration-T-">applyClientRegionConfiguration(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
 <dd>
 <div class="block">Configure a client AWS region.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyClientRegionConfiguration-T-">applyClientRegionConfiguration(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><code>AwsClientProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#applyCredentialConfigurations-org.apache.iceberg.aws.AwsClientProperties-T-">applyCredentialConfigurations(AwsClientProperties, T)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyDynamoDbEndpointConfigurations-T-">applyDynamoDbEndpointConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
 <div class="block">Override the endpoint for a dynamoDb client.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#applyEndpointConfigurations-T-">applyEndpointConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Override the endpoint for an S3 client.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/IcebergTableSource.html#applyFilters-java.util.List-">applyFilters(List&lt;ResolvedExpression&gt;)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/IcebergTableSource.html" title="class in org.apache.iceberg.flink.source">IcebergTableSource</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyGlueEndpointConfigurations-T-">applyGlueEndpointConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
@@ -972,6 +1090,13 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyHttpClientConfigurations-T-">applyHttpClientConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#applyHttpClientConfigurations-T-">applyHttpClientConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
 <div class="block">Configure the httpClient for a client according to the HttpClientType.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/IcebergTableSource.html#applyLimit-long-">applyLimit(long)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/IcebergTableSource.html" title="class in org.apache.iceberg.flink.source">IcebergTableSource</a></dt>
@@ -988,19 +1113,31 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3CredentialConfigurations-T-">applyS3CredentialConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure the credentials for an S3 client.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3EndpointConfigurations-T-">applyS3EndpointConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Override the endpoint for an S3 client.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3ServiceConfigurations-T-">applyS3ServiceConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure services settings for an S3 client.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#applyS3SignerConfiguration-T-">applyS3SignerConfiguration(T)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure a signer for an S3 client.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#applySchemaChanges-org.apache.iceberg.UpdateSchema-java.util.List-">applySchemaChanges(UpdateSchema, List&lt;TableChange&gt;)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
 <dd>
@@ -1008,6 +1145,14 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/PropertyUtil.html#applySchemaChanges-java.util.Map-java.util.List-java.util.Map-java.util.Set-">applySchemaChanges(Map&lt;String, String&gt;, List&lt;String&gt;, Map&lt;String, String&gt;, Set&lt;String&gt;)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/PropertyUtil.html" title="class in org.apache.iceberg.util">PropertyUtil</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#applyServiceConfigurations-T-">applyServiceConfigurations(T)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure services settings for an S3 client.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#applySignerConfiguration-T-">applySignerConfiguration(T)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure a signer for an S3 client.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/IcebergTableSink.html#applyStaticPartition-java.util.Map-">applyStaticPartition(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/IcebergTableSink.html" title="class in org.apache.iceberg.flink">IcebergTableSink</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.AddPartitionSpec.html#applyTo-org.apache.iceberg.TableMetadata.Builder-">applyTo(TableMetadata.Builder)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.AddPartitionSpec.html" title="class in org.apache.iceberg">MetadataUpdate.AddPartitionSpec</a></dt>
@@ -1244,6 +1389,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#asResult--">asResult()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#asResult--">asResult()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/UpdateTableRequest.UpdateRequirement.AssertLastAssignedFieldId.html#AssertLastAssignedFieldId-int-">AssertLastAssignedFieldId(int)</a></span> - Constructor for class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/UpdateTableRequest.UpdateRequirement.AssertLastAssignedFieldId.html" title="class in org.apache.iceberg.rest.requests">UpdateTableRequest.UpdateRequirement.AssertLastAssignedFi [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/UpdateTableRequest.UpdateRequirement.AssertLastAssignedPartitionId.html#AssertLastAssignedPartitionId-int-">AssertLastAssignedPartitionId(int)</a></span> - Constructor for class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/UpdateTableRequest.UpdateRequirement.AssertLastAssignedPartitionId.html" title="class in org.apache.iceberg.rest.requests">UpdateTableRequest.UpdateRequirement.Asse [...]
@@ -1327,33 +1474,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/metrics/CommitMetricsResult.html#attempts--">attempts()</a></span> - Method in interface org.apache.iceberg.metrics.<a href="org/apache/iceberg/metrics/CommitMetricsResult.html" title="interface in org.apache.iceberg.metrics">CommitMetricsResult</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#AUTH_DEFAULT_REFRESH_ENABLED">AUTH_DEFAULT_REFRESH_ENABLED</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">Will be removed in 1.3.0; Use <a href="org/apache/iceberg/rest/auth/OAuth2Properties.html#TOKEN_REFRESH_ENABLED"><code>OAuth2Properties.TOKEN_REFRESH_ENABLED</code></a> to control token
-     refresh behavior.</span></div>
-</div>
-</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT">AUTH_DEFAULT_REFRESH_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">Will be removed in 1.3.0; Use <a href="org/apache/iceberg/rest/auth/OAuth2Properties.html#TOKEN_REFRESH_ENABLED_DEFAULT"><code>OAuth2Properties.TOKEN_REFRESH_ENABLED_DEFAULT</code></a> to control
-     default token refresh behavior.</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#AUTH_SESSION_TIMEOUT_MS">AUTH_SESSION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#AUTH_SESSION_TIMEOUT_MS_DEFAULT">AUTH_SESSION_TIMEOUT_MS_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/auth/OAuth2Util.html#authHeaders-java.lang.String-">authHeaders(String)</a></span> - Static method in class org.apache.iceberg.rest.auth.<a href="org/apache/iceberg/rest/auth/OAuth2Util.html" title="class in org.apache.iceberg.rest.auth">OAuth2Util</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html#AuthSession-java.util.Map-java.lang.String-java.lang.String-">AuthSession(Map&lt;String, String&gt;, String, String)</a></span> - Constructor for class org.apache.iceberg.rest.auth.<a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html" title="class in org.apache.iceberg.rest.auth">OAuth2Util.AuthSession</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html#AuthSession-java.util.Map-java.lang.String-java.lang.String-java.lang.String-java.lang.String-"><code>AuthSession(Map, String, String,
-     String, String)</code></a> instead.</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html#AuthSession-java.util.Map-java.lang.String-java.lang.String-java.lang.String-java.lang.String-">AuthSession(Map&lt;String, String&gt;, String, String, String, String)</a></span> - Constructor for class org.apache.iceberg.rest.auth.<a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html" title="class in org.apache.iceberg.rest.auth">OAuth2Util.AuthSession</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/avro/Avro.html" title="class in org.apache.iceberg.avro"><span class="typeNameLink">Avro</span></a> - Class in <a href="org/apache/iceberg/avro/package-summary.html">org.apache.iceberg.avro</a></dt>
@@ -1388,7 +1514,7 @@
 <dd>
 <div class="block">Read Iceberg rows as <code>GenericRecord</code>.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/AvroGenericRecordReaderFunction.html#AvroGenericRecordReaderFunction-java.lang.String-org.apache.flink.configuration.ReadableConfig-org.apache.iceberg.Schema-org.apache.iceberg.Schema-java.lang.String-boolean-org.apache.iceberg.io.FileIO-org.apache.iceberg.encryption.EncryptionManager-">AvroGenericRecordReaderFunction(String, ReadableConfig, Schema, Schema, String, boolean, FileIO, EncryptionManager)</a></sp [...]
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/AvroGenericRecordReaderFunction.html#AvroGenericRecordReaderFunction-java.lang.String-org.apache.flink.configuration.ReadableConfig-org.apache.iceberg.Schema-org.apache.iceberg.Schema-java.lang.String-boolean-org.apache.iceberg.io.FileIO-org.apache.iceberg.encryption.EncryptionManager-java.util.List-">AvroGenericRecordReaderFunction(String, ReadableConfig, Schema, Schema, String, boolean, FileIO, EncryptionM [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/flink/sink/AvroGenericRecordToRowDataMapper.html" title="class in org.apache.iceberg.flink.sink"><span class="typeNameLink">AvroGenericRecordToRowDataMapper</span></a> - Class in <a href="org/apache/iceberg/flink/sink/package-summary.html">org.apache.iceberg.flink.sink</a></dt>
 <dd>
@@ -1428,6 +1554,12 @@
 <dd>
 <div class="block">Interface to customize AWS clients used by Iceberg.</div>
 </dd>
+<dt><a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><span class="typeNameLink">AwsClientProperties</span></a> - Class in <a href="org/apache/iceberg/aws/package-summary.html">org.apache.iceberg.aws</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#AwsClientProperties--">AwsClientProperties()</a></span> - Constructor for class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#AwsClientProperties-java.util.Map-">AwsClientProperties(Map&lt;String, String&gt;)</a></span> - Constructor for class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AssumeRoleAwsClientFactory.html#awsProperties--">awsProperties()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AssumeRoleAwsClientFactory.html" title="class in org.apache.iceberg.aws">AssumeRoleAwsClientFactory</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws"><span class="typeNameLink">AwsProperties</span></a> - Class in <a href="org/apache/iceberg/aws/package-summary.html">org.apache.iceberg.aws</a></dt>
@@ -1475,42 +1607,47 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseCombinedScanTask.html#BaseCombinedScanTask-java.util.List-">BaseCombinedScanTask(List&lt;FileScanTask&gt;)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/BaseCombinedScanTask.html" title="class in org.apache.iceberg">BaseCombinedScanTask</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseDeleteOrphanFilesActionResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableDeleteOrphanFiles.Result.builder()</code>
+     instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html#BaseDeleteOrphanFilesActionResult-java.lang.Iterable-">BaseDeleteOrphanFilesActionResult(Iterable&lt;String&gt;)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteOrphanFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseDeleteReachableFilesActionResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#BaseDeleteReachableFilesActionResult-long-long-long-long-">BaseDeleteReachableFilesActionResult(long, long, long, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#BaseDeleteReachableFilesActionResult-long-long-long-long-long-long-">BaseDeleteReachableFilesActionResult(long, long, long, long, long, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BaseTaskWriter.BaseEqualityDeltaWriter.html#BaseEqualityDeltaWriter-org.apache.iceberg.StructLike-org.apache.iceberg.Schema-org.apache.iceberg.Schema-">BaseEqualityDeltaWriter(StructLike, Schema, Schema)</a></span> - Constructor for class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BaseTaskWriter.BaseEqualityDeltaWriter.html" title="class in org.apache.iceberg.io">BaseTaskWriter.BaseEqualityDeltaWriter</a></dt>
-<dd>&nbsp;</dd>
-<dt><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseExpireSnapshotsActionResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0.</span></div>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableDeleteReachableFiles.Result.builder()</code>
+     instead.</span></div>
 </div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#BaseExpireSnapshotsActionResult-long-long-long-">BaseExpireSnapshotsActionResult(long, long, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#BaseDeleteReachableFilesActionResult-long-long-long-long-">BaseDeleteReachableFilesActionResult(long, long, long, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#BaseExpireSnapshotsActionResult-long-long-long-long-long-">BaseExpireSnapshotsActionResult(long, long, long, long, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#BaseDeleteReachableFilesActionResult-long-long-long-long-long-long-">BaseDeleteReachableFilesActionResult(long, long, long, long, long, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
-<dt><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseFileGroupRewriteResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BaseTaskWriter.BaseEqualityDeltaWriter.html#BaseEqualityDeltaWriter-org.apache.iceberg.StructLike-org.apache.iceberg.Schema-org.apache.iceberg.Schema-">BaseEqualityDeltaWriter(StructLike, Schema, Schema)</a></span> - Constructor for class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BaseTaskWriter.BaseEqualityDeltaWriter.html" title="class in org.apache.iceberg.io">BaseTaskWriter.BaseEqualityDeltaWriter</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#BaseFileGroupRewriteResult-org.apache.iceberg.actions.RewriteDataFiles.FileGroupInfo-int-int-">BaseFileGroupRewriteResult(RewriteDataFiles.FileGroupInfo, int, int)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
+<dt><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseFileGroupRewriteResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">Will be removed in 1.3.0; use <code>BaseFileGroupRewriteResult#BaseFileGroupRewriteResult(FileGroupInfo, int, int, long)</code>
-     instead.</span></div>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteDataFiles.FileGroupRewriteResult.builder()</code> instead.</span></div>
 </div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#BaseFileGroupRewriteResult-org.apache.iceberg.actions.RewriteDataFiles.FileGroupInfo-int-int-">BaseFileGroupRewriteResult(RewriteDataFiles.FileGroupInfo, int, int)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#BaseFileGroupRewriteResult-org.apache.iceberg.actions.RewriteDataFiles.FileGroupInfo-int-int-long-">BaseFileGroupRewriteResult(RewriteDataFiles.FileGroupInfo, int, int, long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseFileScanTask.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseFileScanTask</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseFileScanTask.html#BaseFileScanTask-org.apache.iceberg.DataFile-org.apache.iceberg.DeleteFile:A-java.lang.String-java.lang.String-org.apache.iceberg.expressions.ResidualEvaluator-">BaseFileScanTask(DataFile, DeleteFile[], String, String, ResidualEvaluator)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/BaseFileScanTask.html" title="class in org.apache.iceberg">BaseFileScanTask</a></dt>
@@ -1527,12 +1664,6 @@
 <dd>
 <div class="block">Base class for metadata tables.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetadataTable.html#BaseMetadataTable-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-java.lang.String-">BaseMetadataTable(TableOperations, Table, String)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetadataTable.html" title="class in org.apache.iceberg">BaseMetadataTable</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use BaseMetadataTable(Table, String) instead.</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetadataTable.html#BaseMetadataTable-org.apache.iceberg.Table-java.lang.String-">BaseMetadataTable(Table, String)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetadataTable.html" title="class in org.apache.iceberg">BaseMetadataTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseMetastoreCatalog.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseMetastoreCatalog</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -1550,9 +1681,15 @@
 <dt><a href="org/apache/iceberg/BaseMetastoreTableOperations.CommitStatus.html" title="enum in org.apache.iceberg"><span class="typeNameLink">BaseMetastoreTableOperations.CommitStatus</span></a> - Enum in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseMigrateTableActionResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseMigrateTableActionResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableMigrateTable.Result.builder()</code> instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseMigrateTableActionResult.html#BaseMigrateTableActionResult-long-">BaseMigrateTableActionResult(long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseMigrateTableActionResult.html" title="class in org.apache.iceberg.actions">BaseMigrateTableActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseOverwriteFiles.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseOverwriteFiles</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseOverwriteFiles.html#BaseOverwriteFiles-java.lang.String-org.apache.iceberg.TableOperations-">BaseOverwriteFiles(String, TableOperations)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/BaseOverwriteFiles.html" title="class in org.apache.iceberg">BaseOverwriteFiles</a></dt>
@@ -1573,6 +1710,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/BasePositionDeltaWriter.html" title="class in org.apache.iceberg.io"><span class="typeNameLink">BasePositionDeltaWriter</span></a>&lt;<a href="org/apache/iceberg/io/BasePositionDeltaWriter.html" title="type parameter in BasePositionDeltaWriter">T</a>&gt; - Class in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BasePositionDeltaWriter.html#BasePositionDeltaWriter-org.apache.iceberg.io.PartitioningWriter-org.apache.iceberg.io.PartitioningWriter-">BasePositionDeltaWriter(PartitioningWriter&lt;T, DataWriteResult&gt;, PartitioningWriter&lt;PositionDelete&lt;T&gt;, DeleteWriteResult&gt;)</a></span> - Constructor for class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BasePositionDeltaWriter.html" title="class in org.apache.iceber [...]
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BasePositionDeltaWriter.html#BasePositionDeltaWriter-org.apache.iceberg.io.PartitioningWriter-org.apache.iceberg.io.PartitioningWriter-org.apache.iceberg.io.PartitioningWriter-">BasePositionDeltaWriter(PartitioningWriter&lt;T, DataWriteResult&gt;, PartitioningWriter&lt;T, DataWriteResult&gt;, PartitioningWriter&lt;PositionDelete&lt;T&gt;, DeleteWriteResult&gt;)</a></span> - Constructor for class org.apache.iceberg.io.<a href [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseReplacePartitions.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseReplacePartitions</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -1584,19 +1723,39 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html#BaseRewriteDataFilesAction-org.apache.iceberg.Table-">BaseRewriteDataFilesAction(Table)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseRewriteDataFilesFileGroupInfo</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteDataFiles.FileGroupInfo.builder()</code> instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html#BaseRewriteDataFilesFileGroupInfo-int-int-org.apache.iceberg.StructLike-">BaseRewriteDataFilesFileGroupInfo(int, int, StructLike)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesFileGroupInfo</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseRewriteDataFilesResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseRewriteDataFilesResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteDataFiles.Result.builder()</code>
+     instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesResult.html#BaseRewriteDataFilesResult-java.util.List-">BaseRewriteDataFilesResult(List&lt;RewriteDataFiles.FileGroupRewriteResult&gt;)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesResult.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseRewriteManifests.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseRewriteManifests</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseRewriteManifestsActionResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableRewriteManifests.Result.builder()</code>
+     instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html#BaseRewriteManifestsActionResult-java.lang.Iterable-java.lang.Iterable-">BaseRewriteManifestsActionResult(Iterable&lt;ManifestFile&gt;, Iterable&lt;ManifestFile&gt;)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html" title="class in org.apache.iceberg.actions">BaseRewriteManifestsActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseScanTaskGroup.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseScanTaskGroup</span></a>&lt;<a href="org/apache/iceberg/BaseScanTaskGroup.html" title="type parameter in BaseScanTaskGroup">T</a> extends <a href="org/apache/iceberg/ScanTask.html" title="interface in org.apache.iceberg">ScanTask</a>&gt; - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseScanTaskGroup.html#BaseScanTaskGroup-org.apache.iceberg.StructLike-java.util.Collection-">BaseScanTaskGroup(StructLike, Collection&lt;T&gt;)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/BaseScanTaskGroup.html" title="class in org.apache.iceberg">BaseScanTaskGroup</a></dt>
@@ -1612,9 +1771,16 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html#baseSignerUri--">baseSignerUri()</a></span> - Method in class org.apache.iceberg.aws.s3.signer.<a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html" title="class in org.apache.iceberg.aws.s3.signer">S3V4RestSignerClient</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BaseSnapshotTableActionResult.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BaseSnapshotTableActionResult</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; use <code>ImmutableSnapshotTable.Result.builder()</code>
+     instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseSnapshotTableActionResult.html#BaseSnapshotTableActionResult-long-">BaseSnapshotTableActionResult(long)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseSnapshotTableActionResult.html" title="class in org.apache.iceberg.actions">BaseSnapshotTableActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/BaseTable.html" title="class in org.apache.iceberg"><span class="typeNameLink">BaseTable</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">Base <a href="org/apache/iceberg/Table.html" title="interface in org.apache.iceberg"><code>Table</code></a> implementation.</div>
@@ -1801,10 +1967,14 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">BinPackStrategy</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
-<div class="block">A rewrite strategy for data files which determines which files to rewrite based on their size.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; use <a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><code>SizeBasedFileRewriter</code></a> instead.</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#BinPackStrategy--">BinPackStrategy()</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/puffin/Blob.html" title="class in org.apache.iceberg.puffin"><span class="typeNameLink">Blob</span></a> - Class in <a href="org/apache/iceberg/puffin/package-summary.html">org.apache.iceberg.puffin</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/Blob.html#Blob-java.lang.String-java.util.List-long-long-java.nio.ByteBuffer-">Blob(String, List&lt;Integer&gt;, long, long, ByteBuffer)</a></span> - Constructor for class org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/Blob.html" title="class in org.apache.iceberg.puffin">Blob</a></dt>
@@ -1989,6 +2159,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.BucketString.html#BucketString--">BucketString()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.BucketString.html" title="class in org.apache.iceberg.spark.functions">BucketFunction.BucketString</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#bucketToAccessPointMapping--">bucketToAccessPointMapping()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/util/BucketUtil.html" title="class in org.apache.iceberg.util"><span class="typeNameLink">BucketUtil</span></a> - Class in <a href="org/apache/iceberg/util/package-summary.html">org.apache.iceberg.util</a></dt>
 <dd>
 <div class="block">Contains the logic for hashing various types for use with the <code>bucket</code> partition
@@ -2114,14 +2286,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/SparkProcedures.ProcedureBuilder.html#build--">build()</a></span> - Method in interface org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/SparkProcedures.ProcedureBuilder.html" title="interface in org.apache.iceberg.spark.procedures">SparkProcedures.ProcedureBuilder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewriteBuilder.html#build--">build()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewriteBuilder.html" title="class in org.apache.iceberg.spark.source">SparkPositionDeletesRewriteBuilder</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkScanBuilder.html#build--">build()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkScanBuilder.html" title="class in org.apache.iceberg.spark.source">SparkScanBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.Builder.html#build--">build()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.Builder.html" title="class in org.apache.iceberg">TableMetadata.Builder</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriteBuilder.html#build--">build()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriteBuilder.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWriteBuilder</a></dt>
-<dd>
-<div class="block">Returns a logical delta write.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/AvroSchemaUtil.html#buildAvroProjection-org.apache.avro.Schema-org.apache.iceberg.Schema-java.util.Map-">buildAvroProjection(Schema, Schema, Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/AvroSchemaUtil.html" title="class in org.apache.iceberg.avro">AvroSchemaUtil</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkScanBuilder.html#buildChangelogScan--">buildChangelogScan()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkScanBuilder.html" title="class in org.apache.iceberg.spark.source">SparkScanBuilder</a></dt>
@@ -2152,10 +2322,6 @@
 <div class="block">Returns the first valid implementation as a BoundMethod or throws a NoSuchMethodException if
  there is none.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#buildCopyOnWriteDistribution-org.apache.iceberg.Table-org.apache.spark.sql.connector.write.RowLevelOperation.Command-org.apache.iceberg.DistributionMode-">buildCopyOnWriteDistribution(Table, RowLevelOperation.Command, DistributionMode)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in o [...]
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#buildCopyOnWriteOrdering-org.apache.iceberg.Table-org.apache.spark.sql.connector.write.RowLevelOperation.Command-org.apache.spark.sql.connector.distributions.Distribution-">buildCopyOnWriteOrdering(Table, RowLevelOperation.Command, Distribution)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title=" [...]
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkScanBuilder.html#buildCopyOnWriteScan--">buildCopyOnWriteScan()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkScanBuilder.html" title="class in org.apache.iceberg.spark.source">SparkScanBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.DeleteWriteBuilder.html#buildEqualityWriter--">buildEqualityWriter()</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.DeleteWriteBuilder.html" title="class in org.apache.iceberg.avro">Avro.DeleteWriteBuilder</a></dt>
@@ -2200,12 +2366,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/WriteResult.html#builder--">builder()</a></span> - Static method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/WriteResult.html" title="class in org.apache.iceberg.io">WriteResult</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/HTTPClient.html#builder--">builder()</a></span> - Static method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/HTTPClient.html" title="class in org.apache.iceberg.rest">HTTPClient</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/HTTPClient.html#builder-java.util.Map-"><code>HTTPClient.builder(Map)</code></a></span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/HTTPClient.html#builder-java.util.Map-">builder(Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/HTTPClient.html" title="class in org.apache.iceberg.rest">HTTPClient</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/CreateNamespaceRequest.html#builder--">builder()</a></span> - Static method in class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/CreateNamespaceRequest.html" title="class in org.apache.iceberg.rest.requests">CreateNamespaceRequest</a></dt>
@@ -2248,6 +2408,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html#builder--">builder()</a></span> - Static method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RemoveOrphanFilesProcedure</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html#builder--">builder()</a></span> - Static method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RewritePositionDeleteFilesProcedure</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/Tasks.Builder.html#Builder-java.lang.Iterable-">Builder(Iterable&lt;I&gt;)</a></span> - Constructor for class org.apache.iceberg.util.<a href="org/apache/iceberg/util/Tasks.Builder.html" title="class in org.apache.iceberg.util">Tasks.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/sink/FlinkSink.html#builderFor-org.apache.flink.streaming.api.datastream.DataStream-org.apache.flink.api.common.functions.MapFunction-org.apache.flink.api.common.typeinfo.TypeInformation-">builderFor(DataStream&lt;T&gt;, MapFunction&lt;T, RowData&gt;, TypeInformation&lt;RowData&gt;)</a></span> - Static method in class org.apache.iceberg.flink.sink.<a href="org/apache/iceberg/flink/sink/FlinkSink.html" title="class in org. [...]
@@ -2316,10 +2478,6 @@
 <div class="block">Converts an Iceberg schema to a corresponding ORC schema within the context of an existing ORC
  file schema.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#buildPositionDeltaDistribution-org.apache.iceberg.Table-org.apache.spark.sql.connector.write.RowLevelOperation.Command-org.apache.iceberg.DistributionMode-">buildPositionDeltaDistribution(Table, RowLevelOperation.Command, DistributionMode)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class  [...]
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#buildPositionDeltaOrdering-org.apache.iceberg.Table-org.apache.spark.sql.connector.write.RowLevelOperation.Command-">buildPositionDeltaOrdering(Table, RowLevelOperation.Command)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark">SparkDistributionAndOrderingUtil< [...]
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.DeleteWriteBuilder.html#buildPositionWriter--">buildPositionWriter()</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.DeleteWriteBuilder.html" title="class in org.apache.iceberg.avro">Avro.DeleteWriteBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/orc/ORC.DeleteWriteBuilder.html#buildPositionWriter--">buildPositionWriter()</a></span> - Method in class org.apache.iceberg.orc.<a href="org/apache/iceberg/orc/ORC.DeleteWriteBuilder.html" title="class in org.apache.iceberg.orc">ORC.DeleteWriteBuilder</a></dt>
@@ -2348,35 +2506,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkOrcReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.orc.TypeDescription-java.util.Map-">buildReader(Schema, TypeDescription, Map&lt;Integer, ?&gt;)</a></span> - Static method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkOrcReaders.html" title="class in org.apache.iceberg.spark.data.vectorized">VectorizedSparkO [...]
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-boolean-">buildReader(Schema, MessageType, boolean)</a></span> - Static method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html" title="class in org.apache.iceberg.spark.data.vectorized">VectorizedSparkParquetRea [...]
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-"><code>VectorizedSparkParquetReaders.buildReader(Schema, MessageType, Map,
-     DeleteFilter)</code></a> instead.</span></div>
-</div>
-</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-boolean-java.util.Map-">buildReader(Schema, MessageType, boolean, Map&lt;Integer, ?&gt;)</a></span> - Static method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html" title="class in org.apache.iceberg.spark.data. [...]
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-"><code>VectorizedSparkParquetReaders.buildReader(Schema, MessageType, Map,
-     DeleteFilter)</code></a> instead.</span></div>
-</div>
-</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-boolean-java.util.Map-org.apache.iceberg.data.DeleteFilter-">buildReader(Schema, MessageType, boolean, Map&lt;Integer, ?&gt;, DeleteFilter&lt;InternalRow&gt;)</a></span> - Static method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/VectorizedSp [...]
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-"><code>VectorizedSparkParquetReaders.buildReader(Schema, MessageType, Map,
-     DeleteFilter)</code></a> instead.</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders.html#buildReader-org.apache.iceberg.Schema-org.apache.parquet.schema.MessageType-java.util.Map-org.apache.iceberg.data.DeleteFilter-">buildReader(Schema, MessageType, Map&lt;Integer, ?&gt;, DeleteFilter&lt;InternalRow&gt;)</a></span> - Static method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/VectorizedSparkParquetReaders [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.html#buildReplacement-org.apache.iceberg.Schema-org.apache.iceberg.PartitionSpec-org.apache.iceberg.SortOrder-java.lang.String-java.util.Map-">buildReplacement(Schema, PartitionSpec, SortOrder, String, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.html" title="class in org.apache.iceberg">TableMetadata</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#buildRequiredDistribution-org.apache.iceberg.Table-org.apache.iceberg.DistributionMode-">buildRequiredDistribution(Table, DistributionMode)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark">SparkDistributionAndOrderingUtil</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#buildRequiredOrdering-org.apache.iceberg.Table-org.apache.spark.sql.connector.distributions.Distribution-">buildRequiredOrdering(Table, Distribution)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark">SparkDistributionAndOrderingUtil</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/SortOrderUtil.html#buildSortOrder-org.apache.iceberg.Table-">buildSortOrder(Table)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/SortOrderUtil.html" title="class in org.apache.iceberg.util">SortOrderUtil</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/SortOrderUtil.html#buildSortOrder-org.apache.iceberg.Table-org.apache.iceberg.SortOrder-">buildSortOrder(Table, SortOrder)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/SortOrderUtil.html" title="class in org.apache.iceberg.util">SortOrderUtil</a></dt>
@@ -2512,6 +2645,12 @@
 </a>
 <h2 class="title">C</h2>
 <dl>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CACHE_CASE_SENSITIVE">CACHE_CASE_SENSITIVE</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
+<dd>
+<div class="block">Controls whether the caching catalog will cache table entries using case sensitive keys.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CACHE_CASE_SENSITIVE_DEFAULT">CACHE_CASE_SENSITIVE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CACHE_ENABLED">CACHE_ENABLED</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>
 <div class="block">Controls whether the catalog will cache table entries upon load.</div>
@@ -2527,7 +2666,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CACHE_EXPIRATION_INTERVAL_MS_OFF">CACHE_EXPIRATION_INTERVAL_MS_OFF</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/hive/CachedClientPool.html" title="class in org.apache.iceberg.hive"><span class="typeNameLink">CachedClientPool</span></a> - Class in <a href="org/apache/iceberg/hive/package-summary.html">org.apache.iceberg.hive</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">A ClientPool that caches the underlying HiveClientPool instances.</div>
+</dd>
 <dt><a href="org/apache/iceberg/CachingCatalog.html" title="class in org.apache.iceberg"><span class="typeNameLink">CachingCatalog</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">Class that wraps an Iceberg Catalog to cache tables.</div>
@@ -2544,6 +2685,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html#call-org.apache.spark.sql.catalyst.InternalRow-">call(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RemoveOrphanFilesProcedure</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html#call-org.apache.spark.sql.catalyst.InternalRow-">call(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RewritePositionDeleteFilesProcedure</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#CALL">CALL</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#CALL">CALL</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser</a></dt>
@@ -2594,12 +2737,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.DateToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampNtzToDaysFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.DateToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampNtzToMonthsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html" title="class in org.apache.iceberg.spark.functions">TruncateFunction.TruncateBigInt</a></dt>
@@ -2618,6 +2767,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.DateToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampNtzToYearsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html#canonicalName--">canonicalName()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/transforms/Hours.html#canTransform-org.apache.iceberg.types.Type-">canTransform(Type)</a></span> - Method in class org.apache.iceberg.transforms.<a href="org/apache/iceberg/transforms/Hours.html" title="class in org.apache.iceberg.transforms">Hours</a></dt>
@@ -2668,6 +2819,8 @@
 <dd>
 <div class="block">Is it case sensitive</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseReplaceSortOrder.html#caseSensitive-boolean-">caseSensitive(boolean)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseReplaceSortOrder.html" title="class in org.apache.iceberg">BaseReplaceSortOrder</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DeleteFiles.html#caseSensitive-boolean-">caseSensitive(boolean)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/DeleteFiles.html" title="interface in org.apache.iceberg">DeleteFiles</a></dt>
 <dd>
 <div class="block">Enables or disables case sensitive expression binding for methods that accept expressions.</div>
@@ -2709,6 +2862,10 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SortOrder.Builder.html#caseSensitive-boolean-">caseSensitive(boolean)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SortOrder.Builder.html" title="class in org.apache.iceberg">SortOrder.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/SortOrderBuilder.html#caseSensitive-boolean-">caseSensitive(boolean)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/SortOrderBuilder.html" title="interface in org.apache.iceberg">SortOrderBuilder</a></dt>
+<dd>
+<div class="block">Set case sensitivity of sort column name resolution.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkScanBuilder.html#caseSensitive-boolean-">caseSensitive(boolean)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkScanBuilder.html" title="class in org.apache.iceberg.spark.source">SparkScanBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadConf.html#caseSensitive--">caseSensitive()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark">SparkReadConf</a></dt>
@@ -2815,6 +2972,8 @@
 <dd>
 <div class="block">An iterator that transforms rows from changelog tables within a single Spark task.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#ChangelogIterator-java.util.Iterator-org.apache.spark.sql.types.StructType-">ChangelogIterator(Iterator&lt;Row&gt;, StructType)</a></span> - Constructor for class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/ChangelogOperation.html" title="enum in org.apache.iceberg"><span class="typeNameLink">ChangelogOperation</span></a> - Enum in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">An enum representing possible operations in a changelog.</div>
@@ -2833,6 +2992,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.html#changes--">changes()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.html" title="class in org.apache.iceberg">TableMetadata</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#changeTypeIndex--">changeTypeIndex()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#channelNames">channelNames</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/gcp/GCPProperties.html#channelReadChunkSize--">channelReadChunkSize()</a></span> - Method in class org.apache.iceberg.gcp.<a href="org/apache/iceberg/gcp/GCPProperties.html" title="class in org.apache.iceberg.gcp">GCPProperties</a></dt>
@@ -2855,6 +3016,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/exceptions/ValidationException.html#check-boolean-java.lang.String-java.lang.Object...-">check(boolean, String, Object...)</a></span> - Static method in exception org.apache.iceberg.exceptions.<a href="org/apache/iceberg/exceptions/ValidationException.html" title="class in org.apache.iceberg.exceptions">ValidationException</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/view/ViewVersion.html#check--">check()</a></span> - Method in interface org.apache.iceberg.view.<a href="org/apache/iceberg/view/ViewVersion.html" title="interface in org.apache.iceberg.view">ViewVersion</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#CHECK_NULLABILITY">CHECK_NULLABILITY</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#CHECK_NULLABILITY">CHECK_NULLABILITY</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
@@ -2894,6 +3057,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html#checkSourceCatalog-org.apache.spark.sql.connector.catalog.CatalogPlugin-">checkSourceCatalog(CatalogPlugin)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html" title="class in org.apache.iceberg.spark.actions">SnapshotTableSparkAction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CHECKSUM_ENABLED">CHECKSUM_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Enables eTag checks for S3 PUT and MULTIPART upload requests.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CHECKSUM_ENABLED_DEFAULT">CHECKSUM_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManageSnapshots.html#cherrypick-long-">cherrypick(long)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ManageSnapshots.html" title="interface in org.apache.iceberg">ManageSnapshots</a></dt>
 <dd>
 <div class="block">Apply supported changes in given snapshot and create a new snapshot which will be set as the
@@ -2950,8 +3119,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/StructLikeSet.html#clear--">clear()</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/StructLikeSet.html" title="class in org.apache.iceberg.util">StructLikeSet</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html#clearRewrite-org.apache.iceberg.Table-java.lang.String-">clearRewrite(Table, String)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark">FileRewriteCoordinator</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/AliyunProperties.html#CLIENT_ACCESS_KEY_ID">CLIENT_ACCESS_KEY_ID</a></span> - Static variable in class org.apache.iceberg.aliyun.<a href="org/apache/iceberg/aliyun/AliyunProperties.html" title="class in org.apache.iceberg.aliyun">AliyunProperties</a></dt>
 <dd>
 <div class="block">Aliyun uses an AccessKey pair, which includes an AccessKey ID and an AccessKey secret to
@@ -2988,10 +3155,17 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_ASSUME_ROLE_TIMEOUT_SEC_DEFAULT">CLIENT_ASSUME_ROLE_TIMEOUT_SEC_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_CREDENTIALS_PROVIDER">CLIENT_CREDENTIALS_PROVIDER</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#CLIENT_CREDENTIALS_PROVIDER">CLIENT_CREDENTIALS_PROVIDER</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
 <dd>
 <div class="block">Configure the AWS credentials provider used to create AWS clients.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_CREDENTIALS_PROVIDER">CLIENT_CREDENTIALS_PROVIDER</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><code>AwsClientProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/AliyunProperties.html#CLIENT_FACTORY">CLIENT_FACTORY</a></span> - Static variable in class org.apache.iceberg.aliyun.<a href="org/apache/iceberg/aliyun/AliyunProperties.html" title="class in org.apache.iceberg.aliyun">AliyunProperties</a></dt>
 <dd>
 <div class="block">The implementation class of <a href="org/apache/iceberg/aliyun/AliyunClientFactory.html" title="interface in org.apache.iceberg.aliyun"><code>AliyunClientFactory</code></a> to customize Aliyun client
@@ -3001,6 +3175,10 @@
 <dd>
 <div class="block">The implementation class of <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a> to customize AWS client configurations.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CLIENT_FACTORY">CLIENT_FACTORY</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">This property is used to pass in the aws client factory implementation class for S3 FileIO.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/dell/DellProperties.html#CLIENT_FACTORY">CLIENT_FACTORY</a></span> - Static variable in class org.apache.iceberg.dell.<a href="org/apache/iceberg/dell/DellProperties.html" title="class in org.apache.iceberg.dell">DellProperties</a></dt>
 <dd>
 <div class="block">The implementation class of <a href="org/apache/iceberg/dell/DellClientFactory.html" title="interface in org.apache.iceberg.dell"><code>DellClientFactory</code></a> to customize Dell client configurations.</div>
@@ -3009,15 +3187,42 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_CACHE_EVICTION_INTERVAL_MS_DEFAULT">CLIENT_POOL_CACHE_EVICTION_INTERVAL_MS_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_CACHE_KEYS">CLIENT_POOL_CACHE_KEYS</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
+<dd>
+<div class="block">A comma separated list of elements used, in addition to the <a href="org/apache/iceberg/CatalogProperties.html#URI"><code>CatalogProperties.URI</code></a>, to compose the key of
+ the client pool cache.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_SIZE">CLIENT_POOL_SIZE</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#CLIENT_POOL_SIZE_DEFAULT">CLIENT_POOL_SIZE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_REGION">CLIENT_REGION</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#CLIENT_REGION">CLIENT_REGION</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
 <dd>
 <div class="block">Used by <code>AwsClientFactories.DefaultAwsClientFactory</code> and also
  other client factory classes.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#CLIENT_REGION">CLIENT_REGION</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws"><code>AwsClientProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE">CLIENT_TYPE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">The type of <code>SdkHttpClient</code> implementation used by <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a> If set, all AWS clients will use this specified HTTP client.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE_APACHE">CLIENT_TYPE_APACHE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">If this is set under <a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE"><code>HttpClientProperties.CLIENT_TYPE</code></a>, <code>ApacheHttpClient</code> will be used as the HTTP Client in <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a></div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE_DEFAULT">CLIENT_TYPE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE_URLCONNECTION">CLIENT_TYPE_URLCONNECTION</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">If this is set under <a href="org/apache/iceberg/aws/HttpClientProperties.html#CLIENT_TYPE"><code>HttpClientProperties.CLIENT_TYPE</code></a>, <code>UrlConnectionHttpClient</code> will be used as the HTTP
+ Client in <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a></div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#clientAssumeRoleArn--">clientAssumeRoleArn()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#clientAssumeRoleExternalId--">clientAssumeRoleExternalId()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
@@ -3038,13 +3243,33 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ClientPoolImpl.html#ClientPoolImpl-int-java.lang.Class-boolean-">ClientPoolImpl(int, Class&lt;? extends E&gt;, boolean)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/ClientPoolImpl.html" title="class in org.apache.iceberg">ClientPoolImpl</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#clientRegion--">clientRegion()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#clientRegion--">clientRegion()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.html#clone--">clone()</a></span> - Method in interface org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.html" title="interface in org.apache.iceberg.flink">CatalogLoader</a></dt>
+<dd>
+<div class="block">Clone a CatalogLoader.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.CustomCatalogLoader.html#clone--">clone()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.CustomCatalogLoader.html" title="class in org.apache.iceberg.flink">CatalogLoader.CustomCatalogLoader</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.HadoopCatalogLoader.html#clone--">clone()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.HadoopCatalogLoader.html" title="class in org.apache.iceberg.flink">CatalogLoader.HadoopCatalogLoader</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.HiveCatalogLoader.html#clone--">clone()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.HiveCatalogLoader.html" title="class in org.apache.iceberg.flink">CatalogLoader.HiveCatalogLoader</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.RESTCatalogLoader.html#clone--">clone()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.RESTCatalogLoader.html" title="class in org.apache.iceberg.flink">CatalogLoader.RESTCatalogLoader</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/data/RowDataUtil.html#clone-org.apache.flink.table.data.RowData-org.apache.flink.table.data.RowData-org.apache.flink.table.types.logical.RowType-org.apache.flink.api.common.typeutils.TypeSerializer:A-">clone(RowData, RowData, RowType, TypeSerializer[])</a></span> - Static method in class org.apache.iceberg.flink.data.<a href="org/apache/iceberg/flink/data/RowDataUtil.html" title="class in org.apache.iceberg.flink.data">Ro [...]
 <dd>
 <div class="block">Similar to the private <code>RowDataSerializer.copyRowData(RowData, RowData)</code> method.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#close--">close()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager.CommitService</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/TableLoader.CatalogTableLoader.html#clone--">clone()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/TableLoader.CatalogTableLoader.html" title="class in org.apache.iceberg.flink">TableLoader.CatalogTableLoader</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/TableLoader.html#clone--">clone()</a></span> - Method in interface org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/TableLoader.html" title="interface in org.apache.iceberg.flink">TableLoader</a></dt>
+<dd>
+<div class="block">Clone a TableLoader</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/TableLoader.HadoopTableLoader.html#clone--">clone()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/TableLoader.HadoopTableLoader.html" title="class in org.apache.iceberg.flink">TableLoader.HadoopTableLoader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/oss/OSSFileIO.html#close--">close()</a></span> - Method in class org.apache.iceberg.aliyun.oss.<a href="org/apache/iceberg/aliyun/oss/OSSFileIO.html" title="class in org.apache.iceberg.aliyun.oss">OSSFileIO</a></dt>
 <dd>&nbsp;</dd>
@@ -3074,6 +3299,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIO.html#close--">close()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/util/RetryDetector.html#close--">close()</a></span> - Method in class org.apache.iceberg.aws.util.<a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util">RetryDetector</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ClientPoolImpl.html#close-C-">close(C)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ClientPoolImpl.html" title="class in org.apache.iceberg">ClientPoolImpl</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ClientPoolImpl.html#close--">close()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ClientPoolImpl.html" title="class in org.apache.iceberg">ClientPoolImpl</a></dt>
@@ -3115,6 +3342,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveClientPool.html#close-org.apache.hadoop.hive.metastore.IMetaStoreClient-">close(IMetaStoreClient)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveClientPool.html" title="class in org.apache.iceberg.hive">HiveClientPool</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#close--">close()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#close--">close()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BasePositionDeltaWriter.html#close--">close()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BasePositionDeltaWriter.html" title="class in org.apache.iceberg.io">BasePositionDeltaWriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BaseTaskWriter.BaseEqualityDeltaWriter.html#close--">close()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BaseTaskWriter.BaseEqualityDeltaWriter.html" title="class in org.apache.iceberg.io">BaseTaskWriter.BaseEqualityDeltaWriter</a></dt>
@@ -3241,6 +3472,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/PuffinCompressionCodec.html#codecName--">codecName()</a></span> - Method in enum org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/PuffinCompressionCodec.html" title="enum in org.apache.iceberg.puffin">PuffinCompressionCodec</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/util/PartitionUtil.html#coercePartition-org.apache.iceberg.types.Types.StructType-org.apache.iceberg.PartitionSpec-org.apache.iceberg.StructLike-">coercePartition(Types.StructType, PartitionSpec, StructLike)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/PartitionUtil.html" title="class in org.apache.iceberg.util">PartitionUtil</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/FindFiles.Builder.html#collect--">collect()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/FindFiles.Builder.html" title="class in org.apache.iceberg">FindFiles.Builder</a></dt>
 <dd>
 <div class="block">Returns all files in the table that match all of the filters.</div>
@@ -3332,10 +3565,17 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/CloseableIterable.html#combine-java.lang.Iterable-java.io.Closeable-">combine(Iterable&lt;E&gt;, Closeable)</a></span> - Static method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/CloseableIterable.html" title="interface in org.apache.iceberg.io">CloseableIterable</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/metrics/MetricsReporters.html#combine-org.apache.iceberg.metrics.MetricsReporter-org.apache.iceberg.metrics.MetricsReporter-">combine(MetricsReporter, MetricsReporter)</a></span> - Static method in class org.apache.iceberg.metrics.<a href="org/apache/iceberg/metrics/MetricsReporters.html" title="class in org.apache.iceberg.metrics">MetricsReporters</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/CombinedScanTask.html" title="interface in org.apache.iceberg"><span class="typeNameLink">CombinedScanTask</span></a> - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">A scan task made of several ranges from files.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html#commit-java.util.Set-">commit(Set&lt;RewritePositionDeletesGroup&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager</a></dt>
+<dd>
+<div class="block">Perform a commit operation on the table adding and removing files as required for this set of
+ file groups.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetastoreTableOperations.html#commit-org.apache.iceberg.TableMetadata-org.apache.iceberg.TableMetadata-">commit(TableMetadata, TableMetadata)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetastoreTableOperations.html" title="class in org.apache.iceberg">BaseMetastoreTableOperations</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseReplaceSortOrder.html#commit--">commit()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseReplaceSortOrder.html" title="class in org.apache.iceberg">BaseReplaceSortOrder</a></dt>
@@ -3446,6 +3686,12 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.html#commitOrClean-java.util.Set-">commitOrClean(Set&lt;RewriteFileGroup&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#commitOrClean-java.util.Set-">commitOrClean(Set&lt;RewriteFileGroup&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager.CommitService</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html#commitOrClean-java.util.Set-">commitOrClean(Set&lt;RewritePositionDeletesGroup&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.CommitService.html#commitOrClean-java.util.Set-">commitOrClean(Set&lt;RewritePositionDeletesGroup&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager.CommitService</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/CommitMetadata.html#commitProperties--">commitProperties()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/CommitMetadata.html" title="class in org.apache.iceberg.spark">CommitMetadata</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/metrics/CommitReport.html" title="interface in org.apache.iceberg.metrics"><span class="typeNameLink">CommitReport</span></a> - Interface in <a href="org/apache/iceberg/metrics/package-summary.html">org.apache.iceberg.metrics</a></dt>
@@ -3482,6 +3728,10 @@
 <dd>
 <div class="block">Apply the pending changes from all actions and commit.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#comparator-org.apache.iceberg.RewriteJobOrder-">comparator(RewriteJobOrder)</a></span> - Static method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#comparator-org.apache.iceberg.RewriteJobOrder-">comparator(RewriteJobOrder)</a></span> - Static method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/BoundTerm.html#comparator--">comparator()</a></span> - Method in interface org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/BoundTerm.html" title="interface in org.apache.iceberg.expressions">BoundTerm</a></dt>
 <dd>
 <div class="block">Returns a <code>Comparator</code> for values produced by this term.</div>
@@ -3516,17 +3766,22 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteOptions.html#COMPRESSION_CODEC">COMPRESSION_CODEC</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteOptions.html" title="class in org.apache.iceberg.flink">FlinkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#COMPRESSION_FACTOR">COMPRESSION_FACTOR</a></span> - Static variable in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>
-<div class="block">The number of shuffle partitions and consequently the number of output files created by the
- Spark Sort is based on the size of the input data files used in this rewrite operation.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteOptions.html#COMPRESSION_LEVEL">COMPRESSION_LEVEL</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteOptions.html" title="class in org.apache.iceberg.flink">FlinkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteOptions.html#COMPRESSION_STRATEGY">COMPRESSION_STRATEGY</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteOptions.html" title="class in org.apache.iceberg.flink">FlinkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/BlobMetadata.html#compressionCodec--">compressionCodec()</a></span> - Method in class org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/BlobMetadata.html" title="class in org.apache.iceberg.puffin">BlobMetadata</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/ComputeUpdateIterator.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">ComputeUpdateIterator</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
+<dd>
+<div class="block">An iterator that finds delete/insert rows which represent an update, and converts them into
+ update records from changelog tables within a single Spark task.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#computeUpdates-java.util.Iterator-org.apache.spark.sql.types.StructType-java.lang.String:A-">computeUpdates(Iterator&lt;Row&gt;, StructType, String[])</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>
+<div class="block">Creates an iterator composing <code>RemoveCarryoverIterator</code> and <a href="org/apache/iceberg/spark/ComputeUpdateIterator.html" title="class in org.apache.iceberg.spark"><code>ComputeUpdateIterator</code></a>
+ to remove carry-over rows and compute update rows</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/CloseableIterable.html#concat-java.lang.Iterable-">concat(Iterable&lt;CloseableIterable&lt;E&gt;&gt;)</a></span> - Static method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/CloseableIterable.html" title="interface in org.apache.iceberg.io">CloseableIterable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/Parquet.html#concat-java.lang.Iterable-java.io.File-int-org.apache.iceberg.Schema-java.util.Map-">concat(Iterable&lt;File&gt;, File, int, Schema, Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/Parquet.html" title="class in org.apache.iceberg.parquet">Parquet</a></dt>
@@ -3759,7 +4014,7 @@
 </dd>
 <dt><a href="org/apache/iceberg/flink/source/enumerator/ContinuousSplitPlannerImpl.html" title="class in org.apache.iceberg.flink.source.enumerator"><span class="typeNameLink">ContinuousSplitPlannerImpl</span></a> - Class in <a href="org/apache/iceberg/flink/source/enumerator/package-summary.html">org.apache.iceberg.flink.source.enumerator</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/enumerator/ContinuousSplitPlannerImpl.html#ContinuousSplitPlannerImpl-org.apache.iceberg.Table-org.apache.iceberg.flink.source.ScanContext-java.lang.String-">ContinuousSplitPlannerImpl(Table, ScanContext, String)</a></span> - Constructor for class org.apache.iceberg.flink.source.enumerator.<a href="org/apache/iceberg/flink/source/enumerator/ContinuousSplitPlannerImpl.html" title="class in org.apache.iceberg.flink.s [...]
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/enumerator/ContinuousSplitPlannerImpl.html#ContinuousSplitPlannerImpl-org.apache.iceberg.flink.TableLoader-org.apache.iceberg.flink.source.ScanContext-java.lang.String-">ContinuousSplitPlannerImpl(TableLoader, ScanContext, String)</a></span> - Constructor for class org.apache.iceberg.flink.source.enumerator.<a href="org/apache/iceberg/flink/source/enumerator/ContinuousSplitPlannerImpl.html" title="class in org.apac [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/types/Conversions.html" title="class in org.apache.iceberg.types"><span class="typeNameLink">Conversions</span></a> - Class in <a href="org/apache/iceberg/types/package-summary.html">org.apache.iceberg.types</a></dt>
 <dd>&nbsp;</dd>
@@ -3865,8 +4120,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkAggregates.html#convert-org.apache.spark.sql.connector.expressions.aggregate.AggregateFunc-">convert(AggregateFunc)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkAggregates.html" title="class in org.apache.iceberg.spark">SparkAggregates</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html#convert-org.apache.iceberg.SortOrder-">convert(SortOrder)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark">SparkDistributionAndOrderingUtil</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkFilters.html#convert-org.apache.spark.sql.sources.Filter:A-">convert(Filter[])</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkFilters.html" title="class in org.apache.iceberg.spark">SparkFilters</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkFilters.html#convert-org.apache.spark.sql.sources.Filter-">convert(Filter)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkFilters.html" title="class in org.apache.iceberg.spark">SparkFilters</a></dt>
@@ -3883,10 +4136,6 @@
 <dd>
 <div class="block">Convert a Spark <code>struct</code> to a <a href="org/apache/iceberg/Schema.html" title="class in org.apache.iceberg"><code>Schema</code></a> with new field ids.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSchemaUtil.html#convert-org.apache.spark.sql.types.StructType-boolean-">convert(StructType, boolean)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSchemaUtil.html" title="class in org.apache.iceberg.spark">SparkSchemaUtil</a></dt>
-<dd>
-<div class="block">Convert a Spark <code>struct</code> to a <a href="org/apache/iceberg/Schema.html" title="class in org.apache.iceberg"><code>Schema</code></a> with new field ids.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSchemaUtil.html#convert-org.apache.spark.sql.types.DataType-">convert(DataType)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSchemaUtil.html" title="class in org.apache.iceberg.spark">SparkSchemaUtil</a></dt>
 <dd>
 <div class="block">Convert a Spark <code>struct</code> to a <a href="org/apache/iceberg/types/Type.html" title="interface in org.apache.iceberg.types"><code>Type</code></a> with new field ids.</div>
@@ -3945,6 +4194,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/UUIDUtil.html#convertToByteBuffer-java.util.UUID-">convertToByteBuffer(UUID)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/UUIDUtil.html" title="class in org.apache.iceberg.util">UUIDUtil</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/util/UUIDUtil.html#convertToByteBuffer-java.util.UUID-java.nio.ByteBuffer-">convertToByteBuffer(UUID, ByteBuffer)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/UUIDUtil.html" title="class in org.apache.iceberg.util">UUIDUtil</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/AvroSchemaUtil.html#convertTypes-org.apache.iceberg.types.Types.StructType-java.lang.String-">convertTypes(Types.StructType, String)</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/AvroSchemaUtil.html" title="class in org.apache.iceberg.avro">AvroSchemaUtil</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSchemaUtil.html#convertWithFreshIds-org.apache.iceberg.Schema-org.apache.spark.sql.types.StructType-">convertWithFreshIds(Schema, StructType)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSchemaUtil.html" title="class in org.apache.iceberg.spark">SparkSchemaUtil</a></dt>
@@ -4061,8 +4312,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/SerializableMap.html#copyOf-java.util.Map-">copyOf(Map&lt;K, V&gt;)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/SerializableMap.html" title="class in org.apache.iceberg.util">SerializableMap</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#copyOnWriteMergeDistributionMode--">copyOnWriteMergeDistributionMode()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#copyOnWriteRequirements-org.apache.spark.sql.connector.write.RowLevelOperation.Command-">copyOnWriteRequirements(RowLevelOperation.Command)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteUtil.html#copyOnWriteRequirements-org.apache.iceberg.Table-org.apache.spark.sql.connector.write.RowLevelOperation.Command-org.apache.iceberg.DistributionMode-boolean-">copyOnWriteRequirements(Table, RowLevelOperation.Command, DistributionMode, boolean)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteUtil.html" title="class in org.apache.iceberg.spark">Spar [...]
+<dd>
+<div class="block">Builds requirements for copy-on-write DELETE, UPDATE, MERGE operations.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.html#copyWithAppendsBetween-java.lang.Long-long-">copyWithAppendsBetween(Long, long)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.html" title="class in org.apache.iceberg.flink.source">ScanContext</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkTable.html#copyWithBranch-java.lang.String-">copyWithBranch(String)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source">SparkTable</a></dt>
@@ -4234,6 +4489,8 @@
 <dd>
 <div class="block">Create a table using the FileSystem implementation resolve from location.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#create--">create()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/OutputFile.html#create--">create()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/OutputFile.html" title="interface in org.apache.iceberg.io">OutputFile</a></dt>
 <dd>
 <div class="block">Create a new file and return a <a href="org/apache/iceberg/io/PositionOutputStream.html" title="class in org.apache.iceberg.io"><code>PositionOutputStream</code></a> to it.</div>
@@ -4248,10 +4505,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/orc/OrcValueReaders.StructReader.html#create--">create()</a></span> - Method in class org.apache.iceberg.orc.<a href="org/apache/iceberg/orc/OrcValueReaders.StructReader.html" title="class in org.apache.iceberg.orc">OrcValueReaders.StructReader</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#create-java.util.Iterator-org.apache.spark.sql.types.StructType-java.lang.String:A-">create(Iterator&lt;Row&gt;, StructType, String[])</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
-<dd>
-<div class="block">Creates an iterator for records of a changelog table.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Tables.html#create-org.apache.iceberg.Schema-java.lang.String-">create(Schema, String)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Tables.html" title="interface in org.apache.iceberg">Tables</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Tables.html#create-org.apache.iceberg.Schema-org.apache.iceberg.PartitionSpec-java.lang.String-">create(Schema, PartitionSpec, String)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Tables.html" title="interface in org.apache.iceberg">Tables</a></dt>
@@ -4308,8 +4561,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/Parquet.ReadBuilder.html#createBatchedReaderFunc-java.util.function.Function-">createBatchedReaderFunc(Function&lt;MessageType, VectorizedReader&lt;?&gt;&gt;)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/Parquet.ReadBuilder.html" title="class in org.apache.iceberg.parquet">Parquet.ReadBuilder</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaBatchWrite.html#createBatchWriterFactory-org.apache.spark.sql.connector.write.PhysicalWriteInfo-">createBatchWriterFactory(PhysicalWriteInfo)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaBatchWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaBatchWrite</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManageSnapshots.html#createBranch-java.lang.String-long-">createBranch(String, long)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ManageSnapshots.html" title="interface in org.apache.iceberg">ManageSnapshots</a></dt>
 <dd>
 <div class="block">Create a new branch pointing to the given snapshot id.</div>
@@ -4394,6 +4645,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#createNamespace-org.apache.iceberg.catalog.Namespace-java.util.Map-">createNamespace(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#createNamespace-org.apache.iceberg.catalog.Namespace-">createNamespace(Namespace)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#createNamespace-org.apache.iceberg.catalog.Namespace-java.util.Map-">createNamespace(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#createNamespace-org.apache.iceberg.catalog.Namespace-java.util.Map-">createNamespace(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#createNamespace-org.apache.iceberg.catalog.Namespace-java.util.Map-">createNamespace(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -4437,6 +4692,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopOutputFile.html#createOrOverwrite--">createOrOverwrite()</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopOutputFile.html" title="class in org.apache.iceberg.hadoop">HadoopOutputFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#createOrOverwrite--">createOrOverwrite()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/OutputFile.html#createOrOverwrite--">createOrOverwrite()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/OutputFile.html" title="interface in org.apache.iceberg.io">OutputFile</a></dt>
 <dd>
 <div class="block">Create a new file and return a <a href="org/apache/iceberg/io/PositionOutputStream.html" title="class in org.apache.iceberg.io"><code>PositionOutputStream</code></a> to it.</div>
@@ -4577,8 +4834,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/parquet/BaseParquetWriter.html#createWriter-org.apache.parquet.schema.MessageType-">createWriter(MessageType)</a></span> - Method in class org.apache.iceberg.data.parquet.<a href="org/apache/iceberg/data/parquet/BaseParquetWriter.html" title="class in org.apache.iceberg.data.parquet">BaseParquetWriter</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriterFactory.html#createWriter-int-long-">createWriter(int, long)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriterFactory.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWriterFactory</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.DataWriteBuilder.html#createWriterFunc-java.util.function.Function-">createWriterFunc(Function&lt;Schema, DatumWriter&lt;?&gt;&gt;)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.DataWriteBuilder.html" title="class in org.apache.iceberg.avro">Avro.DataWriteBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.DeleteWriteBuilder.html#createWriterFunc-java.util.function.Function-">createWriterFunc(Function&lt;Schema, DatumWriter&lt;?&gt;&gt;)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.DeleteWriteBuilder.html" title="class in org.apache.iceberg.avro">Avro.DeleteWriteBuilder</a></dt>
@@ -4611,6 +4866,10 @@
 <dd>
 <div class="block">Returns the session's credential map.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#credentialsProvider-java.lang.String-java.lang.String-java.lang.String-">credentialsProvider(String, String, String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
+<dd>
+<div class="block">Returns a credentials provider instance.</div>
+</dd>
 <dt><a href="org/apache/iceberg/io/CredentialSupplier.html" title="interface in org.apache.iceberg.io"><span class="typeNameLink">CredentialSupplier</span></a> - Interface in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>
 <div class="block">Interface used to expose credentials held by a FileIO instance.</div>
@@ -4749,6 +5008,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/DataFiles.Builder.html" title="class in org.apache.iceberg"><span class="typeNameLink">DataFiles.Builder</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html#dataFilesCount--">dataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupFailureResult</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/DataFilesTable.html" title="class in org.apache.iceberg"><span class="typeNameLink">DataFilesTable</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">A <a href="org/apache/iceberg/Table.html" title="interface in org.apache.iceberg"><code>Table</code></a> implementation that exposes a table's data files as rows.</div>
@@ -4786,22 +5047,16 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/BaseFileWriterFactory.html#dataSchema--">dataSchema()</a></span> - Method in class org.apache.iceberg.data.<a href="org/apache/iceberg/data/BaseFileWriterFactory.html" title="class in org.apache.iceberg.data">BaseFileWriterFactory</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/iceberg/DataTableScan.html" title="class in org.apache.iceberg"><span class="typeNameLink">DataTableScan</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/DataTableScan.html#DataTableScan-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-">DataTableScan(TableOperations, Table)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/DataTableScan.html" title="class in org.apache.iceberg">DataTableScan</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/ContentFile.html#dataSequenceNumber--">dataSequenceNumber()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ContentFile.html" title="interface in org.apache.iceberg">ContentFile</a></dt>
 <dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use DataTableScan(Table, Schema, TableScanContext)
-     instead.</span></div>
-</div>
+<div class="block">Returns the data sequence number of the file.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/DataTableScan.html#DataTableScan-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-org.apache.iceberg.Schema-org.apache.iceberg.TableScanContext-">DataTableScan(TableOperations, Table, Schema, TableScanContext)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/DataTableScan.html" title="class in org.apache.iceberg">DataTableScan</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#dataSequenceNumber-long-">dataSequenceNumber(long)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
 <dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use DataTableScan(Table, Schema, TableScanContext)
-     instead.</span></div>
-</div>
+<div class="block">Configure the data sequence number for this rewrite operation.</div>
 </dd>
+<dt><a href="org/apache/iceberg/DataTableScan.html" title="class in org.apache.iceberg"><span class="typeNameLink">DataTableScan</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DataTableScan.html#DataTableScan-org.apache.iceberg.Table-org.apache.iceberg.Schema-org.apache.iceberg.TableScanContext-">DataTableScan(Table, Schema, TableScanContext)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/DataTableScan.html" title="class in org.apache.iceberg">DataTableScan</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/DataTask.html" title="interface in org.apache.iceberg"><span class="typeNameLink">DataTask</span></a> - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -4902,6 +5157,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">DaysFunction.DateToDaysFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">DaysFunction.TimestampNtzToDaysFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">DaysFunction.TimestampToDaysFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/DateTimeUtil.html#daysToIsoDate-int-">daysToIsoDate(int)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/DateTimeUtil.html" title="class in org.apache.iceberg.util">DateTimeUtil</a></dt>
@@ -5075,6 +5332,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.html#defaultSpecId--">defaultSpecId()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.html" title="class in org.apache.iceberg">TableMetadata</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#defaultTargetFileSize--">defaultTargetFileSize()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#defaultTargetFileSize--">defaultTargetFileSize()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html#defaultTargetFileSize--">defaultTargetFileSize()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedPositionDeletesRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/metrics/DefaultTimer.html" title="class in org.apache.iceberg.metrics"><span class="typeNameLink">DefaultTimer</span></a> - Class in <a href="org/apache/iceberg/metrics/package-summary.html">org.apache.iceberg.metrics</a></dt>
 <dd>
 <div class="block">A default <a href="org/apache/iceberg/metrics/Timer.html" title="interface in org.apache.iceberg.metrics"><code>Timer</code></a> implementation that uses a <code>Stopwatch</code> instance internally to
@@ -5096,6 +5359,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#defaultWarehouseLocation-org.apache.iceberg.catalog.TableIdentifier-">defaultWarehouseLocation(TableIdentifier)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#defaultWarehouseLocation-org.apache.iceberg.catalog.TableIdentifier-">defaultWarehouseLocation(TableIdentifier)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#defaultWarehouseLocation-org.apache.iceberg.catalog.TableIdentifier-">defaultWarehouseLocation(TableIdentifier)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#defaultWarehouseLocation-org.apache.iceberg.catalog.TableIdentifier-">defaultWarehouseLocation(TableIdentifier)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -5155,20 +5420,38 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/RESTClient.html#delete-java.lang.String-java.util.Map-java.lang.Class-java.util.Map-java.util.function.Consumer-">delete(String, Map&lt;String, String&gt;, Class&lt;T&gt;, Map&lt;String, String&gt;, Consumer&lt;ErrorResponse&gt;)</a></span> - Method in interface org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/RESTClient.html" title="interface in org.apache.iceberg.rest">RESTClient</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html#delete-T-T-">delete(T, T)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWriter</a></dt>
-<dd>
-<div class="block">Passes information for a row that must be deleted.</div>
-</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#DELETE">DELETE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_AVRO_COMPRESSION">DELETE_AVRO_COMPRESSION</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_AVRO_COMPRESSION_LEVEL">DELETE_AVRO_COMPRESSION_LEVEL</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_BATCH_SIZE">DELETE_BATCH_SIZE</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure the batch size used when deleting multiple files from a given S3 bucket</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_BATCH_SIZE_DEFAULT">DELETE_BATCH_SIZE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Default batch size used when deleting files.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_BATCH_SIZE_MAX">DELETE_BATCH_SIZE_MAX</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Max possible batch size for deletion.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_DEFAULT_FILE_FORMAT">DELETE_DEFAULT_FILE_FORMAT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_DISTRIBUTION_MODE">DELETE_DISTRIBUTION_MODE</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_ENABLED">DELETE_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Determines if <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a> deletes the object when io.delete() is called, default to true.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_ENABLED_DEFAULT">DELETE_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#DELETE_FILE_PATH">DELETE_FILE_PATH</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/PositionDeletesTable.html#DELETE_FILE_PATH">DELETE_FILE_PATH</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/PositionDeletesTable.html" title="class in org.apache.iceberg">PositionDeletesTable</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#DELETE_FILE_POS">DELETE_FILE_POS</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#DELETE_FILE_ROW_DOC">DELETE_FILE_ROW_DOC</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
@@ -5179,10 +5462,20 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#DELETE_FILE_THRESHOLD">DELETE_FILE_THRESHOLD</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+<div class="block">The minimum number of deletes that needs to be associated with a data file for it to be
+ considered for rewriting.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#DELETE_FILE_THRESHOLD">DELETE_FILE_THRESHOLD</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
+<dd>
 <div class="block">The minimum number of deletes that needs to be associated with a data file for it to be
  considered for rewriting.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#DELETE_FILE_THRESHOLD_DEFAULT">DELETE_FILE_THRESHOLD_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#DELETE_FILE_THRESHOLD_DEFAULT">DELETE_FILE_THRESHOLD_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#DELETE_FORMAT">DELETE_FORMAT</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
@@ -5220,10 +5513,20 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_PARQUET_ROW_GROUP_SIZE_BYTES">DELETE_PARQUET_ROW_GROUP_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_TAGS_PREFIX">DELETE_TAGS_PREFIX</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Used by <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a> to tag objects when deleting.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_TARGET_FILE_SIZE_BYTES">DELETE_TARGET_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#DELETE_TARGET_FILE_SIZE_BYTES_DEFAULT">DELETE_TARGET_FILE_SIZE_BYTES_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DELETE_THREADS">DELETE_THREADS</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Number of threads to use for adding delete tags to S3 objects, default to <code>Runtime.availableProcessors()</code></div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#deleteBatchSize--">deleteBatchSize()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/UpdateSchema.html#deleteColumn-java.lang.String-">deleteColumn(String)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/UpdateSchema.html" title="interface in org.apache.iceberg">UpdateSchema</a></dt>
 <dd>
 <div class="block">Delete a column in the schema.</div>
@@ -5255,8 +5558,6 @@
 <div class="block">A scan task for deletes generated by removing a data file from the table.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#deletedDataFilesCount--">deletedDataFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#deletedDataFilesCount--">deletedDataFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
@@ -5269,8 +5570,6 @@
 <div class="block">Returns the number of deleted data files.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#deletedEqualityDeleteFilesCount--">deletedEqualityDeleteFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#deletedEqualityDeleteFilesCount--">deletedEqualityDeleteFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
@@ -5296,11 +5595,7 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/ManifestFileBean.html#deletedFilesCount--">deletedFilesCount()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/ManifestFileBean.html" title="class in org.apache.iceberg.spark.actions">ManifestFileBean</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#deleteDistributionMode--">deleteDistributionMode()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#deletedManifestListsCount--">deletedManifestListsCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#deletedManifestListsCount--">deletedManifestListsCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
@@ -5313,8 +5608,6 @@
 <div class="block">Returns the number of deleted manifest lists.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#deletedManifestsCount--">deletedManifestsCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#deletedManifestsCount--">deletedManifestsCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
@@ -5327,14 +5620,14 @@
 <div class="block">Returns the number of deleted manifests.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#deletedOtherFilesCount--">deletedOtherFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/DeleteReachableFiles.Result.html#deletedOtherFilesCount--">deletedOtherFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/DeleteReachableFiles.Result.html" title="interface in org.apache.iceberg.actions">DeleteReachableFiles.Result</a></dt>
 <dd>
 <div class="block">Returns the number of deleted metadata json, version hint files.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html#deletedPositionDeleteFilesCount--">deletedPositionDeleteFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteReachableFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteReachableFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html#deletedPositionDeleteFilesCount--">deletedPositionDeleteFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html" title="class in org.apache.iceberg.actions">BaseExpireSnapshotsActionResult</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 &nbsp;</dd>
@@ -5394,6 +5687,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopFileIO.html#deleteFile-java.lang.String-">deleteFile(String)</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopFileIO.html" title="class in org.apache.iceberg.hadoop">HadoopFileIO</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#deleteFile-java.lang.String-">deleteFile(String)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/FileIO.html#deleteFile-java.lang.String-">deleteFile(String)</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/FileIO.html" title="interface in org.apache.iceberg.io">FileIO</a></dt>
 <dd>
 <div class="block">Delete the file at the given path.</div>
@@ -5412,6 +5707,14 @@
 <dd>
 <div class="block">Delete a <a href="org/apache/iceberg/DataFile.html" title="interface in org.apache.iceberg"><code>DataFile</code></a> from the table.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#deleteFile-org.apache.iceberg.DataFile-">deleteFile(DataFile)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
+<dd>
+<div class="block">Remove a data file from the current table state.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#deleteFile-org.apache.iceberg.DeleteFile-">deleteFile(DeleteFile)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
+<dd>
+<div class="block">Remove a delete file from the table state.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/StreamingDelete.html#deleteFile-java.lang.CharSequence-">deleteFile(CharSequence)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/StreamingDelete.html" title="class in org.apache.iceberg">StreamingDelete</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/StreamingDelete.html#deleteFile-org.apache.iceberg.DataFile-">deleteFile(DataFile)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/StreamingDelete.html" title="class in org.apache.iceberg">StreamingDelete</a></dt>
@@ -5424,6 +5727,10 @@
 <dd>
 <div class="block">Deletes the given paths in a batched manner.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogUtil.html#deleteFiles-org.apache.iceberg.io.FileIO-java.lang.Iterable-java.lang.String-boolean-">deleteFiles(FileIO, Iterable&lt;String&gt;, String, boolean)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogUtil.html" title="class in org.apache.iceberg">CatalogUtil</a></dt>
+<dd>
+<div class="block">Helper to delete files.</div>
+</dd>
 <dt><a href="org/apache/iceberg/DeleteFiles.html" title="interface in org.apache.iceberg"><span class="typeNameLink">DeleteFiles</span></a> - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">API for deleting files from a table.</div>
@@ -5547,6 +5854,10 @@
 </dd>
 <dt><a href="org/apache/iceberg/io/DeleteSchemaUtil.html" title="class in org.apache.iceberg.io"><span class="typeNameLink">DeleteSchemaUtil</span></a> - Class in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#deleteTags--">deleteTags()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#deleteThreads--">deleteThreads()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/RollbackStagedTable.html#deleteWhere-org.apache.spark.sql.sources.Filter:A-">deleteWhere(Filter[])</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/RollbackStagedTable.html" title="class in org.apache.iceberg.spark">RollbackStagedTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkTable.html#deleteWhere-org.apache.spark.sql.sources.Filter:A-">deleteWhere(Filter[])</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source">SparkTable</a></dt>
@@ -5600,10 +5911,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/dell/DellProperties.html#DellProperties-java.util.Map-">DellProperties(Map&lt;String, String&gt;)</a></span> - Constructor for class org.apache.iceberg.dell.<a href="org/apache/iceberg/dell/DellProperties.html" title="class in org.apache.iceberg.dell">DellProperties</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/DeltaBatchWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">DeltaBatchWrite</span></a> - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">An interface that defines how to write a delta of rows during batch processing.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/delta/SnapshotDeltaLakeTable.html#deltaLakeConfiguration-org.apache.hadoop.conf.Configuration-">deltaLakeConfiguration(Configuration)</a></span> - Method in interface org.apache.iceberg.delta.<a href="org/apache/iceberg/delta/SnapshotDeltaLakeTable.html" title="interface in org.apache.iceberg.delta">SnapshotDeltaLakeTable</a></dt>
 <dd>
 <div class="block">Sets the Hadoop configuration used to access delta lake table's logs and datafiles.</div>
@@ -5614,22 +5921,6 @@
 </dd>
 <dt><a href="org/apache/iceberg/delta/DeltaLakeToIcebergMigrationActionsProvider.DefaultDeltaLakeToIcebergMigrationActions.html" title="class in org.apache.iceberg.delta"><span class="typeNameLink">DeltaLakeToIcebergMigrationActionsProvider.DefaultDeltaLakeToIcebergMigrationActions</span></a> - Class in <a href="org/apache/iceberg/delta/package-summary.html">org.apache.iceberg.delta</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">DeltaWrite</span></a> - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">A logical representation of a data source write that handles a delta of rows.</div>
-</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriteBuilder.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">DeltaWriteBuilder</span></a> - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">An interface for building delta writes.</div>
-</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">DeltaWriter</span></a>&lt;<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="type parameter in DeltaWriter">T</a>&gt; - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">A data writer responsible for writing a delta of rows.</div>
-</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriterFactory.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">DeltaWriterFactory</span></a> - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">A factory for creating and initializing delta writers at the executor side.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseReplaceSortOrder.html#desc-org.apache.iceberg.expressions.Term-org.apache.iceberg.NullOrder-">desc(Term, NullOrder)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseReplaceSortOrder.html" title="class in org.apache.iceberg">BaseReplaceSortOrder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BaseColumnIterator.html#desc">desc</a></span> - Variable in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BaseColumnIterator.html" title="class in org.apache.iceberg.parquet">BaseColumnIterator</a></dt>
@@ -5678,6 +5969,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#describe-org.apache.iceberg.SortOrder-">describe(SortOrder)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/FileRewriter.html#description--">description()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions">FileRewriter</a></dt>
+<dd>
+<div class="block">Returns a description for this rewriter.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.html#description--">description()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.html" title="class in org.apache.iceberg.spark.functions">BucketFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.html#description--">description()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction</a></dt>
@@ -5702,6 +5997,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html#description--">description()</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RemoveOrphanFilesProcedure</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html#description--">description()</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RewritePositionDeleteFilesProcedure</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/metrics/NumDeletes.html#description--">description()</a></span> - Method in class org.apache.iceberg.spark.source.metrics.<a href="org/apache/iceberg/spark/source/metrics/NumDeletes.html" title="class in org.apache.iceberg.spark.source.metrics">NumDeletes</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/metrics/NumSplits.html#description--">description()</a></span> - Method in class org.apache.iceberg.spark.source.metrics.<a href="org/apache/iceberg/spark/source/metrics/NumSplits.html" title="class in org.apache.iceberg.spark.source.metrics">NumSplits</a></dt>
@@ -5770,6 +6067,10 @@
 <dd>
 <div class="block">The view query SQL dialect.</div>
 </dd>
+<dt><a href="org/apache/iceberg/arrow/DictEncodedArrowConverter.html" title="class in org.apache.iceberg.arrow"><span class="typeNameLink">DictEncodedArrowConverter</span></a> - Class in <a href="org/apache/iceberg/arrow/package-summary.html">org.apache.iceberg.arrow</a></dt>
+<dd>
+<div class="block">This converts dictionary encoded arrow vectors to a correctly typed arrow vector.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#dictionary--">dictionary()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized">VectorHolder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BaseColumnIterator.html#dictionary">dictionary</a></span> - Variable in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BaseColumnIterator.html" title="class in org.apache.iceberg.parquet">BaseColumnIterator</a></dt>
@@ -5806,6 +6107,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.WriteDistributionSpecContext.html#DISTRIBUTED--">DISTRIBUTED()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.WriteDistributionSpecContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser.WriteDistributionSpecCon [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteRequirements.html#distribution--">distribution()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteRequirements.html" title="class in org.apache.iceberg.spark">SparkWriteRequirements</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteOptions.html#DISTRIBUTION_MODE">DISTRIBUTION_MODE</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteOptions.html" title="class in org.apache.iceberg.flink">FlinkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#DISTRIBUTION_MODE">DISTRIBUTION_MODE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></dt>
@@ -5823,8 +6126,6 @@
 <dd>
 <div class="block">Configure the write <a href="org/apache/iceberg/DistributionMode.html" title="enum in org.apache.iceberg"><code>DistributionMode</code></a> that the flink sink will use.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#distributionMode--">distributionMode()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.html#doBind-org.apache.spark.sql.types.DataType-">doBind(DataType)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.html#doBind-org.apache.spark.sql.types.DataType-">doBind(DataType)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction</a></dt>
@@ -5949,6 +6250,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#dropNamespace-org.apache.iceberg.catalog.Namespace-">dropNamespace(Namespace)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#dropNamespace-org.apache.iceberg.catalog.Namespace-">dropNamespace(Namespace)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#dropNamespace-org.apache.iceberg.catalog.Namespace-">dropNamespace(Namespace)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#dropNamespace-org.apache.iceberg.catalog.Namespace-">dropNamespace(Namespace)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -6011,6 +6314,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#dropTable-org.apache.iceberg.catalog.TableIdentifier-boolean-">dropTable(TableIdentifier, boolean)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#dropTable-org.apache.iceberg.catalog.TableIdentifier-boolean-">dropTable(TableIdentifier, boolean)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#dropTable-org.apache.iceberg.catalog.TableIdentifier-boolean-">dropTable(TableIdentifier, boolean)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/Catalogs.html#dropTable-org.apache.hadoop.conf.Configuration-java.util.Properties-">dropTable(Configuration, Properties)</a></span> - Static method in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/Catalogs.html" title="class in org.apache.iceberg.mr">Catalogs</a></dt>
@@ -6047,6 +6352,12 @@
 <dd>
 <div class="block">Drop a view.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DUALSTACK_ENABLED">DUALSTACK_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Determines if S3 client will use the Dualstack Mode, default to false.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#DUALSTACK_ENABLED_DEFAULT">DUALSTACK_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#dummyHolder-int-">dummyHolder(int)</a></span> - Static method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized">VectorHolder</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/exceptions/DuplicateWAPCommitException.html" title="class in org.apache.iceberg.exceptions"><span class="typeNameLink">DuplicateWAPCommitException</span></a> - Exception in <a href="org/apache/iceberg/exceptions/package-summary.html">org.apache.iceberg.exceptions</a></dt>
@@ -6184,7 +6495,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/Types.ListType.html#elementType--">elementType()</a></span> - Method in class org.apache.iceberg.types.<a href="org/apache/iceberg/types/Types.ListType.html" title="class in org.apache.iceberg.types">Types.ListType</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html#empty--">empty()</a></span> - Static method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html" title="class in org.apache.iceberg.actions">BaseRewriteManifestsActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/catalog/Namespace.html#empty--">empty()</a></span> - Static method in class org.apache.iceberg.catalog.<a href="org/apache/iceberg/catalog/Namespace.html" title="class in org.apache.iceberg.catalog">Namespace</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/encryption/EncryptionKeyMetadata.html#EMPTY">EMPTY</a></span> - Static variable in interface org.apache.iceberg.encryption.<a href="org/apache/iceberg/encryption/EncryptionKeyMetadata.html" title="interface in org.apache.iceberg.encryption">EncryptionKeyMetadata</a></dt>
@@ -6201,6 +6514,8 @@
 <dd>
 <div class="block">A new <a href="org/apache/iceberg/rest/auth/OAuth2Util.AuthSession.html" title="class in org.apache.iceberg.rest.auth"><code>OAuth2Util.AuthSession</code></a> with empty headers.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteRequirements.html#EMPTY">EMPTY</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteRequirements.html" title="class in org.apache.iceberg.spark">SparkWriteRequirements</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/CharSequenceSet.html#empty--">empty()</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/CharSequenceSet.html" title="class in org.apache.iceberg.util">CharSequenceSet</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/ArrayUtil.html#EMPTY_BOOLEAN_ARRAY">EMPTY_BOOLEAN_ARRAY</a></span> - Static variable in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/ArrayUtil.html" title="class in org.apache.iceberg.util">ArrayUtil</a></dt>
@@ -6345,6 +6660,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MicroBatches.MicroBatch.html#endFileIndex--">endFileIndex()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MicroBatches.MicroBatch.html" title="class in org.apache.iceberg">MicroBatches.MicroBatch</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#ENDPOINT">ENDPOINT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure an alternative endpoint of the S3 service for S3FileIO to access.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#endpoint--">endpoint()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html#endpoint--">endpoint()</a></span> - Method in class org.apache.iceberg.aws.s3.signer.<a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html" title="class in org.apache.iceberg.aws.s3.signer">S3V4RestSignerClient</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadConf.html#endSnapshotId--">endSnapshotId()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadConf.html" title="class in org.apache.iceberg.flink">FlinkReadConf</a></dt>
@@ -6381,6 +6702,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/EnvironmentContext.html#ENGINE_VERSION">ENGINE_VERSION</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/EnvironmentContext.html" title="class in org.apache.iceberg">EnvironmentContext</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#enoughContent-java.util.List-">enoughContent(List&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#enoughInputFiles-java.util.List-">enoughInputFiles(List&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/hive/TezUtil.html#enrichContextWithAttemptWrapper-org.apache.hadoop.mapred.TaskAttemptContext-">enrichContextWithAttemptWrapper(TaskAttemptContext)</a></span> - Static method in class org.apache.iceberg.mr.hive.<a href="org/apache/iceberg/mr/hive/TezUtil.html" title="class in org.apache.iceberg.mr.hive">TezUtil</a></dt>
 <dd>
 <div class="block">Creates a new taskAttemptContext by replacing the taskAttemptID with a wrapped object.</div>
@@ -6390,6 +6715,8 @@
 <div class="block">If the Tez vertex id is present in config, creates a new jobContext by appending the Tez vertex
  id to the jobID.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/NoLock.html#ensureActive--">ensureActive()</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive">NoLock</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsBaseListener.html#enterAddPartitionField-org.apache.spark.sql.catalyst.parser.extensions.IcebergSqlExtensionsParser.AddPartitionFieldContext-">enterAddPartitionField(IcebergSqlExtensionsParser.AddPartitionFieldContext)</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsBaseListe [...]
 <dd>
 <div class="block">Enter a parse tree produced by the <code>addPartitionField</code>
@@ -7112,6 +7439,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/GenericRecord.html#equals-java.lang.Object-">equals(Object)</a></span> - Method in class org.apache.iceberg.data.<a href="org/apache/iceberg/data/GenericRecord.html" title="class in org.apache.iceberg.data">GenericRecord</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/data/RowDataProjection.html#equals-java.lang.Object-">equals(Object)</a></span> - Method in class org.apache.iceberg.flink.data.<a href="org/apache/iceberg/flink/data/RowDataProjection.html" title="class in org.apache.iceberg.flink.data">RowDataProjection</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/GenericBlobMetadata.html#equals-java.lang.Object-">equals(Object)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/GenericBlobMetadata.html" title="class in org.apache.iceberg">GenericBlobMetadata</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/GenericManifestFile.html#equals-java.lang.Object-">equals(Object)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/GenericManifestFile.html" title="class in org.apache.iceberg">GenericManifestFile</a></dt>
@@ -7305,6 +7634,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html#execute--">execute()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewriteManifestsSparkAction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html#execute--">execute()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewritePositionDeleteFilesSparkAction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html#execute--">execute()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html" title="class in org.apache.iceberg.spark.actions">SnapshotTableSparkAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/DeleteOrphanFiles.html#executeDeleteWith-java.util.concurrent.ExecutorService-">executeDeleteWith(ExecutorService)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/DeleteOrphanFiles.html" title="interface in org.apache.iceberg.actions">DeleteOrphanFiles</a></dt>
@@ -7369,6 +7700,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopTables.html#exists-java.lang.String-">exists(String)</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopTables.html" title="class in org.apache.iceberg.hadoop">HadoopTables</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html#exists--">exists()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/InputFile.html#exists--">exists()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io">InputFile</a></dt>
 <dd>
 <div class="block">Checks whether the file exists.</div>
@@ -8151,10 +8484,6 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/expressions/ExpressionVisitors.ExpressionVisitor.html" title="class in org.apache.iceberg.expressions"><span class="typeNameLink">ExpressionVisitors.ExpressionVisitor</span></a>&lt;<a href="org/apache/iceberg/expressions/ExpressionVisitors.ExpressionVisitor.html" title="type parameter in ExpressionVisitors.ExpressionVisitor">R</a>&gt; - Class in <a href="org/apache/iceberg/expressions/package-summary.html">org.apache.iceberg.expressions</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">ExtendedLogicalWriteInfo</span></a> - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">A class that holds logical write information not covered by LogicalWriteInfo in Spark.</div>
-</dd>
 <dt><a href="org/apache/iceberg/spark/ExtendedParser.html" title="interface in org.apache.iceberg.spark"><span class="typeNameLink">ExtendedParser</span></a> - Interface in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/ExtendedParser.RawOrderField.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">ExtendedParser.RawOrderField</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
@@ -8178,6 +8507,10 @@
 <div class="block">Takes in a map, and returns a copy filtered on the entries with keys beginning with the
  designated prefix.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ParquetUtil.html#extractTimestampInt96-java.nio.ByteBuffer-">extractTimestampInt96(ByteBuffer)</a></span> - Static method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ParquetUtil.html" title="class in org.apache.iceberg.parquet">ParquetUtil</a></dt>
+<dd>
+<div class="block">Method to read timestamp (parquet Int96) from bytebuffer.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/IcebergSource.html#extractTimeTravelTimestamp-org.apache.spark.sql.util.CaseInsensitiveStringMap-">extractTimeTravelTimestamp(CaseInsensitiveStringMap)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/IcebergSource.html" title="class in org.apache.iceberg.spark.source">IcebergSource</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/IcebergSource.html#extractTimeTravelVersion-org.apache.spark.sql.util.CaseInsensitiveStringMap-">extractTimeTravelVersion(CaseInsensitiveStringMap)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/IcebergSource.html" title="class in org.apache.iceberg.spark.source">IcebergSource</a></dt>
@@ -8196,6 +8529,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkDynamicTableFactory.html#factoryIdentifier--">factoryIdentifier()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkDynamicTableFactory.html" title="class in org.apache.iceberg.flink">FlinkDynamicTableFactory</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html#failedDataFilesCount--">failedDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.Result</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/expressions/False.html" title="class in org.apache.iceberg.expressions"><span class="typeNameLink">False</span></a> - Class in <a href="org/apache/iceberg/expressions/package-summary.html">org.apache.iceberg.expressions</a></dt>
 <dd>
 <div class="block">An <a href="org/apache/iceberg/expressions/Expression.html" title="interface in org.apache.iceberg.expressions"><code>expression</code></a> that is always false.</div>
@@ -8226,20 +8561,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotManager.html#fastForwardBranch-java.lang.String-java.lang.String-">fastForwardBranch(String, String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotManager.html" title="class in org.apache.iceberg">SnapshotManager</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html#fetchNewDataFiles-org.apache.iceberg.Table-java.lang.String-">fetchNewDataFiles(Table, String)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark">FileRewriteCoordinator</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html#fetchSetIDs-org.apache.iceberg.Table-">fetchSetIDs(Table)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark">FileRewriteCoordinator</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html#fetchSetIDs-org.apache.iceberg.Table-">fetchSetIDs(Table)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">FileScanTaskSetManager</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
-&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ScanTaskSetManager.html#fetchSetIds-org.apache.iceberg.Table-">fetchSetIds(Table)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark">ScanTaskSetManager</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html#fetchTasks-org.apache.iceberg.Table-java.lang.String-">fetchTasks(Table, String)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">FileScanTaskSetManager</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
-&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ScanTaskSetManager.html#fetchTasks-org.apache.iceberg.Table-java.lang.String-">fetchTasks(Table, String)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark">ScanTaskSetManager</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/auth/OAuth2Util.html#fetchToken-org.apache.iceberg.rest.RESTClient-java.util.Map-java.lang.String-java.lang.String-">fetchToken(RESTClient, Map&lt;String, String&gt;, String, String)</a></span> - Static method in class org.apache.iceberg.rest.auth.<a href="org/apache/iceberg/rest/auth/OAuth2Util.html" title="class in org.apache.iceberg.rest.auth">OAuth2Util</a></dt>
@@ -8414,12 +8737,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#FILE_PATH_COLUMN_ID">FILE_PATH_COLUMN_ID</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadOptions.html#FILE_SCAN_TASK_SET_ID">FILE_SCAN_TASK_SET_ID</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadOptions.html" title="class in org.apache.iceberg.spark">SparkReadOptions</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use SCAN_TASK_SET_ID instead</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DataFile.html#FILE_SIZE">FILE_SIZE</a></span> - Static variable in interface org.apache.iceberg.<a href="org/apache/iceberg/DataFile.html" title="interface in org.apache.iceberg">DataFile</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/FileAppender.html" title="interface in org.apache.iceberg.io"><span class="typeNameLink">FileAppender</span></a>&lt;<a href="org/apache/iceberg/io/FileAppender.html" title="type parameter in FileAppender">D</a>&gt; - Interface in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
@@ -8434,6 +8751,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ScanSummary.PartitionMetrics.html#fileCount--">fileCount()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ScanSummary.PartitionMetrics.html" title="class in org.apache.iceberg">ScanSummary.PartitionMetrics</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#fileExists-java.lang.String-">fileExists(String)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/GenericStatisticsFile.html#fileFooterSizeInBytes--">fileFooterSizeInBytes()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/GenericStatisticsFile.html" title="class in org.apache.iceberg">GenericStatisticsFile</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/StatisticsFile.html#fileFooterSizeInBytes--">fileFooterSizeInBytes()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/StatisticsFile.html" title="interface in org.apache.iceberg">StatisticsFile</a></dt>
@@ -8495,6 +8814,10 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">FileRewriteCoordinator</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">FileRewriter</span></a>&lt;<a href="org/apache/iceberg/actions/FileRewriter.html" title="type parameter in FileRewriter">T</a> extends <a href="org/apache/iceberg/ContentScanTask.html" title="interface in org.apache.iceberg">ContentScanTask</a>&lt;<a href="org/apache/iceberg/actions/FileRewriter.html" title="type parameter in FileRewriter">F</a>&gt;,<a hre [...]
+<dd>
+<div class="block">A class for rewriting content files.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseCombinedScanTask.html#files--">files()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseCombinedScanTask.html" title="class in org.apache.iceberg">BaseCombinedScanTask</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CombinedScanTask.html#files--">files()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/CombinedScanTask.html" title="interface in org.apache.iceberg">CombinedScanTask</a></dt>
@@ -8513,18 +8836,6 @@
 <dd>
 <div class="block">Read a <a href="org/apache/iceberg/FileScanTask.html" title="interface in org.apache.iceberg"><code>FileScanTask</code></a> into a <a href="org/apache/iceberg/io/CloseableIterator.html" title="interface in org.apache.iceberg.io"><code>CloseableIterator</code></a></div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadConf.html#fileScanTaskSetId--">fileScanTaskSetId()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark">SparkReadConf</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/SparkReadConf.html#scanTaskSetId--"><code>SparkReadConf.scanTaskSetId()</code></a> instead</span></div>
-</div>
-</dd>
-<dt><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">FileScanTaskSetManager</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use <a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark"><code>ScanTaskSetManager</code></a> instead</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/AddedRowsScanTask.html#filesCount--">filesCount()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/AddedRowsScanTask.html" title="interface in org.apache.iceberg">AddedRowsScanTask</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DeletedDataFileScanTask.html#filesCount--">filesCount()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/DeletedDataFileScanTask.html" title="interface in org.apache.iceberg">DeletedDataFileScanTask</a></dt>
@@ -8539,6 +8850,10 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ScanTaskGroup.html#filesCount--">filesCount()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ScanTaskGroup.html" title="interface in org.apache.iceberg">ScanTaskGroup</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/ContentFile.html#fileSequenceNumber--">fileSequenceNumber()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ContentFile.html" title="interface in org.apache.iceberg">ContentFile</a></dt>
+<dd>
+<div class="block">Returns the file sequence number.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/PuffinWriter.html#fileSize--">fileSize()</a></span> - Method in class org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/PuffinWriter.html" title="class in org.apache.iceberg.puffin">PuffinWriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ContentFile.html#fileSizeInBytes--">fileSizeInBytes()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ContentFile.html" title="interface in org.apache.iceberg">ContentFile</a></dt>
@@ -8595,6 +8910,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/events/ScanEvent.html#filter--">filter()</a></span> - Method in class org.apache.iceberg.events.<a href="org/apache/iceberg/events/ScanEvent.html" title="class in org.apache.iceberg.events">ScanEvent</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkSourceFilter.html#filter-org.apache.flink.table.data.RowData-">filter(RowData)</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkSourceFilter.html" title="class in org.apache.iceberg.flink">FlinkSourceFilter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/CloseableIterable.html#filter-org.apache.iceberg.io.CloseableIterable-java.util.function.Predicate-">filter(CloseableIterable&lt;E&gt;, Predicate&lt;E&gt;)</a></span> - Static method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/CloseableIterable.html" title="interface in org.apache.iceberg.io">CloseableIterable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/CloseableIterable.html#filter-org.apache.iceberg.metrics.Counter-org.apache.iceberg.io.CloseableIterable-java.util.function.Predicate-">filter(Counter, CloseableIterable&lt;E&gt;, Predicate&lt;E&gt;)</a></span> - Static method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/CloseableIterable.html" title="interface in org.apache.iceberg.io">CloseableIterable</a></dt>
@@ -8620,6 +8937,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewriteDataFilesSparkAction.html#filter-org.apache.iceberg.expressions.Expression-">filter(Expression)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewriteDataFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewriteDataFilesSparkAction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html#filter-org.apache.iceberg.expressions.Expression-">filter(Expression)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewritePositionDeleteFilesSparkAction</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/util/Filter.html" title="class in org.apache.iceberg.util"><span class="typeNameLink">Filter</span></a>&lt;<a href="org/apache/iceberg/util/Filter.html" title="type parameter in Filter">T</a>&gt; - Class in <a href="org/apache/iceberg/util/package-summary.html">org.apache.iceberg.util</a></dt>
 <dd>
 <div class="block">A Class for generic filters</div>
@@ -8636,6 +8955,18 @@
 <dd>
 <div class="block">Returns the remaining rows (the ones that are not deleted), while counting the deleted ones.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#filterFileGroups-java.util.List-">filterFileGroups(List&lt;List&lt;FileScanTask&gt;&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#filterFileGroups-java.util.List-">filterFileGroups(List&lt;List&lt;T&gt;&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html#filterFileGroups-java.util.List-">filterFileGroups(List&lt;List&lt;PositionDeletesScanTask&gt;&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedPositionDeletesRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#filterFiles-java.lang.Iterable-">filterFiles(Iterable&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#filterFiles-java.lang.Iterable-">filterFiles(Iterable&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html#filterFiles-java.lang.Iterable-">filterFiles(Iterable&lt;PositionDeletesScanTask&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedPositionDeletesRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/FilterIterator.html" title="class in org.apache.iceberg.io"><span class="typeNameLink">FilterIterator</span></a>&lt;<a href="org/apache/iceberg/io/FilterIterator.html" title="type parameter in FilterIterator">T</a>&gt; - Class in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>
 <div class="block">An Iterator that filters another Iterator.</div>
@@ -8666,6 +8997,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/oss/OSSOutputStream.html#finalize--">finalize()</a></span> - Method in class org.apache.iceberg.aliyun.oss.<a href="org/apache/iceberg/aliyun/oss/OSSOutputStream.html" title="class in org.apache.iceberg.aliyun.oss">OSSOutputStream</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIO.html#finalize--">finalize()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/io/ResolvingFileIO.html#finalize--">finalize()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/ResolvingFileIO.html" title="class in org.apache.iceberg.io">ResolvingFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mapping/NameMapping.html#find-int-">find(int)</a></span> - Method in class org.apache.iceberg.mapping.<a href="org/apache/iceberg/mapping/NameMapping.html" title="class in org.apache.iceberg.mapping">NameMapping</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mapping/NameMapping.html#find-java.lang.String...-">find(String...)</a></span> - Method in class org.apache.iceberg.mapping.<a href="org/apache/iceberg/mapping/NameMapping.html" title="class in org.apache.iceberg.mapping">NameMapping</a></dt>
@@ -8723,9 +9058,15 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/ValueWriters.html#fixed-int-">fixed(int)</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/ValueWriters.html" title="class in org.apache.iceberg.avro">ValueWriters</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#fixedLengthDecimalBatchReader--">fixedLengthDecimalBatchReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedLengthDecimalBatchReader.html#FixedLengthDecimalBatchReader--">FixedLengthDecimalBatchReader()</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedLengthDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator.Fi [...]
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html#fixedLengthDecimalDictEncodedReader--">fixedLengthDecimalDictEncodedReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedDictionaryEncodedParquetVal [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/metrics/FixedReservoirHistogram.html" title="class in org.apache.iceberg.metrics"><span class="typeNameLink">FixedReservoirHistogram</span></a> - Class in <a href="org/apache/iceberg/metrics/package-summary.html">org.apache.iceberg.metrics</a></dt>
@@ -8846,6 +9187,10 @@
 <dd>
 <div class="block">Source builder to build <code>DataStream</code>.</div>
 </dd>
+<dt><a href="org/apache/iceberg/flink/FlinkSourceFilter.html" title="class in org.apache.iceberg.flink"><span class="typeNameLink">FlinkSourceFilter</span></a> - Class in <a href="org/apache/iceberg/flink/package-summary.html">org.apache.iceberg.flink</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkSourceFilter.html#FlinkSourceFilter-org.apache.iceberg.Schema-org.apache.iceberg.expressions.Expression-boolean-">FlinkSourceFilter(Schema, Expression, boolean)</a></span> - Constructor for class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkSourceFilter.html" title="class in org.apache.iceberg.flink">FlinkSourceFilter</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/flink/source/FlinkSplitPlanner.html" title="class in org.apache.iceberg.flink.source"><span class="typeNameLink">FlinkSplitPlanner</span></a> - Class in <a href="org/apache/iceberg/flink/source/package-summary.html">org.apache.iceberg.flink.source</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/flink/FlinkTypeVisitor.html" title="class in org.apache.iceberg.flink"><span class="typeNameLink">FlinkTypeVisitor</span></a>&lt;<a href="org/apache/iceberg/flink/FlinkTypeVisitor.html" title="type parameter in FlinkTypeVisitor">T</a>&gt; - Class in <a href="org/apache/iceberg/flink/package-summary.html">org.apache.iceberg.flink</a></dt>
@@ -9182,11 +9527,11 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadataParser.html#fromJson-com.fasterxml.jackson.databind.JsonNode-">fromJson(JsonNode)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadataParser.html" title="class in org.apache.iceberg">TableMetadataParser</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3InputFile.html#fromLocation-java.lang.String-software.amazon.awssdk.services.s3.S3Client-org.apache.iceberg.aws.AwsProperties-org.apache.iceberg.metrics.MetricsContext-">fromLocation(String, S3Client, AwsProperties, MetricsContext)</a></span> - Static method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3">S3InputFile</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3InputFile.html#fromLocation-java.lang.String-software.amazon.awssdk.services.s3.S3Client-org.apache.iceberg.aws.s3.S3FileIOProperties-org.apache.iceberg.metrics.MetricsContext-">fromLocation(String, S3Client, S3FileIOProperties, MetricsContext)</a></span> - Static method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3">S3InputFile</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3InputFile.html#fromLocation-java.lang.String-long-software.amazon.awssdk.services.s3.S3Client-org.apache.iceberg.aws.AwsProperties-org.apache.iceberg.metrics.MetricsContext-">fromLocation(String, long, S3Client, AwsProperties, MetricsContext)</a></span> - Static method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3">S3InputFile</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3InputFile.html#fromLocation-java.lang.String-long-software.amazon.awssdk.services.s3.S3Client-org.apache.iceberg.aws.s3.S3FileIOProperties-org.apache.iceberg.metrics.MetricsContext-">fromLocation(String, long, S3Client, S3FileIOProperties, MetricsContext)</a></span> - Static method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3">S3InputF [...]
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3OutputFile.html#fromLocation-java.lang.String-software.amazon.awssdk.services.s3.S3Client-org.apache.iceberg.aws.AwsProperties-org.apache.iceberg.metrics.MetricsContext-">fromLocation(String, S3Client, AwsProperties, MetricsContext)</a></span> - Static method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3OutputFile.html" title="class in org.apache.iceberg.aws.s3">S3OutputFile</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3OutputFile.html#fromLocation-java.lang.String-software.amazon.awssdk.services.s3.S3Client-org.apache.iceberg.aws.s3.S3FileIOProperties-org.apache.iceberg.metrics.MetricsContext-">fromLocation(String, S3Client, S3FileIOProperties, MetricsContext)</a></span> - Static method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3OutputFile.html" title="class in org.apache.iceberg.aws.s3">S3OutputFile</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopInputFile.html#fromLocation-java.lang.CharSequence-org.apache.hadoop.conf.Configuration-">fromLocation(CharSequence, Configuration)</a></span> - Static method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopInputFile.html" title="class in org.apache.iceberg.hadoop">HadoopInputFile</a></dt>
 <dd>&nbsp;</dd>
@@ -9336,6 +9681,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MicroBatches.MicroBatchBuilder.html#generate-long-long-boolean-">generate(long, long, boolean)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MicroBatches.MicroBatchBuilder.html" title="class in org.apache.iceberg">MicroBatches.MicroBatchBuilder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/MicroBatches.MicroBatchBuilder.html#generate-long-long-long-boolean-">generate(long, long, long, boolean)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MicroBatches.MicroBatchBuilder.html" title="class in org.apache.iceberg">MicroBatches.MicroBatchBuilder</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/JsonUtil.html#generate-org.apache.iceberg.util.JsonUtil.ToJson-boolean-">generate(JsonUtil.ToJson, boolean)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/JsonUtil.html" title="class in org.apache.iceberg.util">JsonUtil</a></dt>
 <dd>
 <div class="block">Helper for writing JSON with a JsonGenerator.</div>
@@ -9542,12 +9889,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html#get--">get()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark">FileRewriteCoordinator</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html#get--">get()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">FileScanTaskSetManager</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
-&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/PositionDeletesRewriteCoordinator.html#get--">get()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/PositionDeletesRewriteCoordinator.html" title="class in org.apache.iceberg.spark">PositionDeletesRewriteCoordinator</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ScanTaskSetManager.html#get--">get()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark">ScanTaskSetManager</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html#get--">get()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark">SparkFunctionCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkStructLike.html#get-int-java.lang.Class-">get(int, Class&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkStructLike.html" title="class in org.apache.iceberg.spark">SparkStructLike</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkTableCache.html#get--">get()</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkTableCache.html" title="class in org.apache.iceberg.spark">SparkTableCache</a></dt>
@@ -9620,6 +9967,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/RowPositionColumnVector.html#getArray-int-">getArray(int)</a></span> - Method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/RowPositionColumnVector.html" title="class in org.apache.iceberg.spark.data.vectorized">RowPositionColumnVector</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/ColumnVector.html#getArrowVector--">getArrowVector()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/ColumnVector.html" title="class in org.apache.iceberg.arrow.vectorized">ColumnVector</a></dt>
+<dd>
+<div class="block">Decodes a dict-encoded vector and returns the actual arrow vector.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#getATN--">getATN()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#getATN--">getATN()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser</a></dt>
@@ -9710,8 +10061,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/hive/HiveIcebergStorageHandler.html#getConf--">getConf()</a></span> - Method in class org.apache.iceberg.mr.hive.<a href="org/apache/iceberg/mr/hive/HiveIcebergStorageHandler.html" title="class in org.apache.iceberg.mr.hive">HiveIcebergStorageHandler</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#getConf--">getConf()</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.ConstantVectorHolder.html#getConstant--">getConstant()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.ConstantVectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized">VectorHolder.ConstantVectorHolder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/common/DynConstructors.Ctor.html#getConstructedClass--">getConstructedClass()</a></span> - Method in class org.apache.iceberg.common.<a href="org/apache/iceberg/common/DynConstructors.Ctor.html" title="class in org.apache.iceberg.common">DynConstructors.Ctor</a></dt>
@@ -9734,6 +10083,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/ArrowVectorAccessor.html#getDecimal-int-int-int-">getDecimal(int, int, int)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/ArrowVectorAccessor.html" title="class in org.apache.iceberg.arrow.vectorized">ArrowVectorAccessor</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/ColumnVector.html#getDecimal-int-int-int-">getDecimal(int, int, int)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/ColumnVector.html" title="class in org.apache.iceberg.arrow.vectorized">ColumnVector</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/data/RowDataProjection.html#getDecimal-int-int-int-">getDecimal(int, int, int)</a></span> - Method in class org.apache.iceberg.flink.data.<a href="org/apache/iceberg/flink/data/RowDataProjection.html" title="class in org.apache.iceberg.flink.data">RowDataProjection</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/data/StructRowData.html#getDecimal-int-int-int-">getDecimal(int, int, int)</a></span> - Method in class org.apache.iceberg.flink.data.<a href="org/apache/iceberg/flink/data/StructRowData.html" title="class in org.apache.iceberg.flink.data">StructRowData</a></dt>
@@ -9748,6 +10099,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetricsConfig.html#getDefault--">getDefault()</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/MetricsConfig.html" title="class in org.apache.iceberg">MetricsConfig</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html#getDefaultReadLimit--">getDefaultReadLimit()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html" title="class in org.apache.iceberg.spark.source">SparkMicroBatchStream</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/DelegatingInputStream.html#getDelegate--">getDelegate()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/DelegatingInputStream.html" title="interface in org.apache.iceberg.io">DelegatingInputStream</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/DelegatingOutputStream.html#getDelegate--">getDelegate()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/DelegatingOutputStream.html" title="interface in org.apache.iceberg.io">DelegatingOutputStream</a></dt>
@@ -9793,7 +10146,9 @@
 <div class="block">Returns the <a href="org/apache/iceberg/PartitionField.html" title="class in org.apache.iceberg"><code>field</code></a> that partitions the given source field</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/ColumnVector.html#getFieldVector--">getFieldVector()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/ColumnVector.html" title="class in org.apache.iceberg.arrow.vectorized">ColumnVector</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">Returns the potentially dict-encoded <code>FieldVector</code>.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadataParser.html#getFileExtension-java.lang.String-">getFileExtension(String)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadataParser.html" title="class in org.apache.iceberg">TableMetadataParser</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadataParser.html#getFileExtension-org.apache.iceberg.TableMetadataParser.Codec-">getFileExtension(TableMetadataParser.Codec)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadataParser.html" title="class in org.apache.iceberg">TableMetadataParser</a></dt>
@@ -9900,6 +10255,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopInputFile.html#getLength--">getLength()</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopInputFile.html" title="class in org.apache.iceberg.hadoop">HadoopInputFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html#getLength--">getLength()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/InputFile.html#getLength--">getLength()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io">InputFile</a></dt>
 <dd>
 <div class="block">Returns the total length of the file, in bytes</div>
@@ -9991,13 +10348,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/pig/IcebergStorage.html#getPartitionKeys-java.lang.String-org.apache.hadoop.mapreduce.Job-">getPartitionKeys(String, Job)</a></span> - Method in class org.apache.iceberg.pig.<a href="org/apache/iceberg/pig/IcebergStorage.html" title="class in org.apache.iceberg.pig">IcebergStorage</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#getPartitions-org.apache.spark.sql.SparkSession-org.apache.hadoop.fs.Path-java.lang.String-java.util.Map-">getPartitions(SparkSession, Path, String, Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/spark/Spark3Util.html#getPartitions-org.apache.spark.sql.SparkSession-org.apache.hadoop.fs.Path-java.lang.String-java.util.Map-org.apache.iceberg.PartitionSpec-"><code>Spark3Util.getPartitions(SparkSession, Path, String, Map,
-     PartitionSpec)</code></a></span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#getPartitions-org.apache.spark.sql.SparkSession-org.apache.hadoop.fs.Path-java.lang.String-java.util.Map-org.apache.iceberg.PartitionSpec-">getPartitions(SparkSession, Path, String, Map&lt;String, String&gt;, PartitionSpec)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
 <dd>
 <div class="block">Use Spark to list all partitions in the table.</div>
@@ -10358,11 +10708,18 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/IcebergBuild.html#gitTags--">gitTags()</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/IcebergBuild.html" title="class in org.apache.iceberg">IcebergBuild</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html#globalIndex--">globalIndex()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesFileGroupInfo</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html#globalIndex--">globalIndex()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupInfo</a></dt>
 <dd>
 <div class="block">returns which file group this is out of the total set of file groups for this rewrite</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html#globalIndex--">globalIndex()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupInfo</a></dt>
+<dd>
+<div class="block">Returns which position delete file group this is out of the total set of file groups for this
+ rewrite</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AssumeRoleAwsClientFactory.html#glue--">glue()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AssumeRoleAwsClientFactory.html" title="class in org.apache.iceberg.aws">AssumeRoleAwsClientFactory</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientFactory.html#glue--">glue()</a></span> - Method in interface org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws">AwsClientFactory</a></dt>
@@ -10431,12 +10788,6 @@
 <dd>
 <div class="block">Returns a grouping key for this task group.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/Partitioning.html#groupingKeyType-java.util.Collection-">groupingKeyType(Collection&lt;PartitionSpec&gt;)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/Partitioning.html" title="class in org.apache.iceberg">Partitioning</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/Partitioning.html#groupingKeyType-org.apache.iceberg.Schema-java.util.Collection-"><code>Partitioning.groupingKeyType(Schema, Collection)</code></a> instead; will be removed in 1.3.0</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Partitioning.html#groupingKeyType-org.apache.iceberg.Schema-java.util.Collection-">groupingKeyType(Schema, Collection&lt;PartitionSpec&gt;)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/Partitioning.html" title="class in org.apache.iceberg">Partitioning</a></dt>
 <dd>
 <div class="block">Builds a grouping key type considering the provided schema and specs.</div>
@@ -10536,24 +10887,20 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopTables.html#HadoopTables-org.apache.hadoop.conf.Configuration-">HadoopTables(Configuration)</a></span> - Constructor for class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopTables.html" title="class in org.apache.iceberg.hadoop">HadoopTables</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadOptions.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadOptions.html" title="class in org.apache.iceberg.spark">SparkReadOptions</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE_DEFAULT">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/ExpressionVisitors.BoundExpressionVisitor.html#handleNonReference-org.apache.iceberg.expressions.Bound-">handleNonReference(Bound&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/ExpressionVisitors.BoundExpressionVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.BoundExpressionVisitor</a></dt>
 <dd>
-<div class="block">Handle a non-reference value in this visitor.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadConf.html#handleTimestampWithoutZone--">handleTimestampWithoutZone()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark">SparkReadConf</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#HANDLE_TIMESTAMP_WITHOUT_TIMEZONE">HANDLE_TIMESTAMP_WITHOUT_TIMEZONE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
 <dd>
-<div class="block">Enables reading a timestamp without time zone as a timestamp with time zone.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#handleTimestampWithoutZone--">handleTimestampWithoutZone()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/ExpressionVisitors.BoundExpressionVisitor.html#handleNonReference-org.apache.iceberg.expressions.Bound-">handleNonReference(Bound&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/ExpressionVisitors.BoundExpressionVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.BoundExpressionVisitor</a></dt>
 <dd>
-<div class="block">Enables writing a timestamp with time zone as a timestamp without time zone.</div>
+<div class="block">Handle a non-reference value in this visitor.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManifestFile.html#hasAddedFiles--">hasAddedFiles()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ManifestFile.html" title="interface in org.apache.iceberg">ManifestFile</a></dt>
 <dd>
@@ -10622,6 +10969,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/GenericRecord.html#hashCode--">hashCode()</a></span> - Method in class org.apache.iceberg.data.<a href="org/apache/iceberg/data/GenericRecord.html" title="class in org.apache.iceberg.data">GenericRecord</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/data/RowDataProjection.html#hashCode--">hashCode()</a></span> - Method in class org.apache.iceberg.flink.data.<a href="org/apache/iceberg/flink/data/RowDataProjection.html" title="class in org.apache.iceberg.flink.data">RowDataProjection</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/GenericBlobMetadata.html#hashCode--">hashCode()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/GenericBlobMetadata.html" title="class in org.apache.iceberg">GenericBlobMetadata</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/GenericManifestFile.html#hashCode--">hashCode()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/GenericManifestFile.html" title="class in org.apache.iceberg">GenericManifestFile</a></dt>
@@ -10716,7 +11065,7 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BasePageIterator.html#hasNext--">hasNext()</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BasePageIterator.html" title="class in org.apache.iceberg.parquet">BasePageIterator</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#hasNext--">hasNext()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ComputeUpdateIterator.html#hasNext--">hasNext()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ComputeUpdateIterator.html" title="class in org.apache.iceberg.spark">ComputeUpdateIterator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ParquetUtil.html#hasNoBloomFilterPages-org.apache.parquet.hadoop.metadata.ColumnChunkMetaData-">hasNoBloomFilterPages(ColumnChunkMetaData)</a></span> - Static method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ParquetUtil.html" title="class in org.apache.iceberg.parquet">ParquetUtil</a></dt>
 <dd>&nbsp;</dd>
@@ -10738,10 +11087,6 @@
 <dd>
 <div class="block">Used to expose a table's TableOperations.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#hasTimestampWithoutZone-org.apache.iceberg.Schema-">hasTimestampWithoutZone(Schema)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
-<dd>
-<div class="block">Responsible for checking if the table schema has a timestamp without timezone column</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/CountNonNull.html#hasValue-org.apache.iceberg.DataFile-">hasValue(DataFile)</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/CountNonNull.html" title="class in org.apache.iceberg.expressions">CountNonNull</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/CountStar.html#hasValue-org.apache.iceberg.DataFile-">hasValue(DataFile)</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/CountStar.html" title="class in org.apache.iceberg.expressions">CountStar</a></dt>
@@ -10844,6 +11189,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkCatalogFactory.html#HIVE_CONF_DIR">HIVE_CONF_DIR</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkCatalogFactory.html" title="class in org.apache.iceberg.flink">FlinkCatalogFactory</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#HIVE_LOCK_ENABLED">HIVE_LOCK_ENABLED</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#HIVE_LOCK_ENABLED_DEFAULT">HIVE_LOCK_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive"><span class="typeNameLink">HiveCatalog</span></a> - Class in <a href="org/apache/iceberg/hive/package-summary.html">org.apache.iceberg.hive</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#HiveCatalog--">HiveCatalog()</a></span> - Constructor for class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
@@ -10907,12 +11256,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#HMS_TABLE_OWNER">HMS_TABLE_OWNER</a></span> - Static variable in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#HMS_TABLE_OWNER">HMS_TABLE_OWNER</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0, use the HMS_TABLE_OWNER constant from HiveCatalog</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/Expressions.html#hour-java.lang.String-">hour(String)</a></span> - Static method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/Expressions.html" title="class in org.apache.iceberg.expressions">Expressions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/PartitionSpec.Builder.html#hour-java.lang.String-java.lang.String-">hour(String, String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/PartitionSpec.Builder.html" title="class in org.apache.iceberg">PartitionSpec.Builder</a></dt>
@@ -10953,66 +11296,114 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.html#HoursFunction--">HoursFunction()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">HoursFunction.TimestampNtzToHoursFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">HoursFunction.TimestampToHoursFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS">HTTP_CLIENT_APACHE_CONNECTION_ACQUISITION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the connection acquisition timeout in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_MAX_IDLE_TIME_MS">HTTP_CLIENT_APACHE_CONNECTION_MAX_IDLE_TIME_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the connection max idle time in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_TIME_TO_LIVE_MS">HTTP_CLIENT_APACHE_CONNECTION_TIME_TO_LIVE_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the connection time to live in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_CONNECTION_TIMEOUT_MS">HTTP_CLIENT_APACHE_CONNECTION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the connection timeout in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_EXPECT_CONTINUE_ENABLED">HTTP_CLIENT_APACHE_EXPECT_CONTINUE_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure whether to enable the expect continue setting for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_MAX_CONNECTIONS">HTTP_CLIENT_APACHE_MAX_CONNECTIONS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the max connections number for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_SOCKET_TIMEOUT_MS">HTTP_CLIENT_APACHE_SOCKET_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the socket timeout in milliseconds for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_TCP_KEEP_ALIVE_ENABLED">HTTP_CLIENT_APACHE_TCP_KEEP_ALIVE_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure whether to enable the tcp keep alive setting for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED">HTTP_CLIENT_APACHE_USE_IDLE_CONNECTION_REAPER_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure whether to use idle connection reaper for <code>ApacheHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE">HTTP_CLIENT_TYPE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">The type of <code>SdkHttpClient</code> implementation used by <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a> If set, all AWS clients will use this specified HTTP client.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_APACHE">HTTP_CLIENT_TYPE_APACHE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">If this is set under <a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE"><code>AwsProperties.HTTP_CLIENT_TYPE</code></a>, <code>ApacheHttpClient</code> will be used as the HTTP Client in <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a></div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_DEFAULT">HTTP_CLIENT_TYPE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE_URLCONNECTION">HTTP_CLIENT_TYPE_URLCONNECTION</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">If this is set under <a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_TYPE"><code>AwsProperties.HTTP_CLIENT_TYPE</code></a>, <code>UrlConnectionHttpClient</code> will be used as the HTTP
- Client in <a href="org/apache/iceberg/aws/AwsClientFactory.html" title="interface in org.apache.iceberg.aws"><code>AwsClientFactory</code></a></div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_URLCONNECTION_CONNECTION_TIMEOUT_MS">HTTP_CLIENT_URLCONNECTION_CONNECTION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the connection timeout in milliseconds for <code>UrlConnectionHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#HTTP_CLIENT_URLCONNECTION_SOCKET_TIMEOUT_MS">HTTP_CLIENT_URLCONNECTION_SOCKET_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure the socket timeout in milliseconds for <code>UrlConnectionHttpClient.Builder</code>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><code>HttpClientProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><a href="org/apache/iceberg/rest/HTTPClient.html" title="class in org.apache.iceberg.rest"><span class="typeNameLink">HTTPClient</span></a> - Class in <a href="org/apache/iceberg/rest/package-summary.html">org.apache.iceberg.rest</a></dt>
 <dd>
@@ -11022,6 +11413,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#httpClientProperties--">httpClientProperties()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws"><span class="typeNameLink">HttpClientProperties</span></a> - Class in <a href="org/apache/iceberg/aws/package-summary.html">org.apache.iceberg.aws</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#HttpClientProperties--">HttpClientProperties()</a></span> - Constructor for class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#HttpClientProperties-java.util.Map-">HttpClientProperties(Map&lt;String, String&gt;)</a></span> - Constructor for class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>&nbsp;</dd>
 </dl>
 <a name="I:I">
 <!--   -->
@@ -11139,6 +11536,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/enumerator/IcebergEnumeratorStateSerializer.html#IcebergEnumeratorStateSerializer--">IcebergEnumeratorStateSerializer()</a></span> - Constructor for class org.apache.iceberg.flink.source.enumerator.<a href="org/apache/iceberg/flink/source/enumerator/IcebergEnumeratorStateSerializer.html" title="class in org.apache.iceberg.flink.source.enumerator">IcebergEnumeratorStateSerializer</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#icebergField--">icebergField()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized">VectorHolder</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/mr/hive/serde/objectinspector/IcebergFixedObjectInspector.html" title="class in org.apache.iceberg.mr.hive.serde.objectinspector"><span class="typeNameLink">IcebergFixedObjectInspector</span></a> - Class in <a href="org/apache/iceberg/mr/hive/serde/objectinspector/package-summary.html">org.apache.iceberg.mr.hive.serde.objectinspector</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/data/IcebergGenerics.html" title="class in org.apache.iceberg.data"><span class="typeNameLink">IcebergGenerics</span></a> - Class in <a href="org/apache/iceberg/data/package-summary.html">org.apache.iceberg.data</a></dt>
@@ -11569,7 +11968,9 @@
 <div class="block">Checks for a method implementation.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseSnapshotTableActionResult.html#importedDataFilesCount--">importedDataFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseSnapshotTableActionResult.html" title="class in org.apache.iceberg.actions">BaseSnapshotTableActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SnapshotTable.Result.html#importedDataFilesCount--">importedDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SnapshotTable.Result.html" title="interface in org.apache.iceberg.actions">SnapshotTable.Result</a></dt>
 <dd>
 <div class="block">Returns the number of imported data files.</div>
@@ -11746,11 +12147,29 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/IcebergSource.html#inferSchema-org.apache.spark.sql.util.CaseInsensitiveStringMap-">inferSchema(CaseInsensitiveStringMap)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/IcebergSource.html" title="class in org.apache.iceberg.spark.source">IcebergSource</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#info--">info()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html#info--">info()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupFailureResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html#info--">info()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupRewriteResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#info--">info()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html#info--">info()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupRewriteResult</a></dt>
+<dd>
+<div class="block">Description of this position delete file group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#info--">info()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/FileRewriter.html#init-java.util.Map-">init(Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions">FileRewriter</a></dt>
+<dd>
+<div class="block">Initializes this rewriter using provided options.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#init-java.util.Map-">init(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#init-java.util.Map-">init(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedPageIterator.html#initDataReader-org.apache.parquet.column.Encoding-org.apache.parquet.bytes.ByteBufferInputStream-int-">initDataReader(Encoding, ByteBufferInputStream, int)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedPageIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">Vector [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BasePageIterator.html#initDataReader-org.apache.parquet.column.Encoding-org.apache.parquet.bytes.ByteBufferInputStream-int-">initDataReader(Encoding, ByteBufferInputStream, int)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BasePageIterator.html" title="class in org.apache.iceberg.parquet">BasePageIterator</a></dt>
@@ -11795,6 +12214,15 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIO.html#initialize-java.util.Map-">initialize(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html#initialize-java.util.Map-">initialize(Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html" title="interface in org.apache.iceberg.aws.s3">S3FileIOAwsClientFactory</a></dt>
+<dd>
+<div class="block">Initialize AWS client factory from catalog properties.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/S3FileIOAwsClientFactories.html#initialize-java.util.Map-">initialize(Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/S3FileIOAwsClientFactories.html" title="class in org.apache.iceberg.aws">S3FileIOAwsClientFactories</a></dt>
+<dd>
+<div class="block">Attempts to load an AWS client factory class for S3 file IO defined in the catalog property
+ <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#CLIENT_FACTORY"><code>S3FileIOProperties.CLIENT_FACTORY</code></a>.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/catalog/BaseSessionCatalog.html#initialize-java.lang.String-java.util.Map-">initialize(String, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.catalog.<a href="org/apache/iceberg/catalog/BaseSessionCatalog.html" title="class in org.apache.iceberg.catalog">BaseSessionCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/catalog/Catalog.html#initialize-java.lang.String-java.util.Map-">initialize(String, Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.catalog.<a href="org/apache/iceberg/catalog/Catalog.html" title="interface in org.apache.iceberg.catalog">Catalog</a></dt>
@@ -11838,6 +12266,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#initialize-java.lang.String-java.util.Map-">initialize(String, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#initialize-java.lang.String-java.util.Map-">initialize(String, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/FileIO.html#initialize-java.util.Map-">initialize(Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/FileIO.html" title="interface in org.apache.iceberg.io">FileIO</a></dt>
 <dd>
 <div class="block">Initialize File IO from catalog properties.</div>
@@ -11878,6 +12308,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkCatalog.html#initialize-java.lang.String-org.apache.spark.sql.util.CaseInsensitiveStringMap-">initialize(String, CaseInsensitiveStringMap)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkCatalog.html" title="class in org.apache.iceberg.spark">SparkCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html#initialize-java.lang.String-org.apache.spark.sql.util.CaseInsensitiveStringMap-">initialize(String, CaseInsensitiveStringMap)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark">SparkFunctionCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#initialize-java.lang.String-org.apache.spark.sql.util.CaseInsensitiveStringMap-">initialize(String, CaseInsensitiveStringMap)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/LockManagers.BaseLockManager.html#initialize-java.util.Map-">initialize(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/LockManagers.BaseLockManager.html" title="class in org.apache.iceberg.util">LockManagers.BaseLockManager</a></dt>
@@ -11892,6 +12324,35 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.html#initModule--">initModule()</a></span> - Static method in class org.apache.iceberg.aws.s3.signer.<a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.html" title="class in org.apache.iceberg.aws.s3.signer">S3ObjectMapper</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory"><span class="typeNameLink">InMemoryCatalog</span></a> - Class in <a href="org/apache/iceberg/inmemory/package-summary.html">org.apache.iceberg.inmemory</a></dt>
+<dd>
+<div class="block">Catalog implementation that uses in-memory data-structures to store the namespaces and tables.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#InMemoryCatalog--">InMemoryCatalog()</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory"><span class="typeNameLink">InMemoryFileIO</span></a> - Class in <a href="org/apache/iceberg/inmemory/package-summary.html">org.apache.iceberg.inmemory</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#InMemoryFileIO--">InMemoryFileIO()</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory"><span class="typeNameLink">InMemoryInputFile</span></a> - Class in <a href="org/apache/iceberg/inmemory/package-summary.html">org.apache.iceberg.inmemory</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html#InMemoryInputFile-byte:A-">InMemoryInputFile(byte[])</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html#InMemoryInputFile-java.lang.String-byte:A-">InMemoryInputFile(String, byte[])</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory"><span class="typeNameLink">InMemoryOutputFile</span></a> - Class in <a href="org/apache/iceberg/inmemory/package-summary.html">org.apache.iceberg.inmemory</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#InMemoryOutputFile--">InMemoryOutputFile()</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#InMemoryOutputFile-java.lang.String-">InMemoryOutputFile(String)</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#InMemoryOutputFile-java.lang.String-org.apache.iceberg.inmemory.InMemoryFileIO-">InMemoryOutputFile(String, InMemoryFileIO)</a></span> - Constructor for class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>
+<div class="block">If the optional parentFileIO is provided, file-existence behaves similarly to S3FileIO;
+ existence checks are performed up-front if creating without overwrite, but files only exist in
+ the parentFileIO if close() has been called on the associated output streams (or pre-existing
+ files are populated into the parentFileIO through other means).</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/mapred/AbstractMapredIcebergRecordReader.html#innerReader">innerReader</a></span> - Variable in class org.apache.iceberg.mr.mapred.<a href="org/apache/iceberg/mr/mapred/AbstractMapredIcebergRecordReader.html" title="class in org.apache.iceberg.mr.mapred">AbstractMapredIcebergRecordReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/FindFiles.Builder.html#inPartition-org.apache.iceberg.PartitionSpec-org.apache.iceberg.StructLike-">inPartition(PartitionSpec, StructLike)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/FindFiles.Builder.html" title="class in org.apache.iceberg">FindFiles.Builder</a></dt>
@@ -11919,13 +12380,17 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/encryption/InputFilesDecryptor.html#InputFilesDecryptor-org.apache.iceberg.CombinedScanTask-org.apache.iceberg.io.FileIO-org.apache.iceberg.encryption.EncryptionManager-">InputFilesDecryptor(CombinedScanTask, FileIO, EncryptionManager)</a></span> - Constructor for class org.apache.iceberg.encryption.<a href="org/apache/iceberg/encryption/InputFilesDecryptor.html" title="class in org.apache.iceberg.encryption">InputFilesDecrypto [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#inputFileSize-java.util.List-">inputFileSize(List&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr"><span class="typeNameLink">InputFormatConfig</span></a> - Class in <a href="org/apache/iceberg/mr/package-summary.html">org.apache.iceberg.mr</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/mr/InputFormatConfig.ConfigBuilder.html" title="class in org.apache.iceberg.mr"><span class="typeNameLink">InputFormatConfig.ConfigBuilder</span></a> - Class in <a href="org/apache/iceberg/mr/package-summary.html">org.apache.iceberg.mr</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/mr/InputFormatConfig.InMemoryDataModel.html" title="enum in org.apache.iceberg.mr"><span class="typeNameLink">InputFormatConfig.InMemoryDataModel</span></a> - Enum in <a href="org/apache/iceberg/mr/package-summary.html">org.apache.iceberg.mr</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#inputSize-java.util.List-">inputSize(List&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.BucketBinary.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.BucketBinary.html" title="class in org.apache.iceberg.spark.functions">BucketFunction.BucketBinary</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.BucketDecimal.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.BucketDecimal.html" title="class in org.apache.iceberg.spark.functions">BucketFunction.BucketDecimal</a></dt>
@@ -11938,12 +12403,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.DateToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampNtzToDaysFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.DateToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampNtzToMonthsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html" title="class in org.apache.iceberg.spark.functions">TruncateFunction.TruncateBigInt</a></dt>
@@ -11962,6 +12433,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.DateToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampNtzToYearsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html#inputTypes--">inputTypes()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/BasePositionDeltaWriter.html#insert-T-org.apache.iceberg.PartitionSpec-org.apache.iceberg.StructLike-">insert(T, PartitionSpec, StructLike)</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/BasePositionDeltaWriter.html" title="class in org.apache.iceberg.io">BasePositionDeltaWriter</a></dt>
@@ -11974,10 +12447,8 @@
 <dd>
 <div class="block">Inserts a row to the provided spec/partition.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html#insert-T-">insert(T)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWriter</a></dt>
-<dd>
-<div class="block">Passes a row to insert.</div>
-</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#INSERT">INSERT</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/FindFiles.Builder.html#inSnapshot-long-">inSnapshot(long)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/FindFiles.Builder.html" title="class in org.apache.iceberg">FindFiles.Builder</a></dt>
 <dd>
 <div class="block">Base results on the given snapshot.</div>
@@ -11991,9 +12462,15 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ParquetValueReaders.IntAsLongReader.html#IntAsLongReader-org.apache.parquet.column.ColumnDescriptor-">IntAsLongReader(ColumnDescriptor)</a></span> - Constructor for class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ParquetValueReaders.IntAsLongReader.html" title="class in org.apache.iceberg.parquet">ParquetValueReaders.IntAsLongReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#intBackedDecimalBatchReader--">intBackedDecimalBatchReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntBackedDecimalBatchReader.html#IntBackedDecimalBatchReader--">IntBackedDecimalBatchReader()</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntBackedDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator.IntBackedD [...]
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html#intBackedDecimalDictEncodedReader--">intBackedDecimalDictEncodedReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedDictionaryEncodedParquetValuesR [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#INTEGER_VALUE">INTEGER_VALUE</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
@@ -12100,12 +12577,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html#invoke-int-">invoke(int)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.DateToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampNtzToDaysFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html#invoke-int-">invoke(int)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.DateToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampNtzToMonthsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html#invoke-int-long-">invoke(int, long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html" title="class in org.apache.iceberg.spark.functions">TruncateFunction.TruncateBigInt</a></dt>
@@ -12124,6 +12607,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html#invoke-int-">invoke(int)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.DateToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampNtzToYearsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html#invoke-long-">invoke(long)</a></span> - Static method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/common/DynConstructors.Ctor.html#invokeChecked-java.lang.Object-java.lang.Object...-">invokeChecked(Object, Object...)</a></span> - Method in class org.apache.iceberg.common.<a href="org/apache/iceberg/common/DynConstructors.Ctor.html" title="class in org.apache.iceberg.common">DynConstructors.Ctor</a></dt>
@@ -12205,6 +12690,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#IS_DELETED">IS_DELETED</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isAccelerationEnabled--">isAccelerationEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/common/DynFields.UnboundField.html#isAlwaysNull--">isAlwaysNull()</a></span> - Method in class org.apache.iceberg.common.<a href="org/apache/iceberg/common/DynFields.UnboundField.html" title="class in org.apache.iceberg.common">DynFields.UnboundField</a></dt>
 <dd>
 <div class="block">Returns whether the field is always null.</div>
@@ -12245,6 +12732,12 @@
 <dd>
 <div class="block">Determines if the given character value is a unicode high-surrogate code unit.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isChecksumEnabled--">isChecksumEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/ClientPoolImpl.html#isClosed--">isClosed()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ClientPoolImpl.html" title="class in org.apache.iceberg">ClientPoolImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#isClosed--">isClosed()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ClientPoolImpl.html#isConnectionException-java.lang.Exception-">isConnectionException(Exception)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ClientPoolImpl.html" title="class in org.apache.iceberg">ClientPoolImpl</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveClientPool.html#isConnectionException-java.lang.Exception-">isConnectionException(Exception)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveClientPool.html" title="class in org.apache.iceberg.hive">HiveClientPool</a></dt>
@@ -12259,10 +12752,16 @@
 <dd>
 <div class="block">Checks whether a row at the position is deleted.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isDeleteEnabled--">isDeleteEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManifestReader.html#isDeleteManifestReader--">isDeleteManifestReader()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ManifestReader.html" title="class in org.apache.iceberg">ManifestReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#isDictionaryEncoded--">isDictionaryEncoded()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized">VectorHolder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#isDifferentValue-org.apache.spark.sql.Row-org.apache.spark.sql.Row-int-">isDifferentValue(Row, Row, int)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isDualStackEnabled--">isDualStackEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#isDummy--">isDummy()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized">VectorHolder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/Types.ListType.html#isElementOptional--">isElementOptional()</a></span> - Method in class org.apache.iceberg.types.<a href="org/apache/iceberg/types/Types.ListType.html" title="class in org.apache.iceberg.types">Types.ListType</a></dt>
@@ -12435,20 +12934,36 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/PartitionSpec.html#isPartitioned--">isPartitioned()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/PartitionSpec.html" title="class in org.apache.iceberg">PartitionSpec</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isPathStyleAccess--">isPathStyleAccess()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/util/FlinkCompatibilityUtil.html#isPhysicalColumn-org.apache.flink.table.api.TableColumn-">isPhysicalColumn(TableColumn)</a></span> - Static method in class org.apache.iceberg.flink.util.<a href="org/apache/iceberg/flink/util/FlinkCompatibilityUtil.html" title="class in org.apache.iceberg.flink.util">FlinkCompatibilityUtil</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isPreloadClientEnabled--">isPreloadClientEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/Type.html#isPrimitiveType--">isPrimitiveType()</a></span> - Method in interface org.apache.iceberg.types.<a href="org/apache/iceberg/types/Type.html" title="interface in org.apache.iceberg.types">Type</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/Type.PrimitiveType.html#isPrimitiveType--">isPrimitiveType()</a></span> - Method in class org.apache.iceberg.types.<a href="org/apache/iceberg/types/Type.PrimitiveType.html" title="class in org.apache.iceberg.types">Type.PrimitiveType</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/TypeUtil.html#isPromotionAllowed-org.apache.iceberg.types.Type-org.apache.iceberg.types.Type.PrimitiveType-">isPromotionAllowed(Type, Type.PrimitiveType)</a></span> - Static method in class org.apache.iceberg.types.<a href="org/apache/iceberg/types/TypeUtil.html" title="class in org.apache.iceberg.types">TypeUtil</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isRemoteSigningEnabled--">isRemoteSigningEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/Types.NestedField.html#isRequired--">isRequired()</a></span> - Method in class org.apache.iceberg.types.<a href="org/apache/iceberg/types/Types.NestedField.html" title="class in org.apache.iceberg.types">Types.NestedField</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#isS3ChecksumEnabled--">isS3ChecksumEnabled()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#isS3DeleteEnabled--">isS3DeleteEnabled()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/BoundPredicate.html#isSetPredicate--">isSetPredicate()</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/BoundPredicate.html" title="class in org.apache.iceberg.expressions">BoundPredicate</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/BoundSetPredicate.html#isSetPredicate--">isSetPredicate()</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/BoundSetPredicate.html" title="class in org.apache.iceberg.expressions">BoundSetPredicate</a></dt>
@@ -12497,6 +13012,8 @@
 <dd>
 <div class="block">Returns true if the sort order is unsorted</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isUseArnRegionEnabled--">isUseArnRegionEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/DateTimeUtil.html#isUTCTimestamptz-java.lang.String-">isUTCTimestamptz(String)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/DateTimeUtil.html" title="class in org.apache.iceberg.util">DateTimeUtil</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#isValidDecimal--">isValidDecimal()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
@@ -12521,6 +13038,8 @@
 <dd>
 <div class="block">Return whether this transform is the void transform.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#isWriteNamespaceTagEnabled--">isWriteNamespaceTagEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SetAccumulator.html#isZero--">isZero()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SetAccumulator.html" title="class in org.apache.iceberg.spark.actions">SetAccumulator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorizedTableScanIterable.html#iterator--">iterator()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorizedTableScanIterable.html" title="class in org.apache.iceberg.arrow.vectorized">VectorizedTableScanIterable</a></dt>
@@ -12725,6 +13244,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html#latestOffset--">latestOffset()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html" title="class in org.apache.iceberg.spark.source">SparkMicroBatchStream</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html#latestOffset-org.apache.spark.sql.connector.read.streaming.Offset-org.apache.spark.sql.connector.read.streaming.ReadLimit-">latestOffset(Offset, ReadLimit)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkMicroBatchStream.html" title="class in org.apache.iceberg.spark.source">SparkMicroBatchStream</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/SnapshotUtil.html#latestSnapshot-org.apache.iceberg.Table-java.lang.String-">latestSnapshot(Table, String)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/SnapshotUtil.html" title="class in org.apache.iceberg.util">SnapshotUtil</a></dt>
 <dd>
 <div class="block">Fetch the snapshot at the head of the given branch in the given table.</div>
@@ -12911,6 +13432,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#listNamespaces-org.apache.iceberg.catalog.Namespace-">listNamespaces(Namespace)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#listNamespaces--">listNamespaces()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#listNamespaces-org.apache.iceberg.catalog.Namespace-">listNamespaces(Namespace)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#listNamespaces--">listNamespaces()</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#listNamespaces-org.apache.iceberg.catalog.Namespace-">listNamespaces(Namespace)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
@@ -12949,20 +13474,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/TableMigrationUtil.html#listPartition-java.util.Map-java.lang.String-java.lang.String-org.apache.iceberg.PartitionSpec-org.apache.hadoop.conf.Configuration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-int-">listPartition(Map&lt;String, String&gt;, String, String, PartitionSpec, Configuration, MetricsConfig, NameMapping, int)</a></span> - Static method in class org.apache.iceberg.data.<a href="org [...]
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkTableUtil.html#listPartition-org.apache.iceberg.spark.SparkTableUtil.SparkPartition-org.apache.iceberg.PartitionSpec-org.apache.iceberg.hadoop.SerializableConfiguration-org.apache.iceberg.MetricsConfig-">listPartition(SparkTableUtil.SparkPartition, PartitionSpec, SerializableConfiguration, MetricsConfig)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkTableUtil.html [...]
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/data/TableMigrationUtil.html#listPartition-java.util.Map-java.lang.String-java.lang.String-org.apache.iceberg.PartitionSpec-org.apache.hadoop.conf.Configuration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-"><code>TableMigrationUtil.listPartition(Map, String, String, PartitionSpec,
-     Configuration, MetricsConfig, NameMapping)</code></a></span></div>
-</div>
-</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkTableUtil.html#listPartition-org.apache.iceberg.spark.SparkTableUtil.SparkPartition-org.apache.iceberg.PartitionSpec-org.apache.iceberg.hadoop.SerializableConfiguration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-">listPartition(SparkTableUtil.SparkPartition, PartitionSpec, SerializableConfiguration, MetricsConfig, NameMapping)</a></span> - Static method in class org.apache.iceberg.spark.< [...]
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">use <a href="org/apache/iceberg/data/TableMigrationUtil.html#listPartition-java.util.Map-java.lang.String-java.lang.String-org.apache.iceberg.PartitionSpec-org.apache.hadoop.conf.Configuration-org.apache.iceberg.MetricsConfig-org.apache.iceberg.mapping.NameMapping-"><code>TableMigrationUtil.listPartition(Map, String, String, PartitionSpec,
-     Configuration, MetricsConfig, NameMapping)</code></a></span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkCatalog.html#listPartitions-org.apache.flink.table.catalog.ObjectPath-">listPartitions(ObjectPath)</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkCatalog.html" title="class in org.apache.iceberg.flink">FlinkCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkCatalog.html#listPartitions-org.apache.flink.table.catalog.ObjectPath-org.apache.flink.table.catalog.CatalogPartitionSpec-">listPartitions(ObjectPath, CatalogPartitionSpec)</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkCatalog.html" title="class in org.apache.iceberg.flink">FlinkCatalog</a></dt>
@@ -13005,6 +13516,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#listTables-org.apache.iceberg.catalog.Namespace-">listTables(Namespace)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#listTables-org.apache.iceberg.catalog.Namespace-">listTables(Namespace)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#listTables-org.apache.iceberg.catalog.Namespace-">listTables(Namespace)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#listTables-org.apache.iceberg.catalog.Namespace-">listTables(Namespace)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -13079,12 +13592,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.RESTCatalogLoader.html#loadCatalog--">loadCatalog()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.RESTCatalogLoader.html" title="class in org.apache.iceberg.flink">CatalogLoader.RESTCatalogLoader</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkTableUtil.html#loadCatalogMetadataTable-org.apache.spark.sql.SparkSession-org.apache.iceberg.Table-org.apache.iceberg.MetadataTableType-">loadCatalogMetadataTable(SparkSession, Table, MetadataTableType)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkTableUtil.html" title="class in org.apache.iceberg.spark">SparkTableUtil</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">since 0.14.0, will be removed in 0.15.0; use <a href="org/apache/iceberg/spark/SparkTableUtil.html#loadMetadataTable-org.apache.spark.sql.SparkSession-org.apache.iceberg.Table-org.apache.iceberg.MetadataTableType-"><code>SparkTableUtil.loadMetadataTable(SparkSession, Table, MetadataTableType)</code></a>.</span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/common/DynClasses.Builder.html#loader-java.lang.ClassLoader-">loader(ClassLoader)</a></span> - Method in class org.apache.iceberg.common.<a href="org/apache/iceberg/common/DynClasses.Builder.html" title="class in org.apache.iceberg.common">DynClasses.Builder</a></dt>
 <dd>
 <div class="block">Set the <code>ClassLoader</code> used to lookup classes by name.</div>
@@ -13105,6 +13612,8 @@
 <dd>
 <div class="block">Load a custom <a href="org/apache/iceberg/io/FileIO.html" title="interface in org.apache.iceberg.io"><code>FileIO</code></a> implementation.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#loadFunction-org.apache.spark.sql.connector.catalog.Identifier-">loadFunction(Identifier)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#loadIcebergCatalog-org.apache.spark.sql.SparkSession-java.lang.String-">loadIcebergCatalog(SparkSession, String)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
 <dd>
 <div class="block">Returns the underlying Iceberg Catalog object represented by a Spark Catalog</div>
@@ -13145,6 +13654,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#loadNamespaceMetadata-org.apache.iceberg.catalog.Namespace-">loadNamespaceMetadata(Namespace)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#loadNamespaceMetadata-org.apache.iceberg.catalog.Namespace-">loadNamespaceMetadata(Namespace)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#loadNamespaceMetadata-org.apache.iceberg.catalog.Namespace-">loadNamespaceMetadata(Namespace)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#loadNamespaceMetadata-org.apache.iceberg.catalog.Namespace-">loadNamespaceMetadata(Namespace)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -13272,6 +13783,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopOutputFile.html#location--">location()</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopOutputFile.html" title="class in org.apache.iceberg.hadoop">HadoopOutputFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html#location--">location()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#location--">location()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/FileInfo.html#location--">location()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/FileInfo.html" title="class in org.apache.iceberg.io">FileInfo</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/InputFile.html#location--">location()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io">InputFile</a></dt>
@@ -13334,6 +13849,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/util/LocationUtil.html" title="class in org.apache.iceberg.util"><span class="typeNameLink">LocationUtil</span></a> - Class in <a href="org/apache/iceberg/util/package-summary.html">org.apache.iceberg.util</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/NoLock.html#lock--">lock()</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive">NoLock</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#LOCK_ACQUIRE_INTERVAL_MS">LOCK_ACQUIRE_INTERVAL_MS</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#LOCK_ACQUIRE_INTERVAL_MS_DEFAULT">LOCK_ACQUIRE_INTERVAL_MS_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
@@ -13354,6 +13871,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#LOCK_HEARTBEAT_TIMEOUT_MS_DEFAULT">LOCK_HEARTBEAT_TIMEOUT_MS_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/ConfigProperties.html#LOCK_HIVE_ENABLED">LOCK_HIVE_ENABLED</a></span> - Static variable in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/ConfigProperties.html" title="class in org.apache.iceberg.hadoop">ConfigProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CatalogProperties.html#LOCK_IMPL">LOCK_IMPL</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/CatalogProperties.html" title="class in org.apache.iceberg">CatalogProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopTables.html#LOCK_PROPERTY_PREFIX">LOCK_PROPERTY_PREFIX</a></span> - Static variable in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopTables.html" title="class in org.apache.iceberg.hadoop">HadoopTables</a></dt>
@@ -13388,9 +13907,15 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ParquetValueReaders.LongAsDecimalReader.html#LongAsDecimalReader-org.apache.parquet.column.ColumnDescriptor-int-">LongAsDecimalReader(ColumnDescriptor, int)</a></span> - Constructor for class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ParquetValueReaders.LongAsDecimalReader.html" title="class in org.apache.iceberg.parquet">ParquetValueReaders.LongAsDecimalReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#longBackedDecimalBatchReader--">longBackedDecimalBatchReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBackedDecimalBatchReader.html#LongBackedDecimalBatchReader--">LongBackedDecimalBatchReader()</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBackedDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator.LongBa [...]
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html#longBackedDecimalDictEncodedReader--">longBackedDecimalDictEncodedReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedDictionaryEncodedParquetValue [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#longBatchReader--">longBatchReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator</a></dt>
@@ -13466,8 +13991,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/AvroSchemaUtil.html#makeCompatibleName-java.lang.String-">makeCompatibleName(String)</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/AvroSchemaUtil.html" title="class in org.apache.iceberg.avro">AvroSchemaUtil</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#manager--">manager()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseTable.html#manageSnapshots--">manageSnapshots()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseTable.html" title="class in org.apache.iceberg">BaseTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseTransaction.html#manageSnapshots--">manageSnapshots()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseTransaction.html" title="class in org.apache.iceberg">BaseTransaction</a></dt>
@@ -13713,24 +14236,50 @@
 <dd>
 <div class="block">Returns the maximum value of the histogram observations.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadOptions.html#MAX_ALLOWED_PLANNING_FAILURES">MAX_ALLOWED_PLANNING_FAILURES</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadOptions.html" title="class in org.apache.iceberg.flink">FlinkReadOptions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadOptions.html#MAX_ALLOWED_PLANNING_FAILURES_OPTION">MAX_ALLOWED_PLANNING_FAILURES_OPTION</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadOptions.html" title="class in org.apache.iceberg.flink">FlinkReadOptions</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES">MAX_CONCURRENT_FILE_GROUP_REWRITES</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>
 <div class="block">The max number of file groups to be simultaneously rewritten by the rewrite strategy.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES">MAX_CONCURRENT_FILE_GROUP_REWRITES</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
+<dd>
+<div class="block">The max number of file groups to be simultaneously rewritten by the rewrite strategy.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT">MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT">MAX_CONCURRENT_FILE_GROUP_REWRITES_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#MAX_FILE_GROUP_SIZE_BYTES">MAX_FILE_GROUP_SIZE_BYTES</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>
 <div class="block">The entire rewrite operation is broken down into pieces based on partitioning and within
  partitions based on size into groups.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_GROUP_SIZE_BYTES">MAX_FILE_GROUP_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">This option controls the largest amount of data that should be rewritten in a single file
+ group.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#MAX_FILE_GROUP_SIZE_BYTES_DEFAULT">MAX_FILE_GROUP_SIZE_BYTES_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_GROUP_SIZE_BYTES_DEFAULT">MAX_FILE_GROUP_SIZE_BYTES_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#MAX_FILE_SIZE_BYTES">MAX_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Adjusts files which will be considered for rewriting.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_SIZE_BYTES">MAX_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Controls which files will be considered for rewriting.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#MAX_FILE_SIZE_DEFAULT_RATIO">MAX_FILE_SIZE_DEFAULT_RATIO</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MAX_FILE_SIZE_DEFAULT_RATIO">MAX_FILE_SIZE_DEFAULT_RATIO</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadOptions.html#MAX_PLANNING_SNAPSHOT_COUNT">MAX_PLANNING_SNAPSHOT_COUNT</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadOptions.html" title="class in org.apache.iceberg.flink">FlinkReadOptions</a></dt>
 <dd>&nbsp;</dd>
@@ -13748,8 +14297,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/MaxAggregate.html#MaxAggregate-org.apache.iceberg.expressions.BoundTerm-">MaxAggregate(BoundTerm&lt;T&gt;)</a></span> - Constructor for class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/MaxAggregate.html" title="class in org.apache.iceberg.expressions">MaxAggregate</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadConf.html#maxAllowedPlanningFailures--">maxAllowedPlanningFailures()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadConf.html" title="class in org.apache.iceberg.flink">FlinkReadConf</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/IcebergSource.Builder.html#maxAllowedPlanningFailures-int-">maxAllowedPlanningFailures(int)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/IcebergSource.Builder.html" title="class in org.apache.iceberg.flink.source">IcebergSource.Builder</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.Builder.html#maxAllowedPlanningFailures-int-">maxAllowedPlanningFailures(int)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.Builder.html" title="class in org.apache.iceberg.flink.source">ScanContext.Builder</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.html#maxAllowedPlanningFailures--">maxAllowedPlanningFailures()</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.html" title="class in org.apache.iceberg.flink.source">ScanContext</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/ContentCache.html#maxContentLength--">maxContentLength()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/ContentCache.html" title="class in org.apache.iceberg.io">ContentCache</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadConf.html#maxFilesPerMicroBatch--">maxFilesPerMicroBatch()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark">SparkReadConf</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/actions/RewriteDataFilesAction.html#maxParallelism-int-">maxParallelism(int)</a></span> - Method in class org.apache.iceberg.flink.actions.<a href="org/apache/iceberg/flink/actions/RewriteDataFilesAction.html" title="class in org.apache.iceberg.flink.actions">RewriteDataFilesAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadConf.html#maxPlanningSnapshotCount--">maxPlanningSnapshotCount()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadConf.html" title="class in org.apache.iceberg.flink">FlinkReadConf</a></dt>
@@ -13760,12 +14319,16 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.html#maxPlanningSnapshotCount--">maxPlanningSnapshotCount()</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.html" title="class in org.apache.iceberg.flink.source">ScanContext</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadConf.html#maxRecordsPerMicroBatch--">maxRecordsPerMicroBatch()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadConf.html" title="class in org.apache.iceberg.spark">SparkReadConf</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.SetSnapshotRef.html#maxRefAgeMs--">maxRefAgeMs()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.SetSnapshotRef.html" title="class in org.apache.iceberg">MetadataUpdate.SetSnapshotRef</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotRef.Builder.html#maxRefAgeMs-java.lang.Long-">maxRefAgeMs(Long)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotRef.Builder.html" title="class in org.apache.iceberg">SnapshotRef.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotRef.html#maxRefAgeMs--">maxRefAgeMs()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotRef.html" title="class in org.apache.iceberg">SnapshotRef</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#maxRewrittenDataSequenceNumber--">maxRewrittenDataSequenceNumber()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#maxSnapshotAge--">maxSnapshotAge()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.SnapshotRetentionContext.html#maxSnapshotAge--">maxSnapshotAge()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.SnapshotRetentionContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser.SnapshotRetentionContext</a></dt>
@@ -13903,6 +14466,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg"><span class="typeNameLink">MetadataColumns</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkChangelogTable.html#metadataColumns--">metadataColumns()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkChangelogTable.html" title="class in org.apache.iceberg.spark.source">SparkChangelogTable</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkTable.html#metadataColumns--">metadataColumns()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source">SparkTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#metadataFieldIds--">metadataFieldIds()</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
@@ -13936,10 +14501,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/MetaDataReaderFunction.html#MetaDataReaderFunction-org.apache.flink.configuration.ReadableConfig-org.apache.iceberg.Schema-org.apache.iceberg.Schema-org.apache.iceberg.io.FileIO-org.apache.iceberg.encryption.EncryptionManager-">MetaDataReaderFunction(ReadableConfig, Schema, Schema, FileIO, EncryptionManager)</a></span> - Constructor for class org.apache.iceberg.flink.source.reader.<a href="org/apache/iceberg [...]
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html#metadataSchema--">metadataSchema()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html" title="interface in org.apache.spark.sql.connector.iceberg.write">ExtendedLogicalWriteInfo</a></dt>
-<dd>
-<div class="block">The schema of the input metadata from Spark to data source.</div>
-</dd>
 <dt><a href="org/apache/iceberg/MetadataTableType.html" title="enum in org.apache.iceberg"><span class="typeNameLink">MetadataTableType</span></a> - Enum in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/MetadataTableUtils.html" title="class in org.apache.iceberg"><span class="typeNameLink">MetadataTableUtils</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -14143,6 +14704,15 @@
 <dd>
 <div class="block">This interface defines the basic API for reporting metrics for operations to a Table.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/Scan.html#metricsReporter-org.apache.iceberg.metrics.MetricsReporter-">metricsReporter(MetricsReporter)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Scan.html" title="interface in org.apache.iceberg">Scan</a></dt>
+<dd>
+<div class="block">Create a new scan that will report scan metrics to the provided reporter in addition to
+ reporters maintained by the scan.</div>
+</dd>
+<dt><a href="org/apache/iceberg/metrics/MetricsReporters.html" title="class in org.apache.iceberg.metrics"><span class="typeNameLink">MetricsReporters</span></a> - Class in <a href="org/apache/iceberg/metrics/package-summary.html">org.apache.iceberg.metrics</a></dt>
+<dd>
+<div class="block">Utility class that allows combining two given <a href="org/apache/iceberg/metrics/MetricsReporter.html" title="interface in org.apache.iceberg.metrics"><code>MetricsReporter</code></a> instances.</div>
+</dd>
 <dt><a href="org/apache/iceberg/MetricsUtil.html" title="class in org.apache.iceberg"><span class="typeNameLink">MetricsUtil</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/MetricsUtil.ReadableColMetricsStruct.html" title="class in org.apache.iceberg"><span class="typeNameLink">MetricsUtil.ReadableColMetricsStruct</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -14197,7 +14767,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/DateTimeUtil.html#microsToYears-long-">microsToYears(long)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/DateTimeUtil.html" title="class in org.apache.iceberg.util">DateTimeUtil</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseMigrateTableActionResult.html#migratedDataFilesCount--">migratedDataFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseMigrateTableActionResult.html" title="class in org.apache.iceberg.actions">BaseMigrateTableActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/MigrateTable.Result.html#migratedDataFilesCount--">migratedDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/MigrateTable.Result.html" title="interface in org.apache.iceberg.actions">MigrateTable.Result</a></dt>
 <dd>
 <div class="block">Returns the number of migrated data files.</div>
@@ -14231,16 +14803,34 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#MIN_FILE_SIZE_BYTES">MIN_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Adjusts files which will be considered for rewriting.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_FILE_SIZE_BYTES">MIN_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Controls which files will be considered for rewriting.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#MIN_FILE_SIZE_DEFAULT_RATIO">MIN_FILE_SIZE_DEFAULT_RATIO</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_FILE_SIZE_DEFAULT_RATIO">MIN_FILE_SIZE_DEFAULT_RATIO</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#MIN_INPUT_FILES">MIN_INPUT_FILES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">The minimum number of files that need to be in a file group for it to be considered for
  compaction if the total size of that group is less than the <a href="org/apache/iceberg/actions/RewriteDataFiles.html#TARGET_FILE_SIZE_BYTES"><code>RewriteDataFiles.TARGET_FILE_SIZE_BYTES</code></a>.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_INPUT_FILES">MIN_INPUT_FILES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Any file group exceeding this number of files will be rewritten regardless of other criteria.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#MIN_INPUT_FILES_DEFAULT">MIN_INPUT_FILES_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#MIN_INPUT_FILES_DEFAULT">MIN_INPUT_FILES_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManifestFile.html#MIN_SEQUENCE_NUMBER">MIN_SEQUENCE_NUMBER</a></span> - Static variable in interface org.apache.iceberg.<a href="org/apache/iceberg/ManifestFile.html" title="interface in org.apache.iceberg">ManifestFile</a></dt>
 <dd>&nbsp;</dd>
@@ -14364,6 +14954,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">MonthsFunction.DateToMonthsFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">MonthsFunction.TimestampNtzToMonthsFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">MonthsFunction.TimestampToMonthsFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/UpdateSchema.html#moveAfter-java.lang.String-java.lang.String-">moveAfter(String, String)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/UpdateSchema.html" title="interface in org.apache.iceberg">UpdateSchema</a></dt>
@@ -14378,6 +14970,26 @@
 <dd>
 <div class="block">Move a column from its current position to the start of the schema or its parent struct.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_SIZE">MULTIPART_SIZE</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">The size of a single part for multipart upload requests in bytes (default: 32MB).</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_SIZE_DEFAULT">MULTIPART_SIZE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_SIZE_MIN">MULTIPART_SIZE_MIN</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_THRESHOLD_FACTOR">MULTIPART_THRESHOLD_FACTOR</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">The threshold expressed as a factor times the multipart size at which to switch from uploading
+ using a single put object request to uploading using multipart upload (default: 1.5).</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_THRESHOLD_FACTOR_DEFAULT">MULTIPART_THRESHOLD_FACTOR_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#MULTIPART_UPLOAD_THREADS">MULTIPART_UPLOAD_THREADS</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Number of threads to use for uploading parts to S3 (shared pool across all output streams),
+ default to <code>Runtime.availableProcessors()</code></div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.AddPartitionFieldContext.html#multipartIdentifier--">multipartIdentifier()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.AddPartitionFieldContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser.AddPartitionFiel [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.CallContext.html#multipartIdentifier--">multipartIdentifier()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.CallContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser.CallContext</a></dt>
@@ -14414,28 +15026,40 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.MultipartIdentifierContext.html#MultipartIdentifierContext-org.antlr.v4.runtime.ParserRuleContext-int-">MultipartIdentifierContext(ParserRuleContext, int)</a></span> - Constructor for class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.MultipartIdentifierContext.html" title="class in org. [...]
 <dd>&nbsp;</dd>
-</dl>
-<a name="I:N">
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#multiPartSize--">multiPartSize()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#multipartThresholdFactor--">multipartThresholdFactor()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#multipartUploadThreads--">multipartUploadThreads()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+</dl>
+<a name="I:N">
 <!--   -->
 </a>
 <h2 class="title">N</h2>
 <dl>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#name--">name()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/ConvertEqualityDeleteStrategy.html#name--">name()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/ConvertEqualityDeleteStrategy.html" title="interface in org.apache.iceberg.actions">ConvertEqualityDeleteStrategy</a></dt>
 <dd>
 <div class="block">Returns the name of this convert deletes strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#name--">name()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns the name of this rewrite deletes strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#name--">name()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns the name of this rewrite strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#name--">name()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/dynamodb/DynamoDbCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.aws.dynamodb.<a href="org/apache/iceberg/aws/dynamodb/DynamoDbCatalog.html" title="class in org.apache.iceberg.aws.dynamodb">DynamoDbCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/glue/GlueCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.aws.glue.<a href="org/apache/iceberg/aws/glue/GlueCatalog.html" title="class in org.apache.iceberg.aws.glue">GlueCatalog</a></dt>
@@ -14480,6 +15104,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.RemoveSnapshotRef.html#name--">name()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.RemoveSnapshotRef.html" title="class in org.apache.iceberg">MetadataUpdate.RemoveSnapshotRef</a></dt>
@@ -14500,8 +15126,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SerializableTable.html#name--">name()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SerializableTable.html" title="class in org.apache.iceberg">SerializableTable</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.BucketBase.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.BucketBase.html" title="class in org.apache.iceberg.spark.functions">BucketFunction.BucketBase</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.html" title="class in org.apache.iceberg.spark.functions">BucketFunction</a></dt>
@@ -14510,6 +15134,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/IcebergVersionFunction.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/IcebergVersionFunction.html" title="class in org.apache.iceberg.spark.functions">IcebergVersionFunction</a></dt>
@@ -14544,6 +15170,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkCatalog.html" title="class in org.apache.iceberg.spark">SparkCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark">SparkFunctionCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#name--">name()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Table.html#name--">name()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Table.html" title="interface in org.apache.iceberg">Table</a></dt>
@@ -14628,6 +15256,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/dell/ecs/EcsCatalog.html#namespaceExists-org.apache.iceberg.catalog.Namespace-">namespaceExists(Namespace)</a></span> - Method in class org.apache.iceberg.dell.ecs.<a href="org/apache/iceberg/dell/ecs/EcsCatalog.html" title="class in org.apache.iceberg.dell.ecs">EcsCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#namespaceExists-org.apache.iceberg.catalog.Namespace-">namespaceExists(Namespace)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#namespaceExists-org.apache.iceberg.catalog.Namespace-">namespaceExists(Namespace)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#namespaceExists-java.lang.String:A-">namespaceExists(String[])</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></dt>
@@ -14917,6 +15547,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopFileIO.html#newInputFile-java.lang.String-long-">newInputFile(String, long)</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopFileIO.html" title="class in org.apache.iceberg.hadoop">HadoopFileIO</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#newInputFile-java.lang.String-">newInputFile(String)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/FileIO.html#newInputFile-java.lang.String-">newInputFile(String)</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/FileIO.html" title="interface in org.apache.iceberg.io">FileIO</a></dt>
 <dd>
 <div class="block">Get a <a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io"><code>InputFile</code></a> instance to read bytes from the file at the given path.</div>
@@ -14956,6 +15588,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopFileIO.html#newOutputFile-java.lang.String-">newOutputFile(String)</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopFileIO.html" title="class in org.apache.iceberg.hadoop">HadoopFileIO</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryFileIO.html#newOutputFile-java.lang.String-">newOutputFile(String)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryFileIO.html" title="class in org.apache.iceberg.inmemory">InMemoryFileIO</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/FileIO.html#newOutputFile-java.lang.String-">newOutputFile(String)</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/FileIO.html" title="interface in org.apache.iceberg.io">FileIO</a></dt>
 <dd>
 <div class="block">Get a <a href="org/apache/iceberg/io/OutputFile.html" title="interface in org.apache.iceberg.io"><code>OutputFile</code></a> instance to write bytes to the file at the given path.</div>
@@ -15168,6 +15802,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopInputFile.html#newStream--">newStream()</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopInputFile.html" title="class in org.apache.iceberg.hadoop">HadoopInputFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryInputFile.html#newStream--">newStream()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryInputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryInputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/InputFile.html#newStream--">newStream()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io">InputFile</a></dt>
 <dd>
 <div class="block">Opens a new <a href="org/apache/iceberg/io/SeekableInputStream.html" title="class in org.apache.iceberg.io"><code>SeekableInputStream</code></a> for the underlying data file</div>
@@ -15194,6 +15830,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#newTableOps-org.apache.iceberg.catalog.TableIdentifier-">newTableOps(TableIdentifier)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#newTableOps-org.apache.iceberg.catalog.TableIdentifier-">newTableOps(TableIdentifier)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#newTableOps-org.apache.iceberg.catalog.TableIdentifier-">newTableOps(TableIdentifier)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#newTableOps-org.apache.iceberg.catalog.TableIdentifier-">newTableOps(TableIdentifier)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -15224,8 +15862,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkTable.html#newWriteBuilder-org.apache.spark.sql.connector.write.LogicalWriteInfo-">newWriteBuilder(LogicalWriteInfo)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source">SparkTable</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html#newWriteBuilder-org.apache.spark.sql.connector.write.LogicalWriteInfo-">newWriteBuilder(LogicalWriteInfo)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html" title="interface in org.apache.spark.sql.connector.iceberg.write">SupportsDelta</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/ClusteredDataWriter.html#newWriter-org.apache.iceberg.PartitionSpec-org.apache.iceberg.StructLike-">newWriter(PartitionSpec, StructLike)</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/ClusteredDataWriter.html" title="class in org.apache.iceberg.io">ClusteredDataWriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/ClusteredEqualityDeleteWriter.html#newWriter-org.apache.iceberg.PartitionSpec-org.apache.iceberg.StructLike-">newWriter(PartitionSpec, StructLike)</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/ClusteredEqualityDeleteWriter.html" title="class in org.apache.iceberg.io">ClusteredEqualityDeleteWriter</a></dt>
@@ -15248,7 +15884,7 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/orc/VectorizedRowBatchIterator.html#next--">next()</a></span> - Method in class org.apache.iceberg.orc.<a href="org/apache/iceberg/orc/VectorizedRowBatchIterator.html" title="class in org.apache.iceberg.orc">VectorizedRowBatchIterator</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#next--">next()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ComputeUpdateIterator.html#next--">next()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ComputeUpdateIterator.html" title="class in org.apache.iceberg.spark">ComputeUpdateIterator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.BatchReader.html#nextBatch-org.apache.arrow.vector.FieldVector-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatch(FieldVector, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.BatchReader.html" title="class in org.apache.iceberg.arrow.v [...]
 <dd>&nbsp;</dd>
@@ -15265,7 +15901,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.DoubleBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.DoubleBatchReader.html" title="c [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedLengthDecimalBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedLengthDecimalBa [...]
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedSizeBinaryBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedSizeBinaryBatchRea [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedWidthTypeBinaryBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedWidthTypeBina [...]
@@ -15273,13 +15911,19 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FloatBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FloatBatchReader.html" title="cla [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntBackedDecimalBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntBackedDecimalBatchR [...]
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntegerBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntegerBatchReader.html" title= [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBackedDecimalBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBackedDecimalBatc [...]
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBatchReader.html" title="class [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampInt96BatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampInt96BatchReade [...]
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampMillisBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampMillisBatchRea [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.VarWidthTypeBatchReader.html#nextBatchOf-org.apache.arrow.vector.FieldVector-int-int-int-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">nextBatchOf(FieldVector, int, int, int, NullabilityHolder)</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.VarWidthTypeBatchReader.ht [...]
@@ -15306,6 +15950,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopInputFile.html#NO_LOCATION_PREFERENCE">NO_LOCATION_PREFERENCE</a></span> - Static variable in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopInputFile.html" title="class in org.apache.iceberg.hadoop">HadoopInputFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive"><span class="typeNameLink">NoLock</span></a> - Class in <a href="org/apache/iceberg/hive/package-summary.html">org.apache.iceberg.hive</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/NoLock.html#NoLock--">NoLock()</a></span> - Constructor for class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive">NoLock</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetricsModes.None.html#None--">None()</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/MetricsModes.None.html" title="class in org.apache.iceberg">MetricsModes.None</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#nonMetadataColumn-java.lang.String-">nonMetadataColumn(String)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
@@ -15574,8 +16222,15 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#numOutputFiles-long-">numOutputFiles(long)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Determine how many output files to create when rewriting.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#numOutputFiles-long-">numOutputFiles(long)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Determines the preferable number of output files when rewriting a particular file group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#numRewrittenDeleteFiles--">numRewrittenDeleteFiles()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/ColumnarBatch.html#numRows--">numRows()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/ColumnarBatch.html" title="class in org.apache.iceberg.arrow.vectorized">ColumnarBatch</a></dt>
 <dd>
 <div class="block">Returns the number of rows for read, including filtered rows.</div>
@@ -15747,10 +16402,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/FileMetadata.Builder.html#ofEqualityDeletes-int...-">ofEqualityDeletes(int...)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/FileMetadata.Builder.html" title="class in org.apache.iceberg">FileMetadata.Builder</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#offer-org.apache.iceberg.actions.RewriteFileGroup-">offer(RewriteFileGroup)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager.CommitService</a></dt>
-<dd>
-<div class="block">Places a file group in the queue and commits a batch of file groups if <a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#rewritesPerCommit"><code>RewriteDataFilesCommitManager.CommitService.rewritesPerCommit</code></a> number of file groups are present in the queue.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/BlobMetadata.html#offset--">offset()</a></span> - Method in class org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/BlobMetadata.html" title="class in org.apache.iceberg.puffin">BlobMetadata</a></dt>
 <dd>
 <div class="block">Offset in the file</div>
@@ -15779,6 +16430,10 @@
 <dd>
 <div class="block">Create a UTF8 String from the row value in the arrow vector.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/GenericArrowVectorAccessorFactory.StringFactory.html#ofRow-org.apache.arrow.vector.FixedSizeBinaryVector-int-">ofRow(FixedSizeBinaryVector, int)</a></span> - Method in interface org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/GenericArrowVectorAccessorFactory.StringFactory.html" title="interface in org.apache.iceberg.arrow.vectorized">GenericArrowVectorAccessorFactory.StringFact [...]
+<dd>
+<div class="block">Create a UTF8 String from the row value in the FixedSizeBinaryVector vector.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/DeleteOrphanFiles.html#olderThan-long-">olderThan(long)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/DeleteOrphanFiles.html" title="interface in org.apache.iceberg.actions">DeleteOrphanFiles</a></dt>
 <dd>
 <div class="block">Removes orphan files only if they are older than the given timestamp.</div>
@@ -15871,6 +16526,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/EqualityDeleteRowReader.html#open-org.apache.iceberg.FileScanTask-">open(FileScanTask)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/EqualityDeleteRowReader.html" title="class in org.apache.iceberg.spark.source">EqualityDeleteRowReader</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/MicroBatches.html#openManifestFile-org.apache.iceberg.io.FileIO-java.util.Map-boolean-org.apache.iceberg.Snapshot-org.apache.iceberg.ManifestFile-boolean-">openManifestFile(FileIO, Map&lt;Integer, PartitionSpec&gt;, boolean, Snapshot, ManifestFile, boolean)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/MicroBatches.html" title="class in org.apache.iceberg">MicroBatches</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/AddedRowsScanTask.html#operation--">operation()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/AddedRowsScanTask.html" title="interface in org.apache.iceberg">AddedRowsScanTask</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseOverwriteFiles.html#operation--">operation()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseOverwriteFiles.html" title="class in org.apache.iceberg">BaseOverwriteFiles</a></dt>
@@ -15897,12 +16554,16 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/StreamingDelete.html#operation--">operation()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/StreamingDelete.html" title="class in org.apache.iceberg">StreamingDelete</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/view/ViewVersion.html#operation--">operation()</a></span> - Method in interface org.apache.iceberg.view.<a href="org/apache/iceberg/view/ViewVersion.html" title="interface in org.apache.iceberg.view">ViewVersion</a></dt>
+<dd>
+<div class="block">Return the operation which produced the view version</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/OutputFileFactory.Builder.html#operationId-java.lang.String-">operationId(String)</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/OutputFileFactory.Builder.html" title="class in org.apache.iceberg.io">OutputFileFactory.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetadataTable.html#operations--">operations()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetadataTable.html" title="class in org.apache.iceberg">BaseMetadataTable</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 2.0.0; do not use metadata table TableOperations</span></div>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0; do not use metadata table TableOperations</span></div>
 </div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseTable.html#operations--">operations()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseTable.html" title="class in org.apache.iceberg">BaseTable</a></dt>
@@ -15941,25 +16602,27 @@
 <div class="block">Configures this action with extra options.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/ConvertEqualityDeleteStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/ConvertEqualityDeleteStrategy.html" title="interface in org.apache.iceberg.actions">ConvertEqualityDeleteStrategy</a></dt>
 <dd>
 <div class="block">Sets options to be used with this strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Sets options to be used with this strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Sets options to be used with this strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#options-java.util.Map-">options(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/Expressions.html#or-org.apache.iceberg.expressions.Expression-org.apache.iceberg.expressions.Expression-">or(Expression, Expression)</a></span> - Static method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/Expressions.html" title="class in org.apache.iceberg.expressions">Expressions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/ExpressionVisitors.CustomOrderExpressionVisitor.html#or-java.util.function.Supplier-java.util.function.Supplier-">or(Supplier&lt;R&gt;, Supplier&lt;R&gt;)</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/ExpressionVisitors.CustomOrderExpressionVisitor.html" title="class in org.apache.iceberg.expressions">ExpressionVisitors.CustomOrderExpressionVisitor</a></dt>
@@ -16102,6 +16765,8 @@
 <dd>
 <div class="block">Returns the ID of this sort order</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteRequirements.html#ordering--">ordering()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteRequirements.html" title="class in org.apache.iceberg.spark">SparkWriteRequirements</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteJobOrder.html#orderName--">orderName()</a></span> - Method in enum org.apache.iceberg.<a href="org/apache/iceberg/RewriteJobOrder.html" title="enum in org.apache.iceberg">RewriteJobOrder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/SortOrderUtil.html#orderPreservingSortedColumns-org.apache.iceberg.SortOrder-">orderPreservingSortedColumns(SortOrder)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/SortOrderUtil.html" title="class in org.apache.iceberg.util">SortOrderUtil</a></dt>
@@ -16136,6 +16801,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/aws/s3/signer/package-summary.html">org.apache.iceberg.aws.s3.signer</a> - package org.apache.iceberg.aws.s3.signer</dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/aws/util/package-summary.html">org.apache.iceberg.aws.util</a> - package org.apache.iceberg.aws.util</dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/catalog/package-summary.html">org.apache.iceberg.catalog</a> - package org.apache.iceberg.catalog</dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/common/package-summary.html">org.apache.iceberg.common</a> - package org.apache.iceberg.common</dt>
@@ -16192,6 +16859,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/hive/package-summary.html">org.apache.iceberg.hive</a> - package org.apache.iceberg.hive</dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/inmemory/package-summary.html">org.apache.iceberg.inmemory</a> - package org.apache.iceberg.inmemory</dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a> - package org.apache.iceberg.io</dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/jdbc/package-summary.html">org.apache.iceberg.jdbc</a> - package org.apache.iceberg.jdbc</dt>
@@ -16262,8 +16931,6 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/spark/sql/connector/iceberg/catalog/package-summary.html">org.apache.spark.sql.connector.iceberg.catalog</a> - package org.apache.spark.sql.connector.iceberg.catalog</dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a> - package org.apache.spark.sql.connector.iceberg.write</dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/common/DynMethods.Builder.html#orNoop--">orNoop()</a></span> - Method in class org.apache.iceberg.common.<a href="org/apache/iceberg/common/DynMethods.Builder.html" title="class in org.apache.iceberg.common">DynMethods.Builder</a></dt>
 <dd>
 <div class="block">If no implementation has been found, adds a NOOP method.</div>
@@ -16274,7 +16941,9 @@
  Exception.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html#orphanFileLocations--">orphanFileLocations()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseDeleteOrphanFilesActionResult.html" title="class in org.apache.iceberg.actions">BaseDeleteOrphanFilesActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/DeleteOrphanFiles.Result.html#orphanFileLocations--">orphanFileLocations()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/DeleteOrphanFiles.Result.html" title="interface in org.apache.iceberg.actions">DeleteOrphanFiles.Result</a></dt>
 <dd>
 <div class="block">Returns locations of orphan files.</div>
@@ -16317,6 +16986,8 @@
  string form has the syntax as below, which refers to RFC2396: [scheme:][//bucket][object
  key][#fragment] [scheme:][//bucket][object key][?query][#fragment]</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#OUTPUT_SPEC_ID">OUTPUT_SPEC_ID</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/InputFormatConfig.html#OUTPUT_TABLES">OUTPUT_TABLES</a></span> - Static variable in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr">InputFormatConfig</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/OutputFile.html" title="interface in org.apache.iceberg.io"><span class="typeNameLink">OutputFile</span></a> - Interface in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
@@ -16333,6 +17004,8 @@
 <dd>
 <div class="block">Pass a PartitionSpec id to specify which PartitionSpec should be used in DataFile rewrite</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#outputSpecId--">outputSpecId()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/hive/HiveIcebergStorageHandler.html#outputTables-org.apache.hadoop.conf.Configuration-">outputTables(Configuration)</a></span> - Static method in class org.apache.iceberg.mr.hive.<a href="org/apache/iceberg/mr/hive/HiveIcebergStorageHandler.html" title="class in org.apache.iceberg.mr.hive">HiveIcebergStorageHandler</a></dt>
 <dd>
 <div class="block">Returns the names of the output tables stored in the configuration.</div>
@@ -16345,6 +17018,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html#outputType--">outputType()</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RemoveOrphanFilesProcedure</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html#outputType--">outputType()</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RewritePositionDeleteFilesProcedure</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/catalog/Procedure.html#outputType--">outputType()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.catalog.<a href="org/apache/spark/sql/connector/iceberg/catalog/Procedure.html" title="interface in org.apache.spark.sql.connector.iceberg.catalog">Procedure</a></dt>
 <dd>
 <div class="block">Returns the type of rows produced by this procedure.</div>
@@ -16455,6 +17130,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html#parameters--">parameters()</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RemoveOrphanFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RemoveOrphanFilesProcedure</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html#parameters--">parameters()</a></span> - Method in class org.apache.iceberg.spark.procedures.<a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures">RewritePositionDeleteFilesProcedure</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/catalog/Procedure.html#parameters--">parameters()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.catalog.<a href="org/apache/spark/sql/connector/iceberg/catalog/Procedure.html" title="interface in org.apache.spark.sql.connector.iceberg.catalog">Procedure</a></dt>
 <dd>
 <div class="block">Returns the input parameters of this procedure.</div>
@@ -16670,21 +17347,41 @@
 <div class="block">Enable committing groups of files (see max-file-group-size-bytes) prior to the entire rewrite
  completing.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_ENABLED">PARTIAL_PROGRESS_ENABLED</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
+<dd>
+<div class="block">Enable committing groups of files (see max-file-group-size-bytes) prior to the entire rewrite
+ completing.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#PARTIAL_PROGRESS_ENABLED_DEFAULT">PARTIAL_PROGRESS_ENABLED_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_ENABLED_DEFAULT">PARTIAL_PROGRESS_ENABLED_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#PARTIAL_PROGRESS_MAX_COMMITS">PARTIAL_PROGRESS_MAX_COMMITS</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>
 <div class="block">The maximum amount of Iceberg commits that this rewrite is allowed to produce if partial
  progress is enabled.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_MAX_COMMITS">PARTIAL_PROGRESS_MAX_COMMITS</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
+<dd>
+<div class="block">The maximum amount of Iceberg commits that this rewrite is allowed to produce if partial
+ progress is enabled.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT">PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html#partition--">partition()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesFileGroupInfo</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT">PARTIAL_PROGRESS_MAX_COMMITS_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html#partition--">partition()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesFileGroupInfo</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html#partition--">partition()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupInfo</a></dt>
 <dd>
 <div class="block">returns which partition this file group contains files from</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html#partition--">partition()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupInfo</a></dt>
+<dd>
+<div class="block">Returns which partition this position delete file group contains files from.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ContentFile.html#partition--">partition()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ContentFile.html" title="interface in org.apache.iceberg">ContentFile</a></dt>
 <dd>
 <div class="block">Returns partition for this file as a <a href="org/apache/iceberg/StructLike.html" title="interface in org.apache.iceberg"><code>StructLike</code></a>.</div>
@@ -16707,6 +17404,8 @@
 <dd>
 <div class="block">Returns the value of the partition for this scan task</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/PositionDeletesTable.html#PARTITION">PARTITION</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/PositionDeletesTable.html" title="class in org.apache.iceberg">PositionDeletesTable</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkPartitionedFanoutWriter.html#partition-org.apache.spark.sql.catalyst.InternalRow-">partition(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkPartitionedFanoutWriter.html" title="class in org.apache.iceberg.spark.source">SparkPartitionedFanoutWriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkPartitionedWriter.html#partition-org.apache.spark.sql.catalyst.InternalRow-">partition(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkPartitionedWriter.html" title="class in org.apache.iceberg.spark.source">SparkPartitionedWriter</a></dt>
@@ -16774,11 +17473,18 @@
 <div class="block">Represents a single field in a <a href="org/apache/iceberg/PartitionSpec.html" title="class in org.apache.iceberg"><code>PartitionSpec</code></a>.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html#partitionIndex--">partitionIndex()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesFileGroupInfo</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html#partitionIndex--">partitionIndex()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupInfo</a></dt>
 <dd>
 <div class="block">returns which file group this is out of the set of file groups for this partition</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html#partitionIndex--">partitionIndex()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupInfo</a></dt>
+<dd>
+<div class="block">Returns which position delete file group this is out of the set of file groups for this
+ partition</div>
+</dd>
 <dt><a href="org/apache/iceberg/Partitioning.html" title="class in org.apache.iceberg"><span class="typeNameLink">Partitioning</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/RollbackStagedTable.html#partitioning--">partitioning()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/RollbackStagedTable.html" title="class in org.apache.iceberg.spark">RollbackStagedTable</a></dt>
@@ -16889,6 +17595,13 @@
 <dd>
 <div class="block">Returns fully qualified path to the file, suitable for constructing a Hadoop Path.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PATH_STYLE_ACCESS">PATH_STYLE_ACCESS</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">If set <code>true</code>, requests to S3FileIO will use Path-Style, otherwise, Virtual Hosted-Style
+ will be used.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PATH_STYLE_ACCESS_DEFAULT">PATH_STYLE_ACCESS_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/PathIdentifier.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">PathIdentifier</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/PathIdentifier.html#PathIdentifier-java.lang.String-">PathIdentifier(String)</a></span> - Constructor for class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/PathIdentifier.html" title="class in org.apache.iceberg.spark">PathIdentifier</a></dt>
@@ -16925,14 +17638,25 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#planDeleteFileGroups-java.lang.Iterable-">planDeleteFileGroups(Iterable&lt;DeleteFile&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Groups into lists which will be processed in a single executable unit.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#planFileGroups-java.lang.Iterable-">planFileGroups(Iterable&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/FileRewriter.html#planFileGroups-java.lang.Iterable-">planFileGroups(Iterable&lt;T&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions">FileRewriter</a></dt>
+<dd>
+<div class="block">Selects files which this rewriter believes are valid targets to be rewritten based on their
+ scan tasks and groups those scan tasks into file groups.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#planFileGroups-java.lang.Iterable-">planFileGroups(Iterable&lt;FileScanTask&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Groups file scans into lists which will be processed in a single executable unit.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#planFileGroups-java.lang.Iterable-">planFileGroups(Iterable&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Scan.html#planFiles--">planFiles()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Scan.html" title="interface in org.apache.iceberg">Scan</a></dt>
 <dd>
 <div class="block">Plan tasks for this scan where each task reads a single file.</div>
@@ -17022,6 +17746,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/PositionDeletesTable.PositionDeletesBatchScan.html#PositionDeletesBatchScan-org.apache.iceberg.Table-org.apache.iceberg.Schema-org.apache.iceberg.TableScanContext-">PositionDeletesBatchScan(Table, Schema, TableScanContext)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/PositionDeletesTable.PositionDeletesBatchScan.html" title="class in org.apache.iceberg">PositionDeletesTable.PositionDeletesBa [...]
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/PositionDeletesRewriteCoordinator.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">PositionDeletesRewriteCoordinator</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/PositionDeletesScanTask.html" title="interface in org.apache.iceberg"><span class="typeNameLink">PositionDeletesScanTask</span></a> - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">A <a href="org/apache/iceberg/ScanTask.html" title="interface in org.apache.iceberg"><code>ScanTask</code></a> for position delete files</div>
@@ -17039,8 +17765,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/deletes/PositionDeleteWriter.html#PositionDeleteWriter-org.apache.iceberg.io.FileAppender-org.apache.iceberg.FileFormat-java.lang.String-org.apache.iceberg.PartitionSpec-org.apache.iceberg.StructLike-org.apache.iceberg.encryption.EncryptionKeyMetadata-">PositionDeleteWriter(FileAppender&lt;StructLike&gt;, FileFormat, String, PartitionSpec, StructLike, EncryptionKeyMetadata)</a></span> - Constructor for class org.apache.iceberg. [...]
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#positionDeltaMergeDistributionMode--">positionDeltaMergeDistributionMode()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#positionDeltaRequirements-org.apache.spark.sql.connector.write.RowLevelOperation.Command-">positionDeltaRequirements(RowLevelOperation.Command)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteUtil.html#positionDeltaRequirements-org.apache.iceberg.Table-org.apache.spark.sql.connector.write.RowLevelOperation.Command-org.apache.iceberg.DistributionMode-">positionDeltaRequirements(Table, RowLevelOperation.Command, DistributionMode)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteUtil.html" title="class in org.apache.iceberg.spark">SparkWriteUtil</a></dt>
+<dd>
+<div class="block">Builds requirements for merge-on-read DELETE, UPDATE, MERGE operations.</div>
+</dd>
 <dt><a href="org/apache/iceberg/io/PositionDeltaWriter.html" title="interface in org.apache.iceberg.io"><span class="typeNameLink">PositionDeltaWriter</span></a>&lt;<a href="org/apache/iceberg/io/PositionDeltaWriter.html" title="type parameter in PositionDeltaWriter">T</a>&gt; - Interface in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>
 <div class="block">A writer capable of writing data and position deletes that may belong to different specs and
@@ -17054,7 +17784,7 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorizedArrowReader.html#positionsWithSetArrowValidityVector--">positionsWithSetArrowValidityVector()</a></span> - Static method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorizedArrowReader.html" title="class in org.apache.iceberg.arrow.vectorized">VectorizedArrowReader</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.PositionVectorHolder.html#PositionVectorHolder-org.apache.arrow.vector.FieldVector-org.apache.iceberg.types.Type-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">PositionVectorHolder(FieldVector, Type, NullabilityHolder)</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.PositionVectorHolder.html" title="class in o [...]
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.PositionVectorHolder.html#PositionVectorHolder-org.apache.arrow.vector.FieldVector-org.apache.iceberg.types.Types.NestedField-org.apache.iceberg.arrow.vectorized.NullabilityHolder-">PositionVectorHolder(FieldVector, Types.NestedField, NullabilityHolder)</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.PositionVectorHold [...]
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/HTTPClient.html#post-java.lang.String-org.apache.iceberg.rest.RESTRequest-java.lang.Class-java.util.Map-java.util.function.Consumer-">post(String, RESTRequest, Class&lt;T&gt;, Map&lt;String, String&gt;, Consumer&lt;ErrorResponse&gt;)</a></span> - Method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/HTTPClient.html" title="class in org.apache.iceberg.rest">HTTPClient</a></dt>
 <dd>&nbsp;</dd>
@@ -17121,6 +17851,13 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/DeleteOrphanFilesSparkAction.html#prefixMismatchMode-org.apache.iceberg.actions.DeleteOrphanFiles.PrefixMismatchMode-">prefixMismatchMode(DeleteOrphanFiles.PrefixMismatchMode)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/DeleteOrphanFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">DeleteOrphanFilesSparkAction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PRELOAD_CLIENT_ENABLED">PRELOAD_CLIENT_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">This flag controls whether the S3 client will be initialized during the S3FileIO
+ initialization, instead of default lazy initialization upon use.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#PRELOAD_CLIENT_ENABLED_DEFAULT">PRELOAD_CLIENT_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ManifestWriter.html#prepare-org.apache.iceberg.ManifestEntry-">prepare(ManifestEntry&lt;F&gt;)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/ManifestWriter.html" title="class in org.apache.iceberg">ManifestWriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/pig/IcebergStorage.html#prepareToRead-org.apache.hadoop.mapreduce.RecordReader-org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit-">prepareToRead(RecordReader, PigSplit)</a></span> - Method in class org.apache.iceberg.pig.<a href="org/apache/iceberg/pig/IcebergStorage.html" title="class in org.apache.iceberg.pig">IcebergStorage</a></dt>
@@ -17237,12 +17974,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.DateToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.DateToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampNtzToDaysFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampToDaysFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.DateToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.DateToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampNtzToMonthsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampToMonthsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html" title="class in org.apache.iceberg.spark.functions">TruncateFunction.TruncateBigInt</a></dt>
@@ -17261,6 +18004,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.DateToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampNtzToYearsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html#produceResult-org.apache.spark.sql.catalyst.InternalRow-">produceResult(InternalRow)</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampToYearsFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#producesDictionaryEncodedVector--">producesDictionaryEncodedVector()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator</a></dt>
@@ -17506,6 +18251,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/PruneColumnsWithReordering.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">PruneColumnsWithReordering</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/util/RetryDetector.html#publish-software.amazon.awssdk.metrics.MetricCollection-">publish(MetricCollection)</a></span> - Method in class org.apache.iceberg.aws.util.<a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util">RetryDetector</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotSummary.html#PUBLISHED_WAP_ID_PROP">PUBLISHED_WAP_ID_PROP</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotSummary.html" title="class in org.apache.iceberg">SnapshotSummary</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/WapUtil.html#publishedWapId-org.apache.iceberg.Snapshot-">publishedWapId(Snapshot)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/WapUtil.html" title="class in org.apache.iceberg.util">WapUtil</a></dt>
@@ -18086,6 +18833,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/ByteBufferInputStream.html#remainingStream--">remainingStream()</a></span> - Method in class org.apache.iceberg.io.<a href="org/apache/iceberg/io/ByteBufferInputStream.html" title="class in org.apache.iceberg.io">ByteBufferInputStream</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#REMOTE_SIGNING_ENABLED">REMOTE_SIGNING_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#REMOTE_SIGNING_ENABLED_DEFAULT">REMOTE_SIGNING_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/UpdateNamespacePropertiesRequest.html#removals--">removals()</a></span> - Method in class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/UpdateNamespacePropertiesRequest.html" title="class in org.apache.iceberg.rest.requests">UpdateNamespacePropertiesRequest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/UpdateNamespacePropertiesRequest.Builder.html#remove-java.lang.String-">remove(String)</a></span> - Method in class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/UpdateNamespacePropertiesRequest.Builder.html" title="class in org.apache.iceberg.rest.requests">UpdateNamespacePropertiesRequest.Builder</a></dt>
@@ -18126,6 +18877,10 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotManager.html#removeBranch-java.lang.String-">removeBranch(String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotManager.html" title="class in org.apache.iceberg">SnapshotManager</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#removeCarryovers-java.util.Iterator-org.apache.spark.sql.types.StructType-">removeCarryovers(Iterator&lt;Row&gt;, StructType)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>
+<div class="block">Creates an iterator that removes carry-over rows from a changelog table.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.RemoveProperties.html#removed--">removed()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.RemoveProperties.html" title="class in org.apache.iceberg">MetadataUpdate.RemoveProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/responses/UpdateNamespacePropertiesResponse.html#removed--">removed()</a></span> - Method in class org.apache.iceberg.rest.responses.<a href="org/apache/iceberg/rest/responses/UpdateNamespacePropertiesResponse.html" title="class in org.apache.iceberg.rest.responses">UpdateNamespacePropertiesResponse</a></dt>
@@ -18222,6 +18977,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#removeProperties-org.apache.iceberg.catalog.Namespace-java.util.Set-">removeProperties(Namespace, Set&lt;String&gt;)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#removeProperties-org.apache.iceberg.catalog.Namespace-java.util.Set-">removeProperties(Namespace, Set&lt;String&gt;)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#removeProperties-org.apache.iceberg.catalog.Namespace-java.util.Set-">removeProperties(Namespace, Set&lt;String&gt;)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.RemoveProperties.html#RemoveProperties-java.util.Set-">RemoveProperties(Set&lt;String&gt;)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.RemoveProperties.html" title="class in org.apache.iceberg">MetadataUpdate.RemoveProperties</a></dt>
@@ -18264,10 +19021,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotManager.html#removeTag-java.lang.String-">removeTag(String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotManager.html" title="class in org.apache.iceberg">SnapshotManager</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html#removeTasks-org.apache.iceberg.Table-java.lang.String-">removeTasks(Table, String)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">FileScanTaskSetManager</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
-&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ScanTaskSetManager.html#removeTasks-org.apache.iceberg.Table-java.lang.String-">removeTasks(Table, String)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark">ScanTaskSetManager</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.ReadBuilder.html#rename-java.lang.String-java.lang.String-">rename(String, String)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.ReadBuilder.html" title="class in org.apache.iceberg.avro">Avro.ReadBuilder</a></dt>
@@ -18316,6 +19069,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#renameTable-org.apache.iceberg.catalog.TableIdentifier-org.apache.iceberg.catalog.TableIdentifier-">renameTable(TableIdentifier, TableIdentifier)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#renameTable-org.apache.iceberg.catalog.TableIdentifier-org.apache.iceberg.catalog.TableIdentifier-">renameTable(TableIdentifier, TableIdentifier)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#renameTable-org.apache.iceberg.catalog.TableIdentifier-org.apache.iceberg.catalog.TableIdentifier-">renameTable(TableIdentifier, TableIdentifier)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#renameTable-org.apache.iceberg.catalog.TableIdentifier-org.apache.iceberg.catalog.TableIdentifier-">renameTable(TableIdentifier, TableIdentifier)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
@@ -18703,14 +19458,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/metrics/ScanMetricsResult.html#resultDeleteFiles--">resultDeleteFiles()</a></span> - Method in interface org.apache.iceberg.metrics.<a href="org/apache/iceberg/metrics/ScanMetricsResult.html" title="interface in org.apache.iceberg.metrics">ScanMetricsResult</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#results--">results()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager.CommitService</a></dt>
-<dd>
-<div class="block">Returns all File groups which have been committed</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/AggregateEvaluator.html#resultType--">resultType()</a></span> - Method in class org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/AggregateEvaluator.html" title="class in org.apache.iceberg.expressions">AggregateEvaluator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/BucketFunction.BucketBase.html#resultType--">resultType()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/BucketFunction.BucketBase.html" title="class in org.apache.iceberg.spark.functions">BucketFunction.BucketBase</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#resultType--">resultType()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html#resultType--">resultType()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampToHoursFunction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html#resultType--">resultType()</a></span> - Method in class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/TruncateFunction.TruncateBigInt.html" title="class in org.apache.iceberg.spark.functions">TruncateFunction.TruncateBigInt</a></dt>
@@ -18757,8 +19510,17 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.SnapshotRetentionContext.html#RETENTION--">RETENTION()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.SnapshotRetentionContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser.SnapshotRetentionContext</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/util/RetryDetector.html#retried--">retried()</a></span> - Method in class org.apache.iceberg.aws.util.<a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util">RetryDetector</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/Tasks.Builder.html#retry-int-">retry(int)</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/Tasks.Builder.html" title="class in org.apache.iceberg.util">Tasks.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util"><span class="typeNameLink">RetryDetector</span></a> - Class in <a href="org/apache/iceberg/aws/util/package-summary.html">org.apache.iceberg.aws.util</a></dt>
+<dd>
+<div class="block">Metrics are the only reliable way provided by the AWS SDK to determine if an API call was
+ retried.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/util/RetryDetector.html#RetryDetector--">RetryDetector()</a></span> - Constructor for class org.apache.iceberg.aws.util.<a href="org/apache/iceberg/aws/util/RetryDetector.html" title="class in org.apache.iceberg.aws.util">RetryDetector</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ParquetValueReaders.ReusableEntry.html#ReusableEntry--">ReusableEntry()</a></span> - Constructor for class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ParquetValueReaders.ReusableEntry.html" title="class in org.apache.iceberg.parquet">ParquetValueReaders.ReusableEntry</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/ByteBuffers.html#reuse-java.nio.ByteBuffer-int-">reuse(ByteBuffer, int)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/ByteBuffers.html" title="class in org.apache.iceberg.util">ByteBuffers</a></dt>
@@ -18779,19 +19541,36 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/Tasks.Builder.html#revertWith-org.apache.iceberg.util.Tasks.Task-">revertWith(Tasks.Task&lt;I, ?&gt;)</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/Tasks.Builder.html" title="class in org.apache.iceberg.util">Tasks.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/FileRewriter.html#rewrite-java.util.List-">rewrite(List&lt;T&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions">FileRewriter</a></dt>
+<dd>
+<div class="block">Rewrite a group of files represented by the given list of scan tasks.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#REWRITE_ALL">REWRITE_ALL</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Rewrites all files, regardless of their size.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#REWRITE_ALL">REWRITE_ALL</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Overrides other options and forces rewriting of all provided files.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#REWRITE_ALL_DEFAULT">REWRITE_ALL_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#REWRITE_ALL_DEFAULT">REWRITE_ALL_DEFAULT</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#REWRITE_JOB_ORDER">REWRITE_JOB_ORDER</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>
 <div class="block">Forces the rewrite job order based on the value.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#REWRITE_JOB_ORDER">REWRITE_JOB_ORDER</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
+<dd>
+<div class="block">Forces the rewrite job order based on the value.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.html#REWRITE_JOB_ORDER_DEFAULT">REWRITE_JOB_ORDER_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#rewriteCoordinator--">rewriteCoordinator()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html#REWRITE_JOB_ORDER_DEFAULT">REWRITE_JOB_ORDER_DEFAULT</a></span> - Static variable in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/ActionsProvider.html#rewriteDataFiles-org.apache.iceberg.Table-">rewriteDataFiles(Table)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/ActionsProvider.html" title="interface in org.apache.iceberg.actions">ActionsProvider</a></dt>
 <dd>
@@ -18805,6 +19584,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkActions.html#rewriteDataFiles-org.apache.iceberg.Table-">rewriteDataFiles(Table)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkActions.html" title="class in org.apache.iceberg.spark.actions">SparkActions</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupFailureResult.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewriteDataFiles.FileGroupFailureResult</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>
+<div class="block">For a file group that failed to rewrite.</div>
+</dd>
 <dt><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewriteDataFiles.FileGroupInfo</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
 <div class="block">A description of a file group, when it was processed, and within which partition.</div>
@@ -18848,8 +19631,11 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#rewriteDeleteFiles-java.lang.Iterable-">rewriteDeleteFiles(Iterable&lt;DeleteFile&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Define how to rewrite the deletes.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html#rewriteFailures--">rewriteFailures()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.Result</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">RewriteFileGroup</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
 <div class="block">Container class representing a set of files to be rewritten by a RewriteAction and the new files
@@ -18859,6 +19645,7 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#rewriteFiles-java.util.List-">rewriteFiles(List&lt;FileScanTask&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Method which will rewrite files based on this particular RewriteStrategy's algorithm.</div>
 </dd>
 <dt><a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg"><span class="typeNameLink">RewriteFiles</span></a> - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -18867,22 +19654,22 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#rewriteFiles-java.util.Set-java.util.Set-">rewriteFiles(Set&lt;DataFile&gt;, Set&lt;DataFile&gt;)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
 <dd>
-<div class="block">Add a rewrite that replaces one set of data files with another set that contains the same data.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 2.0.0</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#rewriteFiles-java.util.Set-java.util.Set-long-">rewriteFiles(Set&lt;DataFile&gt;, Set&lt;DataFile&gt;, long)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
 <dd>
-<div class="block">Add a rewrite that replaces one set of data files with another set that contains the same data.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 2.0.0</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/RewriteFiles.html#rewriteFiles-java.util.Set-java.util.Set-java.util.Set-java.util.Set-">rewriteFiles(Set&lt;DataFile&gt;, Set&lt;DeleteFile&gt;, Set&lt;DataFile&gt;, Set&lt;DeleteFile&gt;)</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/RewriteFiles.html" title="interface in org.apache.iceberg">RewriteFiles</a></dt>
 <dd>
-<div class="block">Add a rewrite that replaces one set of files with another set that contains the same data.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 2.0.0</span></div>
+</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html#rewriteFiles-java.util.List-">rewriteFiles(List&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkBinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#rewriteFiles-java.util.List-">rewriteFiles(List&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#rewriteFiles-java.util.List-">rewriteFiles(List&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteManifests.html#rewriteIf-java.util.function.Predicate-">rewriteIf(Predicate&lt;ManifestFile&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteManifests.html" title="interface in org.apache.iceberg.actions">RewriteManifests</a></dt>
 <dd>
 <div class="block">Rewrites only manifests that match the given predicate.</div>
@@ -18948,44 +19735,116 @@
 <dd>
 <div class="block">An action for rewriting position delete files.</div>
 </dd>
+<dt><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupInfo.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeleteFiles.FileGroupInfo</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>
+<div class="block">A description of a position delete file group, when it was processed, and within which
+ partition.</div>
+</dd>
+<dt><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeleteFiles.FileGroupRewriteResult</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>
+<div class="block">For a particular position delete file group, the number of position delete files which are
+ newly created and the number of files which were formerly part of the table but have been
+ rewritten.</div>
+</dd>
 <dt><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeleteFiles.Result</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
 <div class="block">The action result that contains a summary of the execution.</div>
 </dd>
+<dt><a href="org/apache/iceberg/spark/procedures/RewritePositionDeleteFilesProcedure.html" title="class in org.apache.iceberg.spark.procedures"><span class="typeNameLink">RewritePositionDeleteFilesProcedure</span></a> - Class in <a href="org/apache/iceberg/spark/procedures/package-summary.html">org.apache.iceberg.spark.procedures</a></dt>
+<dd>
+<div class="block">A procedure that rewrites position delete files in a table.</div>
+</dd>
+<dt><a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions"><span class="typeNameLink">RewritePositionDeleteFilesSparkAction</span></a> - Class in <a href="org/apache/iceberg/spark/actions/package-summary.html">org.apache.iceberg.spark.actions</a></dt>
+<dd>
+<div class="block">Spark implementation of <a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions"><code>RewritePositionDeleteFiles</code></a>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/ActionsProvider.html#rewritePositionDeletes-org.apache.iceberg.Table-">rewritePositionDeletes(Table)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/ActionsProvider.html" title="interface in org.apache.iceberg.actions">ActionsProvider</a></dt>
+<dd>
+<div class="block">Instantiates an action to rewrite position delete files</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkActions.html#rewritePositionDeletes-org.apache.iceberg.Table-">rewritePositionDeletes(Table)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkActions.html" title="class in org.apache.iceberg.spark.actions">SparkActions</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeletesCommitManager</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>
+<div class="block">Functionality used by <a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions"><code>RewritePositionDeleteFiles</code></a> from different platforms to handle
+ commits.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html#RewritePositionDeletesCommitManager-org.apache.iceberg.Table-">RewritePositionDeletesCommitManager(Table)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeletesCommitManager.CommitService</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeletesGroup</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>
+<div class="block">Container class representing a set of position delete files to be rewritten by a <a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.html" title="interface in org.apache.iceberg.actions"><code>RewritePositionDeleteFiles</code></a> and the new files which have been written by the action.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#RewritePositionDeletesGroup-org.apache.iceberg.actions.RewritePositionDeleteFiles.FileGroupInfo-java.util.List-">RewritePositionDeletesGroup(RewritePositionDeleteFiles.FileGroupInfo, List&lt;PositionDeletesScanTask&gt;)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.act [...]
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewritePositionDeleteStrategy</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
-<div class="block">A strategy for an action to rewrite position delete files.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; Use <a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><code>SizeBasedFileRewriter</code></a> instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesResult.html#rewriteResults--">rewriteResults()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesResult.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html#rewriteResults--">rewriteResults()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.Result</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewriteStrategy</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html#rewriteResults--">rewriteResults()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.Result</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions"><span class="typeNameLink">RewriteStrategy</span></a> - Interface in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; use <a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions"><code>FileRewriter</code></a> instead.</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#REWRITTEN_FILE_SCAN_TASK_SET_ID">REWRITTEN_FILE_SCAN_TASK_SET_ID</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#rewrittenBytesCount--">rewrittenBytesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#rewrittenBytes--">rewrittenBytes()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#rewrittenBytesCount--">rewrittenBytesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html#rewrittenBytesCount--">rewrittenBytesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupRewriteResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html#rewrittenBytesCount--">rewrittenBytesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.Result</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html#rewrittenBytesCount--">rewrittenBytesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupRewriteResult</a></dt>
+<dd>
+<div class="block">Returns the number of bytes of rewritten position delete files in this group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html#rewrittenBytesCount--">rewrittenBytesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.Result</a></dt>
+<dd>
+<div class="block">Returns the number of bytes of position delete files that have been rewritten</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html#rewrittenDataFilesCount--">rewrittenDataFilesCount()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseFileGroupRewriteResult.html" title="class in org.apache.iceberg.actions">BaseFileGroupRewriteResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html#rewrittenDataFilesCount--">rewrittenDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.FileGroupRewriteResult</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html#rewrittenDataFilesCount--">rewrittenDataFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFiles.Result.html" title="interface in org.apache.iceberg.actions">RewriteDataFiles.Result</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#rewrittenDeleteFiles--">rewrittenDeleteFiles()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html#rewrittenDeleteFilesCount--">rewrittenDeleteFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.FileGroupRewriteResult.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.FileGroupRewriteResult</a></dt>
+<dd>
+<div class="block">Returns the count of the position delete files that been rewritten in this group.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html#rewrittenDeleteFilesCount--">rewrittenDeleteFilesCount()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteFiles.Result.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteFiles.Result</a></dt>
 <dd>
-<div class="block">Returns the count of the position deletes that been rewritten.</div>
+<div class="block">Returns the count of the position delete files that have been rewritten.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#rewrittenFiles--">rewrittenFiles()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#rewrittenFileSetId--">rewrittenFileSetId()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html#rewrittenManifests--">rewrittenManifests()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteManifestsActionResult.html" title="class in org.apache.iceberg.actions">BaseRewriteManifestsActionResult</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteManifests.Result.html#rewrittenManifests--">rewrittenManifests()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteManifests.Result.html" title="interface in org.apache.iceberg.actions">RewriteManifests.Result</a></dt>
 <dd>
 <div class="block">Returns rewritten manifests.</div>
@@ -19051,13 +19910,13 @@
 </dd>
 <dt><a href="org/apache/iceberg/flink/source/RowDataFileScanTaskReader.html" title="class in org.apache.iceberg.flink.source"><span class="typeNameLink">RowDataFileScanTaskReader</span></a> - Class in <a href="org/apache/iceberg/flink/source/package-summary.html">org.apache.iceberg.flink.source</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/RowDataFileScanTaskReader.html#RowDataFileScanTaskReader-org.apache.iceberg.Schema-org.apache.iceberg.Schema-java.lang.String-boolean-">RowDataFileScanTaskReader(Schema, Schema, String, boolean)</a></span> - Constructor for class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/RowDataFileScanTaskReader.html" title="class in org.apache.iceberg.flink.source">RowDataFileScanTaskReader</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/RowDataFileScanTaskReader.html#RowDataFileScanTaskReader-org.apache.iceberg.Schema-org.apache.iceberg.Schema-java.lang.String-boolean-java.util.List-">RowDataFileScanTaskReader(Schema, Schema, String, boolean, List&lt;Expression&gt;)</a></span> - Constructor for class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/RowDataFileScanTaskReader.html" title="class in org.apache.iceberg.flink.sou [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/flink/data/RowDataProjection.html" title="class in org.apache.iceberg.flink.data"><span class="typeNameLink">RowDataProjection</span></a> - Class in <a href="org/apache/iceberg/flink/data/package-summary.html">org.apache.iceberg.flink.data</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/flink/source/reader/RowDataReaderFunction.html" title="class in org.apache.iceberg.flink.source.reader"><span class="typeNameLink">RowDataReaderFunction</span></a> - Class in <a href="org/apache/iceberg/flink/source/reader/package-summary.html">org.apache.iceberg.flink.source.reader</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/RowDataReaderFunction.html#RowDataReaderFunction-org.apache.flink.configuration.ReadableConfig-org.apache.iceberg.Schema-org.apache.iceberg.Schema-java.lang.String-boolean-org.apache.iceberg.io.FileIO-org.apache.iceberg.encryption.EncryptionManager-">RowDataReaderFunction(ReadableConfig, Schema, Schema, String, boolean, FileIO, EncryptionManager)</a></span> - Constructor for class org.apache.iceberg.flink.so [...]
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/RowDataReaderFunction.html#RowDataReaderFunction-org.apache.flink.configuration.ReadableConfig-org.apache.iceberg.Schema-org.apache.iceberg.Schema-java.lang.String-boolean-org.apache.iceberg.io.FileIO-org.apache.iceberg.encryption.EncryptionManager-java.util.List-">RowDataReaderFunction(ReadableConfig, Schema, Schema, String, boolean, FileIO, EncryptionManager, List&lt;Expression&gt;)</a></span> - Constructo [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/flink/source/RowDataRewriter.html" title="class in org.apache.iceberg.flink.source"><span class="typeNameLink">RowDataRewriter</span></a> - Class in <a href="org/apache/iceberg/flink/source/package-summary.html">org.apache.iceberg.flink.source</a></dt>
 <dd>&nbsp;</dd>
@@ -19084,14 +19943,8 @@
 <dd>
 <div class="block">API for encoding row-level changes to a table.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html#rowId--">rowId()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html" title="interface in org.apache.spark.sql.connector.iceberg.write">SupportsDelta</a></dt>
-<dd>
-<div class="block">Returns the row ID column references that should be used for row equality.</div>
-</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html#rowIdSchema--">rowIdSchema()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html" title="interface in org.apache.spark.sql.connector.iceberg.write">ExtendedLogicalWriteInfo</a></dt>
-<dd>
-<div class="block">The schema of the ID columns from Spark to data source.</div>
-</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#rowIterator--">rowIterator()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/RowLevelOperationMode.html" title="enum in org.apache.iceberg"><span class="typeNameLink">RowLevelOperationMode</span></a> - Enum in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>
 <div class="block">Iceberg supports two ways to modify records in a table: copy-on-write and merge-on-read.</div>
@@ -19259,86 +20112,191 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/lakeformation/LakeFormationAwsClientFactory.html#s3--">s3()</a></span> - Method in class org.apache.iceberg.aws.lakeformation.<a href="org/apache/iceberg/aws/lakeformation/LakeFormationAwsClientFactory.html" title="class in org.apache.iceberg.aws.lakeformation">LakeFormationAwsClientFactory</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html#s3--">s3()</a></span> - Method in interface org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html" title="interface in org.apache.iceberg.aws.s3">S3FileIOAwsClientFactory</a></dt>
+<dd>
+<div class="block">create a Amazon S3 client</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_ACCELERATION_ENABLED">S3_ACCELERATION_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Determines if S3 client will use the Acceleration Mode, default to false.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_ACCELERATION_ENABLED_DEFAULT">S3_ACCELERATION_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_ACCESS_POINTS_PREFIX">S3_ACCESS_POINTS_PREFIX</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used by <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a>, prefix used for bucket access point configuration.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_CHECKSUM_ENABLED">S3_CHECKSUM_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Enables eTag checks for S3 PUT and MULTIPART upload requests.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_CHECKSUM_ENABLED_DEFAULT">S3_CHECKSUM_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DELETE_ENABLED">S3_DELETE_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Determines if <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a> deletes the object when io.delete() is called, default to true.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DELETE_ENABLED_DEFAULT">S3_DELETE_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DELETE_TAGS_PREFIX">S3_DELETE_TAGS_PREFIX</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used by <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a> to tag objects when deleting.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DUALSTACK_ENABLED">S3_DUALSTACK_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Determines if S3 client will use the Dualstack Mode, default to false.</div>
-</dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_DUALSTACK_ENABLED_DEFAULT">S3_DUALSTACK_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_PRELOAD_CLIENT_ENABLED">S3_PRELOAD_CLIENT_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">This flag controls whether the S3 client will be initialized during the S3FileIO
- initialization, instead of default lazy initialization upon use.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_PRELOAD_CLIENT_ENABLED_DEFAULT">S3_PRELOAD_CLIENT_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_REMOTE_SIGNING_ENABLED">S3_REMOTE_SIGNING_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_REMOTE_SIGNING_ENABLED_DEFAULT">S3_REMOTE_SIGNING_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html#S3_SIGNER_ENDPOINT">S3_SIGNER_ENDPOINT</a></span> - Static variable in class org.apache.iceberg.aws.s3.signer.<a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html" title="class in org.apache.iceberg.aws.s3.signer">S3V4RestSignerClient</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html#S3_SIGNER_URI">S3_SIGNER_URI</a></span> - Static variable in class org.apache.iceberg.aws.s3.signer.<a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html" title="class in org.apache.iceberg.aws.s3.signer">S3V4RestSignerClient</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_TAG_ICEBERG_NAMESPACE">S3_TAG_ICEBERG_NAMESPACE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Tag name that will be used by <a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TAGS_PREFIX"><code>AwsProperties.S3_WRITE_TAGS_PREFIX</code></a> when <a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_NAMESPACE_TAG_ENABLED"><code>AwsProperties.S3_WRITE_NAMESPACE_TAG_ENABLED</code></a> is enabled</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#S3_TAG_ICEBERG_NAMESPACE">S3_TAG_ICEBERG_NAMESPACE</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Tag name that will be used by <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TAGS_PREFIX"><code>S3FileIOProperties.WRITE_TAGS_PREFIX</code></a> when <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_NAMESPACE_TAG_ENABLED"><code>S3FileIOProperties.WRITE_NAMESPACE_TAG_ENABLED</code></a> is enabled</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_TAG_ICEBERG_TABLE">S3_TAG_ICEBERG_TABLE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Tag name that will be used by <a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TAGS_PREFIX"><code>AwsProperties.S3_WRITE_TAGS_PREFIX</code></a> when <a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TABLE_TAG_ENABLED"><code>AwsProperties.S3_WRITE_TABLE_TAG_ENABLED</code></a> is enabled</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#S3_TAG_ICEBERG_TABLE">S3_TAG_ICEBERG_TABLE</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Tag name that will be used by <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TAGS_PREFIX"><code>S3FileIOProperties.WRITE_TAGS_PREFIX</code></a> when <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TABLE_TAG_ENABLED"><code>S3FileIOProperties.WRITE_TABLE_TAG_ENABLED</code></a>
+ is enabled</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_USE_ARN_REGION_ENABLED">S3_USE_ARN_REGION_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Enable to make S3FileIO, to make cross-region call to the region specified in the ARN of an
- access point.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_USE_ARN_REGION_ENABLED_DEFAULT">S3_USE_ARN_REGION_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_NAMESPACE_TAG_ENABLED">S3_WRITE_NAMESPACE_TAG_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used by <a href="org/apache/iceberg/aws/glue/GlueCatalog.html" title="class in org.apache.iceberg.aws.glue"><code>GlueCatalog</code></a> to tag objects when writing.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_NAMESPACE_TAG_ENABLED_DEFAULT">S3_WRITE_NAMESPACE_TAG_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TABLE_TAG_ENABLED">S3_WRITE_TABLE_TAG_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used by <a href="org/apache/iceberg/aws/glue/GlueCatalog.html" title="class in org.apache.iceberg.aws.glue"><code>GlueCatalog</code></a> to tag objects when writing.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TABLE_TAG_ENABLED_DEFAULT">S3_WRITE_TABLE_TAG_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3_WRITE_TAGS_PREFIX">S3_WRITE_TAGS_PREFIX</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used by <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a> to tag objects when writing.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3BucketToAccessPointMapping--">s3BucketToAccessPointMapping()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientFactories.html#s3Configuration-java.lang.Boolean-java.lang.Boolean-">s3Configuration(Boolean, Boolean)</a></span> - Static method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientFactories.html" title="class in org.apache.iceberg.aws">AwsClientFactories</a></dt>
 <dd>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span>
@@ -19347,7 +20305,12 @@
 </div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3DeleteTags--">s3DeleteTags()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><span class="typeNameLink">S3FileIO</span></a> - Class in <a href="org/apache/iceberg/aws/s3/package-summary.html">org.apache.iceberg.aws.s3</a></dt>
 <dd>
 <div class="block">FileIO implementation backed by S3.</div>
@@ -19358,128 +20321,267 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIO.html#S3FileIO-org.apache.iceberg.util.SerializableSupplier-">S3FileIO(SerializableSupplier&lt;S3Client&gt;)</a></span> - Constructor for class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></dt>
 <dd>
-<div class="block">Constructor with custom s3 supplier and default AWS properties.</div>
+<div class="block">Constructor with custom s3 supplier and S3FileIO properties.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIO.html#S3FileIO-org.apache.iceberg.util.SerializableSupplier-org.apache.iceberg.aws.AwsProperties-">S3FileIO(SerializableSupplier&lt;S3Client&gt;, AwsProperties)</a></span> - Constructor for class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIO.html#S3FileIO-org.apache.iceberg.util.SerializableSupplier-org.apache.iceberg.aws.s3.S3FileIOProperties-">S3FileIO(SerializableSupplier&lt;S3Client&gt;, S3FileIOProperties)</a></span> - Constructor for class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3">S3FileIO</a></dt>
 <dd>
-<div class="block">Constructor with custom s3 supplier and AWS properties.</div>
+<div class="block">Constructor with custom s3 supplier and S3FileIO properties.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_ACCESS_KEY_ID">S3FILEIO_ACCESS_KEY_ID</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure the static access key ID used to access S3FileIO.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_ACL">S3FILEIO_ACL</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Used to configure canned access control list (ACL) for S3 client to use during write.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_BATCH_SIZE">S3FILEIO_DELETE_BATCH_SIZE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure the batch size used when deleting multiple files from a given S3 bucket</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_BATCH_SIZE_DEFAULT">S3FILEIO_DELETE_BATCH_SIZE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Default batch size used when deleting files.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_BATCH_SIZE_MAX">S3FILEIO_DELETE_BATCH_SIZE_MAX</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Max possible batch size for deletion.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_DELETE_THREADS">S3FILEIO_DELETE_THREADS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Number of threads to use for adding delete tags to S3 objects, default to <code>Runtime.availableProcessors()</code></div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_ENDPOINT">S3FILEIO_ENDPOINT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure an alternative endpoint of the S3 service for S3FileIO to access.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_SIZE">S3FILEIO_MULTIPART_SIZE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">The size of a single part for multipart upload requests in bytes (default: 32MB).</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_SIZE_DEFAULT">S3FILEIO_MULTIPART_SIZE_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_SIZE_MIN">S3FILEIO_MULTIPART_SIZE_MIN</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR">S3FILEIO_MULTIPART_THRESHOLD_FACTOR</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">The threshold expressed as a factor times the multipart size at which to switch from uploading
- using a single put object request to uploading using multipart upload (default: 1.5).</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT">S3FILEIO_MULTIPART_THRESHOLD_FACTOR_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_MULTIPART_UPLOAD_THREADS">S3FILEIO_MULTIPART_UPLOAD_THREADS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Number of threads to use for uploading parts to S3 (shared pool across all output streams),
- default to <code>Runtime.availableProcessors()</code></div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS">S3FILEIO_PATH_STYLE_ACCESS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">If set <code>true</code>, requests to S3FileIO will use Path-Style, otherwise, Virtual Hosted-Style
- will be used.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_PATH_STYLE_ACCESS_DEFAULT">S3FILEIO_PATH_STYLE_ACCESS_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SECRET_ACCESS_KEY">S3FILEIO_SECRET_ACCESS_KEY</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure the static secret access key used to access S3FileIO.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SESSION_TOKEN">S3FILEIO_SESSION_TOKEN</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Configure the static session token used to access S3FileIO.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_KEY">S3FILEIO_SSE_KEY</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">If S3 encryption type is SSE-KMS, input is a KMS Key ID or ARN.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_MD5">S3FILEIO_SSE_MD5</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">If S3 encryption type is SSE-C, input is the base-64 MD5 digest of the secret key.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE">S3FILEIO_SSE_TYPE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Type of S3 Server side encryption used, default to <a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_NONE"><code>AwsProperties.S3FILEIO_SSE_TYPE_NONE</code></a>.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_CUSTOM">S3FILEIO_SSE_TYPE_CUSTOM</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">S3 SSE-C encryption.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_KMS">S3FILEIO_SSE_TYPE_KMS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">S3 SSE-KMS encryption.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_NONE">S3FILEIO_SSE_TYPE_NONE</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">No server side encryption.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_SSE_TYPE_S3">S3FILEIO_SSE_TYPE_S3</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">S3 SSE-S3 encryption.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#S3FILEIO_STAGING_DIRECTORY">S3FILEIO_STAGING_DIRECTORY</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>
-<div class="block">Location to put staging files for upload to S3, default to temp directory set in
- java.io.tmpdir.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoAcl--">s3FileIoAcl()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/iceberg/aws/S3FileIOAwsClientFactories.html" title="class in org.apache.iceberg.aws"><span class="typeNameLink">S3FileIOAwsClientFactories</span></a> - Class in <a href="org/apache/iceberg/aws/package-summary.html">org.apache.iceberg.aws</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoDeleteBatchSize--">s3FileIoDeleteBatchSize()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dt><a href="org/apache/iceberg/aws/s3/S3FileIOAwsClientFactory.html" title="interface in org.apache.iceberg.aws.s3"><span class="typeNameLink">S3FileIOAwsClientFactory</span></a> - Interface in <a href="org/apache/iceberg/aws/s3/package-summary.html">org.apache.iceberg.aws.s3</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoDeleteBatchSize--">s3FileIoDeleteBatchSize()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoDeleteThreads--">s3FileIoDeleteThreads()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoMultiPartSize--">s3FileIoMultiPartSize()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIOMultipartThresholdFactor--">s3FileIOMultipartThresholdFactor()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoMultipartUploadThreads--">s3FileIoMultipartUploadThreads()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><span class="typeNameLink">S3FileIOProperties</span></a> - Class in <a href="org/apache/iceberg/aws/s3/package-summary.html">org.apache.iceberg.aws.s3</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseKey--">s3FileIoSseKey()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#S3FileIOProperties--">S3FileIOProperties()</a></span> - Constructor for class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseMd5--">s3FileIoSseMd5()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#S3FileIOProperties-java.util.Map-">S3FileIOProperties(Map&lt;String, String&gt;)</a></span> - Constructor for class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseKey--">s3FileIoSseKey()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseMd5--">s3FileIoSseMd5()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3FileIoSseType--">s3FileIoSseType()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3fileIoStagingDirectory--">s3fileIoStagingDirectory()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3"><span class="typeNameLink">S3InputFile</span></a> - Class in <a href="org/apache/iceberg/aws/s3/package-summary.html">org.apache.iceberg.aws.s3</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/aws/s3/signer/S3ObjectMapper.html" title="class in org.apache.iceberg.aws.s3.signer"><span class="typeNameLink">S3ObjectMapper</span></a> - Class in <a href="org/apache/iceberg/aws/s3/signer/package-summary.html">org.apache.iceberg.aws.s3.signer</a></dt>
@@ -19495,7 +20597,12 @@
 <dt><a href="org/apache/iceberg/aws/s3/S3OutputFile.html" title="class in org.apache.iceberg.aws.s3"><span class="typeNameLink">S3OutputFile</span></a> - Class in <a href="org/apache/iceberg/aws/s3/package-summary.html">org.apache.iceberg.aws.s3</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3PreloadClientEnabled--">s3PreloadClientEnabled()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><a href="org/apache/iceberg/aws/s3/S3RequestUtil.html" title="class in org.apache.iceberg.aws.s3"><span class="typeNameLink">S3RequestUtil</span></a> - Class in <a href="org/apache/iceberg/aws/s3/package-summary.html">org.apache.iceberg.aws.s3</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/aws/s3/signer/S3SignRequest.html" title="interface in org.apache.iceberg.aws.s3.signer"><span class="typeNameLink">S3SignRequest</span></a> - Interface in <a href="org/apache/iceberg/aws/s3/signer/package-summary.html">org.apache.iceberg.aws.s3.signer</a></dt>
@@ -19519,11 +20626,26 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html#S3V4RestSignerClient--">S3V4RestSignerClient()</a></span> - Constructor for class org.apache.iceberg.aws.s3.signer.<a href="org/apache/iceberg/aws/s3/signer/S3V4RestSignerClient.html" title="class in org.apache.iceberg.aws.s3.signer">S3V4RestSignerClient</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3WriteNamespaceTagEnabled--">s3WriteNamespaceTagEnabled()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3WriteTableTagEnabled--">s3WriteTableTagEnabled()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#s3WriteTags--">s3WriteTags()</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SortOrder.html#sameOrder-org.apache.iceberg.SortOrder-">sameOrder(SortOrder)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SortOrder.html" title="class in org.apache.iceberg">SortOrder</a></dt>
 <dd>
 <div class="block">Checks whether this order is equivalent to another order while ignoring the order id.</div>
@@ -19806,10 +20928,9 @@
 <div class="block">Return the id of the schema used when this snapshot was created, or null if this information is
  not available.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/view/SQLViewRepresentation.html#schemaId--">schemaId()</a></span> - Method in interface org.apache.iceberg.view.<a href="org/apache/iceberg/view/SQLViewRepresentation.html" title="interface in org.apache.iceberg.view">SQLViewRepresentation</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/view/ViewVersion.html#schemaId--">schemaId()</a></span> - Method in interface org.apache.iceberg.view.<a href="org/apache/iceberg/view/ViewVersion.html" title="interface in org.apache.iceberg.view">ViewVersion</a></dt>
 <dd>
-<div class="block">The query output schema ID at version create time, without aliases or null if no schema is
- defined</div>
+<div class="block">The query output schema at version create time, without aliases</div>
 </dd>
 <dt><a href="org/apache/iceberg/SchemaParser.html" title="class in org.apache.iceberg"><span class="typeNameLink">SchemaParser</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
 <dd>&nbsp;</dd>
@@ -19857,6 +20978,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/Pair.html#second--">second()</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/Pair.html" title="class in org.apache.iceberg.util">Pair</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SECRET_ACCESS_KEY">SECRET_ACCESS_KEY</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure the static secret access key used to access S3FileIO.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#secretAccessKey--">secretAccessKey()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/DataIterator.html#seek-int-long-">seek(int, long)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/DataIterator.html" title="class in org.apache.iceberg.flink.source">DataIterator</a></dt>
 <dd>
 <div class="block">(startingFileOffset, startingRecordOffset) points to the next row that reader should resume
@@ -19909,6 +21036,7 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#selectDeleteFiles-java.lang.Iterable-">selectDeleteFiles(Iterable&lt;DeleteFile&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Select the delete files to rewrite.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/InputFormatConfig.html#SELECTED_COLUMNS">SELECTED_COLUMNS</a></span> - Static variable in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr">InputFormatConfig</a></dt>
@@ -19916,9 +21044,12 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/InputFormatConfig.html#selectedColumns-org.apache.hadoop.conf.Configuration-">selectedColumns(Configuration)</a></span> - Static method in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr">InputFormatConfig</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#selectFilesToRewrite-java.lang.Iterable-">selectFilesToRewrite(Iterable&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#selectFilesToRewrite-java.lang.Iterable-">selectFilesToRewrite(Iterable&lt;FileScanTask&gt;)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Selects files which this strategy believes are valid targets to be rewritten.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/TypeUtil.html#selectNot-org.apache.iceberg.types.Types.StructType-java.util.Set-">selectNot(Types.StructType, Set&lt;Integer&gt;)</a></span> - Static method in class org.apache.iceberg.types.<a href="org/apache/iceberg/types/TypeUtil.html" title="class in org.apache.iceberg.types">TypeUtil</a></dt>
@@ -19955,6 +21086,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html#self--">self()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewriteManifestsSparkAction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html#self--">self()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewritePositionDeleteFilesSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewritePositionDeleteFilesSparkAction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html#self--">self()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SnapshotTableSparkAction.html" title="class in org.apache.iceberg.spark.actions">SnapshotTableSparkAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/StreamingDelete.html#self--">self()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/StreamingDelete.html" title="class in org.apache.iceberg">StreamingDelete</a></dt>
@@ -19991,8 +21124,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/SerializableConfiguration.html#SerializableConfiguration-org.apache.hadoop.conf.Configuration-">SerializableConfiguration(Configuration)</a></span> - Constructor for class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/SerializableConfiguration.html" title="class in org.apache.iceberg.hadoop">SerializableConfiguration</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#serializableFileIO-org.apache.iceberg.Table-">serializableFileIO(Table)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
-<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/util/SerializableFunction.html" title="interface in org.apache.iceberg.util"><span class="typeNameLink">SerializableFunction</span></a>&lt;<a href="org/apache/iceberg/util/SerializableFunction.html" title="type parameter in SerializableFunction">S</a>,<a href="org/apache/iceberg/util/SerializableFunction.html" title="type parameter in SerializableFunction">T</a>&gt; - Interface in <a href="org/apache/iceberg/util/package-summary.html">org.apache.iceberg.ut [...]
 <dd>
 <div class="block">A concrete transform function that applies a transform to values of a certain type.</div>
@@ -20079,6 +21210,10 @@
 <dd>
 <div class="block">An async service which allows for committing multiple file groups as their rewrites complete.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html#service-int-">service(int)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesCommitManager.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesCommitManager</a></dt>
+<dd>
+<div class="block">An async service which allows for committing multiple file groups as their rewrites complete.</div>
+</dd>
 <dt><a href="org/apache/iceberg/exceptions/ServiceFailureException.html" title="class in org.apache.iceberg.exceptions"><span class="typeNameLink">ServiceFailureException</span></a> - Exception in <a href="org/apache/iceberg/exceptions/package-summary.html">org.apache.iceberg.exceptions</a></dt>
 <dd>
 <div class="block">Exception thrown on HTTP 5XX Server Error.</div>
@@ -20097,6 +21232,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/exceptions/ServiceUnavailableException.html#ServiceUnavailableException-java.lang.Throwable-java.lang.String-java.lang.Object...-">ServiceUnavailableException(Throwable, String, Object...)</a></span> - Constructor for exception org.apache.iceberg.exceptions.<a href="org/apache/iceberg/exceptions/ServiceUnavailableException.html" title="class in org.apache.iceberg.exceptions">ServiceUnavailableException</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SESSION_TOKEN">SESSION_TOKEN</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Configure the static session token used to access S3FileIO.</div>
+</dd>
 <dt><a href="org/apache/iceberg/catalog/SessionCatalog.html" title="interface in org.apache.iceberg.catalog"><span class="typeNameLink">SessionCatalog</span></a> - Interface in <a href="org/apache/iceberg/catalog/package-summary.html">org.apache.iceberg.catalog</a></dt>
 <dd>
 <div class="block">A Catalog API for table and namespace operations that includes session context.</div>
@@ -20113,6 +21252,8 @@
 <dd>
 <div class="block">Returns a string that identifies this session.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#sessionToken--">sessionToken()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SnapshotUpdateAction.html#set-java.lang.String-java.lang.String-">set(String, String)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SnapshotUpdateAction.html" title="interface in org.apache.iceberg.actions">SnapshotUpdateAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.DataWriteBuilder.html#set-java.lang.String-java.lang.String-">set(String, String)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.DataWriteBuilder.html" title="class in org.apache.iceberg.avro">Avro.DataWriteBuilder</a></dt>
@@ -20233,6 +21374,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SetAccumulator.html#SetAccumulator--">SetAccumulator()</a></span> - Constructor for class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SetAccumulator.html" title="class in org.apache.iceberg.spark.actions">SetAccumulator</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setAcl-software.amazon.awssdk.services.s3.model.ObjectCannedACL-">setAcl(ObjectCannedACL)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/ManifestFileBean.html#setAddedSnapshotId-java.lang.Long-">setAddedSnapshotId(Long)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/ManifestFileBean.html" title="class in org.apache.iceberg.spark.actions">ManifestFileBean</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/Avro.DataWriteBuilder.html#setAll-java.util.Map-">setAll(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/Avro.DataWriteBuilder.html" title="class in org.apache.iceberg.avro">Avro.DataWriteBuilder</a></dt>
@@ -20307,6 +21450,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.Builder.html#setBranchSnapshot-long-java.lang.String-">setBranchSnapshot(long, String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.Builder.html" title="class in org.apache.iceberg">TableMetadata.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setChecksumEnabled-boolean-">setChecksumEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsClientProperties.html#setClientRegion-java.lang.String-">setClientRegion(String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsClientProperties.html" title="class in org.apache.iceberg.aws">AwsClientProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setClientRegion-java.lang.String-">setClientRegion(String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ColumnWriter.html#setColumnStore-org.apache.parquet.column.ColumnWriteStore-">setColumnStore(ColumnWriteStore)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ColumnWriter.html" title="class in org.apache.iceberg.parquet">ColumnWriter</a></dt>
@@ -20341,32 +21488,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#setConf-java.lang.Object-">setConf(Object)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">setConf(Configuration)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/jdbc/JdbcCatalog.html#setConf-java.lang.Object-"><code>JdbcCatalog.setConf(Object)</code></a></span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/hive/HiveIcebergStorageHandler.html#setConf-org.apache.hadoop.conf.Configuration-">setConf(Configuration)</a></span> - Method in class org.apache.iceberg.mr.hive.<a href="org/apache/iceberg/mr/hive/HiveIcebergStorageHandler.html" title="class in org.apache.iceberg.mr.hive">HiveIcebergStorageHandler</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">setConf(Configuration)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/nessie/NessieCatalog.html#setConf-java.lang.Object-">setConf(Object)</a></span> - Method in class org.apache.iceberg.nessie.<a href="org/apache/iceberg/nessie/NessieCatalog.html" title="class in org.apache.iceberg.nessie">NessieCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/RESTCatalog.html#setConf-java.lang.Object-">setConf(Object)</a></span> - Method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/RESTCatalog.html" title="class in org.apache.iceberg.rest">RESTCatalog</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/RESTCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">setConf(Configuration)</a></span> - Method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/RESTCatalog.html" title="class in org.apache.iceberg.rest">RESTCatalog</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/RESTCatalog.html#setConf-java.lang.Object-"><code>RESTCatalog.setConf(Object)</code></a></span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/RESTSessionCatalog.html#setConf-java.lang.Object-">setConf(Object)</a></span> - Method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/RESTSessionCatalog.html" title="class in org.apache.iceberg.rest">RESTSessionCatalog</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/RESTSessionCatalog.html#setConf-org.apache.hadoop.conf.Configuration-">setConf(Configuration)</a></span> - Method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/RESTSessionCatalog.html" title="class in org.apache.iceberg.rest">RESTSessionCatalog</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use <a href="org/apache/iceberg/rest/RESTSessionCatalog.html#setConf-java.lang.Object-"><code>RESTSessionCatalog.setConf(Object)</code></a></span></div>
-</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/snowflake/SnowflakeCatalog.html#setConf-java.lang.Object-">setConf(Object)</a></span> - Method in class org.apache.iceberg.snowflake.<a href="org/apache/iceberg/snowflake/SnowflakeCatalog.html" title="class in org.apache.iceberg.snowflake">SnowflakeCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/ManifestFileBean.html#setContent-java.lang.Integer-">setContent(Integer)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/ManifestFileBean.html" title="class in org.apache.iceberg.spark.actions">ManifestFileBean</a></dt>
@@ -20397,8 +21526,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#setDelegateCatalog-org.apache.spark.sql.connector.catalog.CatalogPlugin-">setDelegateCatalog(CatalogPlugin)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setDeleteBatchSize-int-">setDeleteBatchSize(int)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setDeleteEnabled-boolean-">setDeleteEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/vectorized/ColumnarBatchReader.html#setDeleteFilter-org.apache.iceberg.data.DeleteFilter-">setDeleteFilter(DeleteFilter&lt;InternalRow&gt;)</a></span> - Method in class org.apache.iceberg.spark.data.vectorized.<a href="org/apache/iceberg/spark/data/vectorized/ColumnarBatchReader.html" title="class in org.apache.iceberg.spark.data.vectorized">ColumnarBatchReader</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setDeleteThreads-int-">setDeleteThreads(int)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BasePageIterator.html#setDictionary-org.apache.parquet.column.Dictionary-">setDictionary(Dictionary)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BasePageIterator.html" title="class in org.apache.iceberg.parquet">BasePageIterator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/ParquetValueReaders.StructReader.html#setDouble-I-int-double-">setDouble(I, int, double)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/ParquetValueReaders.StructReader.html" title="class in org.apache.iceberg.parquet">ParquetValueReaders.StructReader</a></dt>
@@ -20481,6 +21616,12 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/SnapshotManager.html#setMinSnapshotsToKeep-java.lang.String-int-">setMinSnapshotsToKeep(String, int)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/SnapshotManager.html" title="class in org.apache.iceberg">SnapshotManager</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setMultiPartSize-int-">setMultiPartSize(int)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setMultipartThresholdFactor-double-">setMultipartThresholdFactor(double)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setMultipartUploadThreads-int-">setMultipartUploadThreads(int)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3InputFile.html#setNativeCryptoParameters-org.apache.iceberg.encryption.NativeFileCryptoParameters-">setNativeCryptoParameters(NativeFileCryptoParameters)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3InputFile.html" title="class in org.apache.iceberg.aws.s3">S3InputFile</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3OutputFile.html#setNativeCryptoParameters-org.apache.iceberg.encryption.NativeFileCryptoParameters-">setNativeCryptoParameters(NativeFileCryptoParameters)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3OutputFile.html" title="class in org.apache.iceberg.aws.s3">S3OutputFile</a></dt>
@@ -20505,6 +21646,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#setOutputFiles-java.util.Set-">setOutputFiles(Set&lt;DataFile&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#setOutputFiles-java.util.Set-">setOutputFiles(Set&lt;DeleteFile&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BasePageIterator.html#setPage-org.apache.parquet.column.page.DataPage-">setPage(DataPage)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BasePageIterator.html" title="class in org.apache.iceberg.parquet">BasePageIterator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/BaseColumnIterator.html#setPageSource-org.apache.parquet.column.page.PageReader-">setPageSource(PageReader)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/BaseColumnIterator.html" title="class in org.apache.iceberg.parquet">BaseColumnIterator</a></dt>
@@ -20533,6 +21676,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/ManifestFileBean.html#setPath-java.lang.String-">setPath(String)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/ManifestFileBean.html" title="class in org.apache.iceberg.spark.actions">ManifestFileBean</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setPreloadClientEnabled-boolean-">setPreloadClientEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.Builder.html#setPreviousFileLocation-java.lang.String-">setPreviousFileLocation(String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.Builder.html" title="class in org.apache.iceberg">TableMetadata.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/dynamodb/DynamoDbCatalog.html#setProperties-org.apache.iceberg.catalog.Namespace-java.util.Map-">setProperties(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.aws.dynamodb.<a href="org/apache/iceberg/aws/dynamodb/DynamoDbCatalog.html" title="class in org.apache.iceberg.aws.dynamodb">DynamoDbCatalog</a></dt>
@@ -20551,6 +21696,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveCatalog.html#setProperties-org.apache.iceberg.catalog.Namespace-java.util.Map-">setProperties(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveCatalog.html" title="class in org.apache.iceberg.hive">HiveCatalog</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryCatalog.html#setProperties-org.apache.iceberg.catalog.Namespace-java.util.Map-">setProperties(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryCatalog.html" title="class in org.apache.iceberg.inmemory">InMemoryCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/jdbc/JdbcCatalog.html#setProperties-org.apache.iceberg.catalog.Namespace-java.util.Map-">setProperties(Namespace, Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.jdbc.<a href="org/apache/iceberg/jdbc/JdbcCatalog.html" title="class in org.apache.iceberg.jdbc">JdbcCatalog</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.SetProperties.html#SetProperties-java.util.Map-">SetProperties(Map&lt;String, String&gt;)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.SetProperties.html" title="class in org.apache.iceberg">MetadataUpdate.SetProperties</a></dt>
@@ -20612,35 +21759,110 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/SparkAvroReader.html#setRowPositionSupplier-java.util.function.Supplier-">setRowPositionSupplier(Supplier&lt;Long&gt;)</a></span> - Method in class org.apache.iceberg.spark.data.<a href="org/apache/iceberg/spark/data/SparkAvroReader.html" title="class in org.apache.iceberg.spark.data">SparkAvroReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3ChecksumEnabled-boolean-">setS3ChecksumEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3DeleteEnabled-boolean-">setS3DeleteEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoAcl-software.amazon.awssdk.services.s3.model.ObjectCannedACL-">setS3FileIoAcl(ObjectCannedACL)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoDeleteBatchSize-int-">setS3FileIoDeleteBatchSize(int)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoDeleteThreads-int-">setS3FileIoDeleteThreads(int)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoMultiPartSize-int-">setS3FileIoMultiPartSize(int)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoMultipartThresholdFactor-double-">setS3FileIoMultipartThresholdFactor(double)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoMultipartUploadThreads-int-">setS3FileIoMultipartUploadThreads(int)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoSseKey-java.lang.String-">setS3FileIoSseKey(String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoSseMd5-java.lang.String-">setS3FileIoSseMd5(String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3FileIoSseType-java.lang.String-">setS3FileIoSseType(String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3fileIoStagingDirectory-java.lang.String-">setS3fileIoStagingDirectory(String)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3PreloadClientEnabled-boolean-">setS3PreloadClientEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3WriteNamespaceTagEnabled-boolean-">setS3WriteNamespaceTagEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/AwsProperties.html#setS3WriteTableTagEnabled-boolean-">setS3WriteTableTagEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/AwsProperties.html" title="class in org.apache.iceberg.aws">AwsProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0, use <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIOProperties</code></a>
+     instead</span></div>
+</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/ProjectionDatumReader.html#setSchema-org.apache.avro.Schema-">setSchema(Schema)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/ProjectionDatumReader.html" title="class in org.apache.iceberg.avro">ProjectionDatumReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/avro/DataReader.html#setSchema-org.apache.avro.Schema-">setSchema(Schema)</a></span> - Method in class org.apache.iceberg.data.avro.<a href="org/apache/iceberg/data/avro/DataReader.html" title="class in org.apache.iceberg.data.avro">DataReader</a></dt>
@@ -20665,6 +21887,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableMetadata.Builder.html#setSnapshotsSupplier-org.apache.iceberg.util.SerializableSupplier-">setSnapshotsSupplier(SerializableSupplier&lt;List&lt;Snapshot&gt;&gt;)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/TableMetadata.Builder.html" title="class in org.apache.iceberg">TableMetadata.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setSseKey-java.lang.String-">setSseKey(String)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setSseMd5-java.lang.String-">setSseMd5(String)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setSseType-java.lang.String-">setSseType(String)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setStagingDirectory-java.lang.String-">setStagingDirectory(String)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataUpdate.SetStatistics.html#SetStatistics-long-org.apache.iceberg.StatisticsFile-">SetStatistics(long, StatisticsFile)</a></span> - Constructor for class org.apache.iceberg.<a href="org/apache/iceberg/MetadataUpdate.SetStatistics.html" title="class in org.apache.iceberg">MetadataUpdate.SetStatistics</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/SetStatistics.html" title="class in org.apache.iceberg"><span class="typeNameLink">SetStatistics</span></a> - Class in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -20701,6 +21931,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.SetWriteDistributionAndOrderingContext.html#SetWriteDistributionAndOrderingContext-org.apache.spark.sql.catalyst.parser.extensions.IcebergSqlExtensionsParser.StatementContext-">SetWriteDistributionAndOrderingContext(IcebergSqlExtensionsParser.StatementContext)</a></span> - Constructor for class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/c [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setWriteNamespaceTagEnabled-boolean-">setWriteNamespaceTagEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#setWriteTableTagEnabled-boolean-">setWriteTableTagEnabled(boolean)</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/IcebergSource.html#shortName--">shortName()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/IcebergSource.html" title="class in org.apache.iceberg.spark.source">IcebergSource</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/ValueWriters.html#shorts--">shorts()</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/ValueWriters.html" title="class in org.apache.iceberg.avro">ValueWriters</a></dt>
@@ -20821,6 +22055,20 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/StructProjection.html#size--">size()</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/StructProjection.html" title="class in org.apache.iceberg.util">StructProjection</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">SizeBasedDataRewriter</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#SizeBasedDataRewriter-org.apache.iceberg.Table-">SizeBasedDataRewriter(Table)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">SizeBasedFileRewriter</span></a>&lt;<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="type parameter in SizeBasedFileRewriter">T</a> extends <a href="org/apache/iceberg/ContentScanTask.html" title="interface in org.apache.iceberg">ContentScanTask</a>&lt;<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="type pa [...]
+<dd>
+<div class="block">A file rewriter that determines which files to rewrite based on their size.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#SizeBasedFileRewriter-org.apache.iceberg.Table-">SizeBasedFileRewriter(Table)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">SizeBasedPositionDeletesRewriter</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html#SizeBasedPositionDeletesRewriter-org.apache.iceberg.Table-">SizeBasedPositionDeletesRewriter(Table)</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedPositionDeletesRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/AddedRowsScanTask.html#sizeBytes--">sizeBytes()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/AddedRowsScanTask.html" title="interface in org.apache.iceberg">AddedRowsScanTask</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ContentScanTask.html#sizeBytes--">sizeBytes()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ContentScanTask.html" title="interface in org.apache.iceberg">ContentScanTask</a></dt>
@@ -20837,8 +22085,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ScanTaskGroup.html#sizeBytes--">sizeBytes()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ScanTaskGroup.html" title="interface in org.apache.iceberg">ScanTaskGroup</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#sizeEstimateMultiple--">sizeEstimateMultiple()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#sizeInBytes--">sizeInBytes()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MicroBatches.MicroBatch.html#sizeInBytes--">sizeInBytes()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/MicroBatches.MicroBatch.html" title="class in org.apache.iceberg">MicroBatches.MicroBatch</a></dt>
@@ -20875,6 +22121,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/metrics/ScanMetricsResult.html#skippedDeleteManifests--">skippedDeleteManifests()</a></span> - Method in interface org.apache.iceberg.metrics.<a href="org/apache/iceberg/metrics/ScanMetricsResult.html" title="interface in org.apache.iceberg.metrics">ScanMetricsResult</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/MicroBatches.html#skippedManifestIndexesFromSnapshot-org.apache.iceberg.io.FileIO-org.apache.iceberg.Snapshot-long-boolean-">skippedManifestIndexesFromSnapshot(FileIO, Snapshot, long, boolean)</a></span> - Static method in class org.apache.iceberg.<a href="org/apache/iceberg/MicroBatches.html" title="class in org.apache.iceberg">MicroBatches</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/InputFormatConfig.ConfigBuilder.html#skipResidualFiltering--">skipResidualFiltering()</a></span> - Method in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/InputFormatConfig.ConfigBuilder.html" title="class in org.apache.iceberg.mr">InputFormatConfig.ConfigBuilder</a></dt>
 <dd>
 <div class="block">Compute platforms pass down filters to data sources.</div>
@@ -21196,10 +22444,13 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#sortOrder-org.apache.iceberg.SortOrder-">sortOrder(SortOrder)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Sets the sort order to be used in this strategy when rewriting files</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#sortOrder--">sortOrder()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetadataTable.html#sortOrder--">sortOrder()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetadataTable.html" title="class in org.apache.iceberg">BaseMetadataTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseTable.html#sortOrder--">sortOrder()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseTable.html" title="class in org.apache.iceberg">BaseTable</a></dt>
@@ -21214,8 +22465,6 @@
 <dd>
 <div class="block">A sort order that defines how data and delete files should be ordered in a table.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#sortOrder--">sortOrder()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/Table.html#sortOrder--">sortOrder()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/Table.html" title="interface in org.apache.iceberg">Table</a></dt>
 <dd>
 <div class="block">Return the <a href="org/apache/iceberg/SortOrder.html" title="class in org.apache.iceberg"><code>sort order</code></a> for this table.</div>
@@ -21266,15 +22515,16 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/transforms/SortOrderVisitor.html" title="interface in org.apache.iceberg.transforms"><span class="typeNameLink">SortOrderVisitor</span></a>&lt;<a href="org/apache/iceberg/transforms/SortOrderVisitor.html" title="type parameter in SortOrderVisitor">T</a>&gt; - Interface in <a href="org/apache/iceberg/transforms/package-summary.html">org.apache.iceberg.transforms</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#sortPlan-org.apache.spark.sql.connector.distributions.Distribution-org.apache.spark.sql.connector.expressions.SortOrder:A-org.apache.spark.sql.catalyst.plans.logical.LogicalPlan-org.apache.spark.sql.internal.SQLConf-">sortPlan(Distribution, SortOrder[], LogicalPlan, SQLConf)</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrat [...]
-<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions"><span class="typeNameLink">SortStrategy</span></a> - Class in <a href="org/apache/iceberg/actions/package-summary.html">org.apache.iceberg.actions</a></dt>
 <dd>
-<div class="block">A rewrite strategy for data files which aims to reorder data with data files to optimally lay
- them out in relation to a column.</div>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">since 1.3.0, will be removed in 1.4.0; use <a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions"><code>SizeBasedFileRewriter</code></a> instead.</span></div>
+</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#SortStrategy--">SortStrategy()</a></span> - Constructor for class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/RenameTableRequest.html#source--">source()</a></span> - Method in class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/RenameTableRequest.html" title="class in org.apache.iceberg.rest.requests">RenameTableRequest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkConfigOptions.html#SOURCE_READER_FETCH_BATCH_RECORD_COUNT">SOURCE_READER_FETCH_BATCH_RECORD_COUNT</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkConfigOptions.html" title="class in org.apache.iceberg.flink">FlinkConfigOptions</a></dt>
@@ -21301,8 +22551,6 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/GenericBlobMetadata.html#sourceSnapshotSequenceNumber--">sourceSnapshotSequenceNumber()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/GenericBlobMetadata.html" title="class in org.apache.iceberg">GenericBlobMetadata</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#spark--">spark()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">Spark3Util</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/Spark3Util.CatalogAndIdentifier.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">Spark3Util.CatalogAndIdentifier</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
@@ -21337,10 +22585,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/SparkAvroWriter.html#SparkAvroWriter-org.apache.spark.sql.types.StructType-">SparkAvroWriter(StructType)</a></span> - Constructor for class org.apache.iceberg.spark.data.<a href="org/apache/iceberg/spark/data/SparkAvroWriter.html" title="class in org.apache.iceberg.spark.data">SparkAvroWriter</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html" title="class in org.apache.iceberg.spark.actions"><span class="typeNameLink">SparkBinPackStrategy</span></a> - Class in <a href="org/apache/iceberg/spark/actions/package-summary.html">org.apache.iceberg.spark.actions</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html#SparkBinPackStrategy-org.apache.iceberg.Table-org.apache.spark.sql.SparkSession-">SparkBinPackStrategy(Table, SparkSession)</a></span> - Constructor for class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkBinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/SparkCachedTableCatalog.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkCachedTableCatalog</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>
 <div class="block">An internal table catalog that is capable of loading tables from a cache.</div>
@@ -21363,12 +22607,16 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkDataFile.html#SparkDataFile-org.apache.iceberg.types.Types.StructType-org.apache.iceberg.types.Types.StructType-org.apache.spark.sql.types.StructType-">SparkDataFile(Types.StructType, Types.StructType, StructType)</a></span> - Constructor for class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkDataFile.html" title="class in org.apache.iceberg.spark">SparkDataFile</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkDistributionAndOrderingUtil</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
-<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/SparkExceptionUtil.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkExceptionUtil</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/SparkFilters.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkFilters</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkFunctionCatalog</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
+<dd>
+<div class="block">A function catalog that can be used to resolve Iceberg functions without a metastore connection.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkFunctionCatalog.html#SparkFunctionCatalog--">SparkFunctionCatalog()</a></span> - Constructor for class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkFunctionCatalog.html" title="class in org.apache.iceberg.spark">SparkFunctionCatalog</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/SparkFunctions.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">SparkFunctions</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/source/SparkMetadataColumn.html" title="class in org.apache.iceberg.spark.source"><span class="typeNameLink">SparkMetadataColumn</span></a> - Class in <a href="org/apache/iceberg/spark/source/package-summary.html">org.apache.iceberg.spark.source</a></dt>
@@ -21407,6 +22655,16 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkPartitionedWriter.html#SparkPartitionedWriter-org.apache.iceberg.PartitionSpec-org.apache.iceberg.FileFormat-org.apache.iceberg.io.FileAppenderFactory-org.apache.iceberg.io.OutputFileFactory-org.apache.iceberg.io.FileIO-long-org.apache.iceberg.Schema-org.apache.spark.sql.types.StructType-">SparkPartitionedWriter(PartitionSpec, FileFormat, FileAppenderFactory&lt;InternalRow&gt;, OutputFileFactory, FileIO, long, [...]
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.html" title="class in org.apache.iceberg.spark.source"><span class="typeNameLink">SparkPositionDeletesRewrite</span></a> - Class in <a href="org/apache/iceberg/spark/source/package-summary.html">org.apache.iceberg.spark.source</a></dt>
+<dd>
+<div class="block"><code>Write</code> class for rewriting position delete files from Spark.</div>
+</dd>
+<dt><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.DeleteTaskCommit.html" title="class in org.apache.iceberg.spark.source"><span class="typeNameLink">SparkPositionDeletesRewrite.DeleteTaskCommit</span></a> - Class in <a href="org/apache/iceberg/spark/source/package-summary.html">org.apache.iceberg.spark.source</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewriteBuilder.html" title="class in org.apache.iceberg.spark.source"><span class="typeNameLink">SparkPositionDeletesRewriteBuilder</span></a> - Class in <a href="org/apache/iceberg/spark/source/package-summary.html">org.apache.iceberg.spark.source</a></dt>
+<dd>
+<div class="block">Builder class for rewrites of position delete files from Spark.</div>
+</dd>
 <dt><a href="org/apache/iceberg/spark/procedures/SparkProcedures.html" title="class in org.apache.iceberg.spark.procedures"><span class="typeNameLink">SparkProcedures</span></a> - Class in <a href="org/apache/iceberg/spark/procedures/package-summary.html">org.apache.iceberg.spark.procedures</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/procedures/SparkProcedures.ProcedureBuilder.html" title="interface in org.apache.iceberg.spark.procedures"><span class="typeNameLink">SparkProcedures.ProcedureBuilder</span></a> - Interface in <a href="org/apache/iceberg/spark/procedures/package-summary.html">org.apache.iceberg.spark.procedures</a></dt>
@@ -21429,16 +22687,12 @@
 <dd>
 <div class="block">Helper methods for working with Spark/Hive metadata.</div>
 </dd>
-<dt><a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkSessionCatalog</span></a>&lt;<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="type parameter in SparkSessionCatalog">T</a> extends org.apache.spark.sql.connector.catalog.TableCatalog &amp; org.apache.spark.sql.connector.catalog.SupportsNamespaces&gt; - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg [...]
+<dt><a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkSessionCatalog</span></a>&lt;<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="type parameter in SparkSessionCatalog">T</a> extends org.apache.spark.sql.connector.catalog.TableCatalog &amp; org.apache.spark.sql.connector.catalog.FunctionCatalog &amp; org.apache.spark.sql.connector.catalog.SupportsNamespaces&gt; - Class in <a href="org/ [...]
 <dd>
 <div class="block">A Spark catalog that can also load non-Iceberg tables.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#SparkSessionCatalog--">SparkSessionCatalog()</a></span> - Constructor for class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.spark">SparkSessionCatalog</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions"><span class="typeNameLink">SparkSortStrategy</span></a> - Class in <a href="org/apache/iceberg/spark/actions/package-summary.html">org.apache.iceberg.spark.actions</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#SparkSortStrategy-org.apache.iceberg.Table-org.apache.spark.sql.SparkSession-">SparkSortStrategy(Table, SparkSession)</a></span> - Constructor for class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkSQLProperties</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/SparkStructLike.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkStructLike</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
@@ -21490,10 +22744,14 @@
 <dd>
 <div class="block">Spark DF write options</div>
 </dd>
-<dt><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions"><span class="typeNameLink">SparkZOrderStrategy</span></a> - Class in <a href="org/apache/iceberg/spark/actions/package-summary.html">org.apache.iceberg.spark.actions</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#SparkZOrderStrategy-org.apache.iceberg.Table-org.apache.spark.sql.SparkSession-java.util.List-">SparkZOrderStrategy(Table, SparkSession, List&lt;String&gt;)</a></span> - Constructor for class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/SparkWriteRequirements.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkWriteRequirements</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
+<dd>
+<div class="block">A set of requirements such as distribution and ordering reported to Spark during writes.</div>
+</dd>
+<dt><a href="org/apache/iceberg/spark/SparkWriteUtil.html" title="class in org.apache.iceberg.spark"><span class="typeNameLink">SparkWriteUtil</span></a> - Class in <a href="org/apache/iceberg/spark/package-summary.html">org.apache.iceberg.spark</a></dt>
+<dd>
+<div class="block">A utility that contains helper methods for working with Spark writes.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html#spec--">spec()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetadataTable.html#spec--">spec()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetadataTable.html" title="class in org.apache.iceberg">BaseMetadataTable</a></dt>
@@ -21536,6 +22794,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#SPEC_ID">SPEC_ID</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/PositionDeletesTable.html#SPEC_ID">SPEC_ID</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/PositionDeletesTable.html" title="class in org.apache.iceberg">PositionDeletesTable</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#SPEC_ID_COLUMN_DOC">SPEC_ID_COLUMN_DOC</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/MetadataColumns.html#SPEC_ID_COLUMN_ID">SPEC_ID_COLUMN_ID</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/MetadataColumns.html" title="class in org.apache.iceberg">MetadataColumns</a></dt>
@@ -21721,9 +22981,15 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#splitSize-long-">splitSize(long)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns the smallest of our max write file threshold, and our estimated split size based on the
  number of output files we want to generate.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#splitSize-long-">splitSize(long)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Returns the smallest of our max write file threshold and our estimated split size based on the
+ number of output files we want to generate.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadConf.html#splitSize--">splitSize()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadConf.html" title="class in org.apache.iceberg.flink">FlinkReadConf</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/FlinkSource.Builder.html#splitSize-java.lang.Long-">splitSize(Long)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/FlinkSource.Builder.html" title="class in org.apache.iceberg.flink.source">FlinkSource.Builder</a></dt>
@@ -21752,6 +23018,40 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/view/SQLViewRepresentation.html" title="interface in org.apache.iceberg.view"><span class="typeNameLink">SQLViewRepresentation</span></a> - Interface in <a href="org/apache/iceberg/view/package-summary.html">org.apache.iceberg.view</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_KEY">SSE_KEY</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">If S3 encryption type is SSE-KMS, input is a KMS Key ID or ARN.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_MD5">SSE_MD5</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">If S3 encryption type is SSE-C, input is the base-64 MD5 digest of the secret key.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE">SSE_TYPE</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Type of S3 Server side encryption used, default to <a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_NONE"><code>S3FileIOProperties.SSE_TYPE_NONE</code></a>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_CUSTOM">SSE_TYPE_CUSTOM</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">S3 SSE-C encryption.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_KMS">SSE_TYPE_KMS</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">S3 SSE-KMS encryption.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_NONE">SSE_TYPE_NONE</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">No server side encryption.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#SSE_TYPE_S3">SSE_TYPE_S3</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">S3 SSE-S3 encryption.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#sseKey--">sseKey()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#sseMd5--">sseMd5()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#sseType--">sseType()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/responses/ErrorResponse.html#stack--">stack()</a></span> - Method in class org.apache.iceberg.rest.responses.<a href="org/apache/iceberg/rest/responses/ErrorResponse.html" title="class in org.apache.iceberg.rest.responses">ErrorResponse</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/CreateTableRequest.Builder.html#stageCreate--">stageCreate()</a></span> - Method in class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/CreateTableRequest.Builder.html" title="class in org.apache.iceberg.rest.requests">CreateTableRequest.Builder</a></dt>
@@ -21782,18 +23082,17 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSessionCatalog.html#stageReplace-org.apache.spark.sql.connector.catalog.Identifier-org.apache.spark.sql.types.StructType-org.apache.spark.sql.connector.expressions.Transform:A-java.util.Map-">stageReplace(Identifier, StructType, Transform[], Map&lt;String, String&gt;)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSessionCatalog.html" title="class in org.apache.iceberg.sp [...]
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileRewriteCoordinator.html#stageRewrite-org.apache.iceberg.Table-java.lang.String-java.util.Set-">stageRewrite(Table, String, Set&lt;DataFile&gt;)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileRewriteCoordinator.html" title="class in org.apache.iceberg.spark">FileRewriteCoordinator</a></dt>
-<dd>
-<div class="block">Called to persist the output of a rewrite action for a specific group.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/CatalogHandlers.html#stageTableCreate-org.apache.iceberg.catalog.Catalog-org.apache.iceberg.catalog.Namespace-org.apache.iceberg.rest.requests.CreateTableRequest-">stageTableCreate(Catalog, Namespace, CreateTableRequest)</a></span> - Static method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/CatalogHandlers.html" title="class in org.apache.iceberg.rest">CatalogHandlers</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/FileScanTaskSetManager.html#stageTasks-org.apache.iceberg.Table-java.lang.String-java.util.List-">stageTasks(Table, String, List&lt;FileScanTask&gt;)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/FileScanTaskSetManager.html" title="class in org.apache.iceberg.spark">FileScanTaskSetManager</a></dt>
-<dd>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
-&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ScanTaskSetManager.html#stageTasks-org.apache.iceberg.Table-java.lang.String-java.util.List-">stageTasks(Table, String, List&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ScanTaskSetManager.html" title="class in org.apache.iceberg.spark">ScanTaskSetManager</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#STAGING_DIRECTORY">STAGING_DIRECTORY</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Location to put staging files for upload to S3, default to temp directory set in
+ java.io.tmpdir.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#stagingDirectory--">stagingDirectory()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteManifests.html#stagingLocation-java.lang.String-">stagingLocation(String)</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteManifests.html" title="interface in org.apache.iceberg.actions">RewriteManifests</a></dt>
 <dd>
 <div class="block">Passes a location where the staged manifests should be written.</div>
@@ -21804,10 +23103,6 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/puffin/StandardPuffinProperties.html" title="class in org.apache.iceberg.puffin"><span class="typeNameLink">StandardPuffinProperties</span></a> - Class in <a href="org/apache/iceberg/puffin/package-summary.html">org.apache.iceberg.puffin</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html#start--">start()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteDataFilesCommitManager.CommitService.html" title="class in org.apache.iceberg.actions">RewriteDataFilesCommitManager.CommitService</a></dt>
-<dd>
-<div class="block">Starts a single threaded executor service for handling file group commits.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/ContentScanTask.html#start--">start()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/ContentScanTask.html" title="interface in org.apache.iceberg">ContentScanTask</a></dt>
 <dd>
 <div class="block">The starting position of this scan range in the file.</div>
@@ -22014,6 +23309,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.Builder.html#streaming-boolean-">streaming(boolean)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.Builder.html" title="class in org.apache.iceberg.flink.source">ScanContext.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_MAX_FILES_PER_MICRO_BATCH">STREAMING_MAX_FILES_PER_MICRO_BATCH</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadOptions.html" title="class in org.apache.iceberg.spark">SparkReadOptions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_MAX_ROWS_PER_MICRO_BATCH">STREAMING_MAX_ROWS_PER_MICRO_BATCH</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadOptions.html" title="class in org.apache.iceberg.spark">SparkReadOptions</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkReadOptions.html#STREAMING_OPTION">STREAMING_OPTION</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkReadOptions.html" title="class in org.apache.iceberg.flink">FlinkReadOptions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkReadOptions.html#STREAMING_SKIP_DELETE_SNAPSHOTS">STREAMING_SKIP_DELETE_SNAPSHOTS</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkReadOptions.html" title="class in org.apache.iceberg.spark">SparkReadOptions</a></dt>
@@ -22222,17 +23521,12 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/view/ViewVersion.html#summary--">summary()</a></span> - Method in interface org.apache.iceberg.view.<a href="org/apache/iceberg/view/ViewVersion.html" title="interface in org.apache.iceberg.view">ViewVersion</a></dt>
 <dd>
-<div class="block">Return the version summary such as the name of the operation that created that version of the
- view</div>
+<div class="block">Return the version summary</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkCatalogFactory.html#supportedProperties--">supportedProperties()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkCatalogFactory.html" title="class in org.apache.iceberg.flink">FlinkCatalogFactory</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/SupportsBulkOperations.html" title="interface in org.apache.iceberg.io"><span class="typeNameLink">SupportsBulkOperations</span></a> - Interface in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html" title="interface in org.apache.spark.sql.connector.iceberg.write"><span class="typeNameLink">SupportsDelta</span></a> - Interface in <a href="org/apache/spark/sql/connector/iceberg/write/package-summary.html">org.apache.spark.sql.connector.iceberg.write</a></dt>
-<dd>
-<div class="block">A mix-in interface for RowLevelOperation.</div>
-</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/IcebergSource.html#supportsExternalMetadata--">supportsExternalMetadata()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/IcebergSource.html" title="class in org.apache.iceberg.spark.source">IcebergSource</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/encryption/KmsClient.html#supportsKeyGeneration--">supportsKeyGeneration()</a></span> - Method in interface org.apache.iceberg.encryption.<a href="org/apache/iceberg/encryption/KmsClient.html" title="interface in org.apache.iceberg.encryption">KmsClient</a></dt>
@@ -22300,12 +23594,16 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#table--">table()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns the table being modified by this rewrite strategy</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#table--">table()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns the table being modified by this rewrite strategy</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#table--">table()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetadataTable.html#table--">table()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetadataTable.html" title="class in org.apache.iceberg">BaseMetadataTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseTransaction.html#table--">table()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseTransaction.html" title="class in org.apache.iceberg">BaseTransaction</a></dt>
@@ -22333,10 +23631,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/ResourcePaths.html#table-org.apache.iceberg.catalog.TableIdentifier-">table(TableIdentifier)</a></span> - Method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/ResourcePaths.html" title="class in org.apache.iceberg.rest">ResourcePaths</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html#table--">table()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkBinPackStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkBinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#table--">table()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkTable.html#table--">table()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkTable.html" title="class in org.apache.iceberg.spark.source">SparkTable</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/Table.html" title="interface in org.apache.iceberg"><span class="typeNameLink">Table</span></a> - Interface in <a href="org/apache/iceberg/package-summary.html">org.apache.iceberg</a></dt>
@@ -22407,8 +23701,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CachingCatalog.html#tableCache">tableCache</a></span> - Variable in class org.apache.iceberg.<a href="org/apache/iceberg/CachingCatalog.html" title="class in org.apache.iceberg">CachingCatalog</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#tableCache--">tableCache()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/ErrorHandlers.html#tableCommitHandler--">tableCommitHandler()</a></span> - Static method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/ErrorHandlers.html" title="class in org.apache.iceberg.rest">ErrorHandlers</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/ErrorHandlers.html#tableErrorHandler--">tableErrorHandler()</a></span> - Static method in class org.apache.iceberg.rest.<a href="org/apache/iceberg/rest/ErrorHandlers.html" title="class in org.apache.iceberg.rest">ErrorHandlers</a></dt>
@@ -22606,6 +23898,10 @@
 <dd>
 <div class="block">The output file size that this rewrite strategy will attempt to generate when rewriting files.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#TARGET_FILE_SIZE_BYTES">TARGET_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">The target output file size that this file rewriter will attempt to generate.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteOptions.html#TARGET_FILE_SIZE_BYTES">TARGET_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteOptions.html" title="class in org.apache.iceberg.flink">FlinkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#TARGET_FILE_SIZE_BYTES">TARGET_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
@@ -22617,7 +23913,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#targetDeleteFileSize--">targetDeleteFileSize()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#targetFileSize--">targetFileSize()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html#targetSizeInBytes-long-">targetSizeInBytes(long)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesAction</a></dt>
 <dd>
 <div class="block">Specify the target rewrite data file size in bytes</div>
@@ -22644,6 +23942,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/metrics/TaskNumSplits.html#TaskNumSplits-long-">TaskNumSplits(long)</a></span> - Constructor for class org.apache.iceberg.spark.source.metrics.<a href="org/apache/iceberg/spark/source/metrics/TaskNumSplits.html" title="class in org.apache.iceberg.spark.source.metrics">TaskNumSplits</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#tasks--">tasks()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseScanTaskGroup.html#tasks--">tasks()</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseScanTaskGroup.html" title="class in org.apache.iceberg">BaseScanTaskGroup</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/CombinedScanTask.html#tasks--">tasks()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/CombinedScanTask.html" title="interface in org.apache.iceberg">CombinedScanTask</a></dt>
@@ -22766,10 +24066,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/hive/serde/objectinspector/IcebergObjectInspector.html#TIMESTAMP_INSPECTOR_WITH_TZ">TIMESTAMP_INSPECTOR_WITH_TZ</a></span> - Static variable in class org.apache.iceberg.mr.hive.serde.objectinspector.<a href="org/apache/iceberg/mr/hive/serde/objectinspector/IcebergObjectInspector.html" title="class in org.apache.iceberg.mr.hive.serde.objectinspector">IcebergObjectInspector</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#TIMESTAMP_WITHOUT_TIMEZONE_ERROR">TIMESTAMP_WITHOUT_TIMEZONE_ERROR</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/DateTimeUtil.html#timestampFromMicros-long-">timestampFromMicros(long)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/DateTimeUtil.html" title="class in org.apache.iceberg.util">DateTimeUtil</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html#timestampInt96BatchReader--">timestampInt96BatchReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampInt96BatchReader.html#TimestampInt96BatchReader--">TimestampInt96BatchReader()</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampInt96BatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedColumnIterator.TimestampInt96Batc [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html#timestampInt96DictEncodedReader--">timestampInt96DictEncodedReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedDictionaryEncodedParquetValuesReade [...]
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/HistoryEntry.html#timestampMillis--">timestampMillis()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/HistoryEntry.html" title="interface in org.apache.iceberg">HistoryEntry</a></dt>
 <dd>
 <div class="block">Returns the timestamp in milliseconds of the change.</div>
@@ -22796,6 +24100,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html#timestampMillisDictEncodedReader--">timestampMillisDictEncodedReader()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.parquet.<a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedDictionaryEncodedParquetValuesReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet">VectorizedDictionaryEncodedParquetValuesRea [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html#TimestampNtzToDaysFunction--">TimestampNtzToDaysFunction()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampNtzToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampNtzToDaysFunction</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html#TimestampNtzToHoursFunction--">TimestampNtzToHoursFunction()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/HoursFunction.TimestampNtzToHoursFunction.html" title="class in org.apache.iceberg.spark.functions">HoursFunction.TimestampNtzToHoursFunction</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html#TimestampNtzToMonthsFunction--">TimestampNtzToMonthsFunction()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/MonthsFunction.TimestampNtzToMonthsFunction.html" title="class in org.apache.iceberg.spark.functions">MonthsFunction.TimestampNtzToMonthsFunction</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html#TimestampNtzToYearsFunction--">TimestampNtzToYearsFunction()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions">YearsFunction.TimestampNtzToYearsFunction</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/orc/GenericOrcReaders.html#timestamps--">timestamps()</a></span> - Static method in class org.apache.iceberg.data.orc.<a href="org/apache/iceberg/data/orc/GenericOrcReaders.html" title="class in org.apache.iceberg.data.orc">GenericOrcReaders</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html#TimestampToDaysFunction--">TimestampToDaysFunction()</a></span> - Constructor for class org.apache.iceberg.spark.functions.<a href="org/apache/iceberg/spark/functions/DaysFunction.TimestampToDaysFunction.html" title="class in org.apache.iceberg.spark.functions">DaysFunction.TimestampToDaysFunction</a></dt>
@@ -22857,7 +24169,9 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/StructLikeSet.html#toArray-T:A-">toArray(T[])</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/StructLikeSet.html" title="class in org.apache.iceberg.util">StructLikeSet</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWrite.html#toBatch--">toBatch()</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWrite.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWrite</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/DictEncodedArrowConverter.html#toArrowVector-org.apache.iceberg.arrow.vectorized.VectorHolder-org.apache.iceberg.arrow.vectorized.ArrowVectorAccessor-">toArrowVector(VectorHolder, ArrowVectorAccessor&lt;?, String, ?, ?&gt;)</a></span> - Static method in class org.apache.iceberg.arrow.<a href="org/apache/iceberg/arrow/DictEncodedArrowConverter.html" title="class in org.apache.iceberg.arrow">DictEncodedArrowConverter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.html#toBatch--">toBatch()</a></span> - Method in class org.apache.iceberg.spark.source.<a href="org/apache/iceberg/spark/source/SparkPositionDeletesRewrite.html" title="class in org.apache.iceberg.spark.source">SparkPositionDeletesRewrite</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseOverwriteFiles.html#toBranch-java.lang.String-">toBranch(String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseOverwriteFiles.html" title="class in org.apache.iceberg">BaseOverwriteFiles</a></dt>
 <dd>&nbsp;</dd>
@@ -22871,6 +24185,8 @@
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/StreamingDelete.html#toBranch-java.lang.String-">toBranch(String)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/StreamingDelete.html" title="class in org.apache.iceberg">StreamingDelete</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#toByteArray--">toByteArray()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/ByteBuffers.html#toByteArray-java.nio.ByteBuffer-">toByteArray(ByteBuffer)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/ByteBuffers.html" title="class in org.apache.iceberg.util">ByteBuffers</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/Literal.html#toByteBuffer--">toByteBuffer()</a></span> - Method in interface org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/Literal.html" title="interface in org.apache.iceberg.expressions">Literal</a></dt>
@@ -22928,6 +24244,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hadoop/HadoopOutputFile.html#toInputFile--">toInputFile()</a></span> - Method in class org.apache.iceberg.hadoop.<a href="org/apache/iceberg/hadoop/HadoopOutputFile.html" title="class in org.apache.iceberg.hadoop">HadoopOutputFile</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html#toInputFile--">toInputFile()</a></span> - Method in class org.apache.iceberg.inmemory.<a href="org/apache/iceberg/inmemory/InMemoryOutputFile.html" title="class in org.apache.iceberg.inmemory">InMemoryOutputFile</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/OutputFile.html#toInputFile--">toInputFile()</a></span> - Method in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/OutputFile.html" title="interface in org.apache.iceberg.io">OutputFile</a></dt>
 <dd>
 <div class="block">Return an <a href="org/apache/iceberg/io/InputFile.html" title="interface in org.apache.iceberg.io"><code>InputFile</code></a> for the location of this output file.</div>
@@ -23132,6 +24450,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#toNamedReference-java.lang.String-">toNamedReference(String)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#tooMuchContent-java.util.List-">tooMuchContent(List&lt;T&gt;)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#toOrdering-org.apache.iceberg.SortOrder-">toOrdering(SortOrder)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/Spark3Util.html#toPartitionSpec-org.apache.iceberg.Schema-org.apache.spark.sql.connector.expressions.Transform:A-">toPartitionSpec(Schema, Transform[])</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/Spark3Util.html" title="class in org.apache.iceberg.spark">Spark3Util</a></dt>
 <dd>
 <div class="block">Converts Spark transforms into a <a href="org/apache/iceberg/PartitionSpec.html" title="class in org.apache.iceberg"><code>PartitionSpec</code></a>.</div>
@@ -23201,9 +24523,13 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/IcebergSourceReader.html#toSplitType-java.lang.String-org.apache.iceberg.flink.source.split.IcebergSourceSplit-">toSplitType(String, IcebergSourceSplit)</a></span> - Method in class org.apache.iceberg.flink.source.reader.<a href="org/apache/iceberg/flink/source/reader/IcebergSourceReader.html" title="class in org.apache.iceberg.flink.source.reader">IcebergSourceReader</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesFileGroupInfo.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesFileGroupInfo</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteFileGroup.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteFileGroup.html" title="class in org.apache.iceberg.actions">RewriteFileGroup</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeletesGroup.html" title="class in org.apache.iceberg.actions">RewritePositionDeletesGroup</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/aliyun/oss/OSSURI.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.aliyun.oss.<a href="org/apache/iceberg/aliyun/oss/OSSURI.html" title="class in org.apache.iceberg.aliyun.oss">OSSURI</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorizedArrowReader.ConstantVectorReader.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.arrow.vectorized.<a href="org/apache/iceberg/arrow/vectorized/VectorizedArrowReader.ConstantVectorReader.html" title="class in org.apache.iceberg.arrow.vectorized">VectorizedArrowReader.ConstantVectorReader</a></dt>
@@ -23272,6 +24598,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/CatalogLoader.RESTCatalogLoader.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/CatalogLoader.RESTCatalogLoader.html" title="class in org.apache.iceberg.flink">CatalogLoader.RESTCatalogLoader</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/data/RowDataProjection.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.flink.data.<a href="org/apache/iceberg/flink/data/RowDataProjection.html" title="class in org.apache.iceberg.flink.data">RowDataProjection</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/FlinkInputSplit.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/FlinkInputSplit.html" title="class in org.apache.iceberg.flink.source">FlinkInputSplit</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/reader/RecordAndPosition.html#toString--">toString()</a></span> - Method in class org.apache.iceberg.flink.source.reader.<a href="org/apache/iceberg/flink/source/reader/RecordAndPosition.html" title="class in org.apache.iceberg.flink.source.reader">RecordAndPosition</a></dt>
@@ -23596,6 +24924,8 @@
 <dd>
 <div class="block">Factory methods for transforms.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/util/StructLikeMap.html#transformValues-java.util.function.Function-">transformValues(Function&lt;T, U&gt;)</a></span> - Method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/StructLikeMap.html" title="class in org.apache.iceberg.util">StructLikeMap</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/HiveTableOperations.html#translateToIcebergProp-java.lang.String-">translateToIcebergProp(String)</a></span> - Static method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/HiveTableOperations.html" title="class in org.apache.iceberg.hive">HiveTableOperations</a></dt>
 <dd>
 <div class="block">Provides key translation where necessary between Iceberg and HMS props.</div>
@@ -23981,6 +25311,8 @@
 <dd>
 <div class="block">The <code>TimeUnit</code> of the timer.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/ReportMetricsRequest.html#unknown--">unknown()</a></span> - Static method in interface org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/ReportMetricsRequest.html" title="interface in org.apache.iceberg.rest.requests">ReportMetricsRequest</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/transforms/PartitionSpecVisitor.html#unknown-int-java.lang.String-int-java.lang.String-">unknown(int, String, int, String)</a></span> - Method in interface org.apache.iceberg.transforms.<a href="org/apache/iceberg/transforms/PartitionSpecVisitor.html" title="interface in org.apache.iceberg.transforms">PartitionSpecVisitor</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/transforms/SortOrderVisitor.html#unknown-java.lang.String-int-java.lang.String-org.apache.iceberg.SortDirection-org.apache.iceberg.NullOrder-">unknown(String, int, String, SortDirection, NullOrder)</a></span> - Method in interface org.apache.iceberg.transforms.<a href="org/apache/iceberg/transforms/SortOrderVisitor.html" title="interface in org.apache.iceberg.transforms">SortOrderVisitor</a></dt>
@@ -23989,6 +25321,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/view/UnknownViewRepresentation.html" title="interface in org.apache.iceberg.view"><span class="typeNameLink">UnknownViewRepresentation</span></a> - Interface in <a href="org/apache/iceberg/view/package-summary.html">org.apache.iceberg.view</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/hive/NoLock.html#unlock--">unlock()</a></span> - Method in class org.apache.iceberg.hive.<a href="org/apache/iceberg/hive/NoLock.html" title="class in org.apache.iceberg.hive">NoLock</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#UNORDERED">UNORDERED</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.NonReservedContext.html#UNORDERED--">UNORDERED()</a></span> - Method in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.NonReservedContext.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser.NonReservedContext</a></dt>
@@ -24067,10 +25401,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/requests/UpdateTableRequest.Builder.html#update-org.apache.iceberg.MetadataUpdate-">update(MetadataUpdate)</a></span> - Method in class org.apache.iceberg.rest.requests.<a href="org/apache/iceberg/rest/requests/UpdateTableRequest.Builder.html" title="class in org.apache.iceberg.rest.requests">UpdateTableRequest.Builder</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html#update-T-T-T-">update(T, T, T)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWriter</a></dt>
-<dd>
-<div class="block">Passes information for a row that must be updated together with the updated row.</div>
-</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#UPDATE_AFTER">UPDATE_AFTER</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/ChangelogIterator.html#UPDATE_BEFORE">UPDATE_BEFORE</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/ChangelogIterator.html" title="class in org.apache.iceberg.spark">ChangelogIterator</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#UPDATE_DISTRIBUTION_MODE">UPDATE_DISTRIBUTION_MODE</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#UPDATE_ISOLATION_LEVEL">UPDATE_ISOLATION_LEVEL</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
@@ -24099,8 +25433,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/responses/UpdateNamespacePropertiesResponse.html#updated--">updated()</a></span> - Method in class org.apache.iceberg.rest.responses.<a href="org/apache/iceberg/rest/responses/UpdateNamespacePropertiesResponse.html" title="class in org.apache.iceberg.rest.responses">UpdateNamespacePropertiesResponse</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#updateDistributionMode--">updateDistributionMode()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/PendingUpdate.html#updateEvent--">updateEvent()</a></span> - Method in interface org.apache.iceberg.<a href="org/apache/iceberg/PendingUpdate.html" title="interface in org.apache.iceberg">PendingUpdate</a></dt>
 <dd>
 <div class="block">Generates update event to notify about metadata changes</div>
@@ -24339,6 +25671,21 @@
 <dd>
 <div class="block">From Apache Spark</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#URLCONNECTION_CONNECTION_TIMEOUT_MS">URLCONNECTION_CONNECTION_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the connection timeout in milliseconds for <code>UrlConnectionHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/HttpClientProperties.html#URLCONNECTION_SOCKET_TIMEOUT_MS">URLCONNECTION_SOCKET_TIMEOUT_MS</a></span> - Static variable in class org.apache.iceberg.aws.<a href="org/apache/iceberg/aws/HttpClientProperties.html" title="class in org.apache.iceberg.aws">HttpClientProperties</a></dt>
+<dd>
+<div class="block">Used to configure the socket timeout in milliseconds for <code>UrlConnectionHttpClient.Builder</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#USE_ARN_REGION_ENABLED">USE_ARN_REGION_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Enable to make S3FileIO, to make cross-region call to the region specified in the ARN of an
+ access point.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#USE_ARN_REGION_ENABLED_DEFAULT">USE_ARN_REGION_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html#USE_CACHING">USE_CACHING</a></span> - Static variable in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewriteManifestsSparkAction</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html#USE_CACHING_DEFAULT">USE_CACHING_DEFAULT</a></span> - Static variable in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/RewriteManifestsSparkAction.html" title="class in org.apache.iceberg.spark.actions">RewriteManifestsSparkAction</a></dt>
@@ -24355,9 +25702,9 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteOptions.html#USE_TABLE_DISTRIBUTION_AND_ORDERING_DEFAULT">USE_TABLE_DISTRIBUTION_AND_ORDERING_DEFAULT</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteOptions.html" title="class in org.apache.iceberg.spark">SparkWriteOptions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES">USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkSQLProperties.html#USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES_DEFAULT">USE_TIMESTAMP_WITHOUT_TIME_ZONE_IN_NEW_TABLES_DEFAULT</a></span> - Static variable in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkSQLProperties.html" title="class in org.apache.iceberg.spark">SparkSQLProperties</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.Builder.html#useBranch-java.lang.String-">useBranch(String)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.Builder.html" title="class in org.apache.iceberg.flink.source">ScanContext.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/InputFormatConfig.ConfigBuilder.html#useHiveRows--">useHiveRows()</a></span> - Method in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/InputFormatConfig.ConfigBuilder.html" title="class in org.apache.iceberg.mr">InputFormatConfig.ConfigBuilder</a></dt>
@@ -24400,14 +25747,13 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.Builder.html#useSnapshotId-java.lang.Long-">useSnapshotId(Long)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.Builder.html" title="class in org.apache.iceberg.flink.source">ScanContext.Builder</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#useTableDistributionAndOrdering--">useTableDistributionAndOrdering()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.Builder.html#useTag-java.lang.String-">useTag(String)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.Builder.html" title="class in org.apache.iceberg.flink.source">ScanContext.Builder</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#useTimestampWithoutZoneInNewTables-org.apache.spark.sql.RuntimeConfig-">useTimestampWithoutZoneInNewTables(RuntimeConfig)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html#useStartingSequenceNumber-boolean-">useStartingSequenceNumber(boolean)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BaseRewriteDataFilesAction.html" title="class in org.apache.iceberg.actions">BaseRewriteDataFilesAction</a></dt>
 <dd>
-<div class="block">Checks whether timestamp types for new tables should be stored with timezone info.</div>
+<div class="block">If the compaction should use the sequence number of the snapshot at compaction start time for
+ new data files, instead of using the sequence number of the newly produced snapshot.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/source/ScanContext.Builder.html#useTag-java.lang.String-">useTag(String)</a></span> - Method in class org.apache.iceberg.flink.source.<a href="org/apache/iceberg/flink/source/ScanContext.Builder.html" title="class in org.apache.iceberg.flink.source">ScanContext.Builder</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/ValueReaders.html#utf8s--">utf8s()</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/ValueReaders.html" title="class in org.apache.iceberg.avro">ValueReaders</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/ValueWriters.html#utf8s--">utf8s()</a></span> - Static method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/ValueWriters.html" title="class in org.apache.iceberg.avro">ValueWriters</a></dt>
@@ -24438,6 +25784,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/data/orc/GenericOrcWriters.html#uuids--">uuids()</a></span> - Static method in class org.apache.iceberg.data.orc.<a href="org/apache/iceberg/data/orc/GenericOrcWriters.html" title="class in org.apache.iceberg.data.orc">GenericOrcWriters</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/data/SparkOrcValueReaders.html#uuids--">uuids()</a></span> - Static method in class org.apache.iceberg.spark.data.<a href="org/apache/iceberg/spark/data/SparkOrcValueReaders.html" title="class in org.apache.iceberg.spark.data">SparkOrcValueReaders</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/types/Types.UUIDType.html#UUIDType--">UUIDType()</a></span> - Constructor for class org.apache.iceberg.types.<a href="org/apache/iceberg/types/Types.UUIDType.html" title="class in org.apache.iceberg.types">Types.UUIDType</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/util/UUIDUtil.html" title="class in org.apache.iceberg.util"><span class="typeNameLink">UUIDUtil</span></a> - Class in <a href="org/apache/iceberg/util/package-summary.html">org.apache.iceberg.util</a></dt>
@@ -24594,9 +25942,9 @@
  operation.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#validateOptions--">validateOptions()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#validateOptions--">validateOptions()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#validatePartitionTransforms-org.apache.iceberg.PartitionSpec-">validatePartitionTransforms(PartitionSpec)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
 <dd>
 <div class="block">Check whether the partition transforms in a spec can be used to write data.</div>
@@ -24607,6 +25955,12 @@
 <dd>
 <div class="block">Validates whether the provided schema is compatible with the expected schema.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#validateTimestampWithoutTimezoneConfig-org.apache.spark.sql.RuntimeConfig-">validateTimestampWithoutTimezoneConfig(RuntimeConfig)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkUtil.html#validateTimestampWithoutTimezoneConfig-org.apache.spark.sql.RuntimeConfig-java.util.Map-">validateTimestampWithoutTimezoneConfig(RuntimeConfig, Map&lt;String, String&gt;)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkUtil.html" title="class in org.apache.iceberg.spark">SparkUtil</a></dt>
+<dd>
+<div class="block">Checks for properties both supplied by Spark's RuntimeConfig and the read or write options</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/util/WapUtil.html#validateWapPublish-org.apache.iceberg.TableMetadata-long-">validateWapPublish(TableMetadata, long)</a></span> - Static method in class org.apache.iceberg.util.<a href="org/apache/iceberg/util/WapUtil.html" title="class in org.apache.iceberg.util">WapUtil</a></dt>
 <dd>
 <div class="block">Check if a given staged snapshot's associated wap-id was already published.</div>
@@ -24626,25 +25980,35 @@
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/exceptions/ValidationException.html#ValidationException-java.lang.Throwable-java.lang.String-java.lang.Object...-">ValidationException(Throwable, String, Object...)</a></span> - Constructor for exception org.apache.iceberg.exceptions.<a href="org/apache/iceberg/exceptions/ValidationException.html" title="class in org.apache.iceberg.exceptions">ValidationException</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/ConvertEqualityDeleteStrategy.html#validOptions--">validOptions()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/ConvertEqualityDeleteStrategy.html" title="interface in org.apache.iceberg.actions">ConvertEqualityDeleteStrategy</a></dt>
 <dd>
 <div class="block">Returns a set of options which this convert strategy can use.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/FileRewriter.html#validOptions--">validOptions()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/FileRewriter.html" title="interface in org.apache.iceberg.actions">FileRewriter</a></dt>
+<dd>
+<div class="block">Returns a set of supported options for this rewriter.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html#validOptions--">validOptions()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewritePositionDeleteStrategy.html" title="interface in org.apache.iceberg.actions">RewritePositionDeleteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns a set of options which this rewrite strategy can use.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/RewriteStrategy.html#validOptions--">validOptions()</a></span> - Method in interface org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/RewriteStrategy.html" title="interface in org.apache.iceberg.actions">RewriteStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Returns a set of options which this rewrite strategy can use.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedDataRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedDataRewriter</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkSortStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkSortStrategy</a></dt>
-<dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.spark.actions.<a href="org/apache/iceberg/spark/actions/SparkZOrderStrategy.html" title="class in org.apache.iceberg.spark.actions">SparkZOrderStrategy</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SortStrategy.html#validOptions--">validOptions()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SortStrategy.html" title="class in org.apache.iceberg.actions">SortStrategy</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/expressions/Literal.html#value--">value()</a></span> - Method in interface org.apache.iceberg.expressions.<a href="org/apache/iceberg/expressions/Literal.html" title="interface in org.apache.iceberg.expressions">Literal</a></dt>
 <dd>
 <div class="block">Returns the value wrapped by this literal.</div>
@@ -25004,7 +26368,7 @@ the order they are declared.</div>
 <div class="block">Container class for holding the Arrow vector storing a batch of values along with other state
  needed for reading values out of it.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#VectorHolder-org.apache.parquet.column.ColumnDescriptor-org.apache.arrow.vector.FieldVector-boolean-org.apache.parquet.column.Dictionary-org.apache.iceberg.arrow.vectorized.NullabilityHolder-org.apache.iceberg.types.Type-">VectorHolder(ColumnDescriptor, FieldVector, boolean, Dictionary, NullabilityHolder, Type)</a></span> - Constructor for class org.apache.iceberg.arrow.vectorized.<a href="org [...]
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.html#VectorHolder-org.apache.parquet.column.ColumnDescriptor-org.apache.arrow.vector.FieldVector-boolean-org.apache.parquet.column.Dictionary-org.apache.iceberg.arrow.vectorized.NullabilityHolder-org.apache.iceberg.types.Types.NestedField-">VectorHolder(ColumnDescriptor, FieldVector, boolean, Dictionary, NullabilityHolder, Types.NestedField)</a></span> - Constructor for class org.apache.iceberg.arr [...]
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/VectorHolder.ConstantVectorHolder.html" title="class in org.apache.iceberg.arrow.vectorized"><span class="typeNameLink">VectorHolder.ConstantVectorHolder</span></a>&lt;<a href="org/apache/iceberg/arrow/vectorized/VectorHolder.ConstantVectorHolder.html" title="type parameter in VectorHolder.ConstantVectorHolder">T</a>&gt; - Class in <a href="org/apache/iceberg/arrow/vectorized/package-summary.html">org.apache.iceberg.arrow.vectorized</a></dt>
 <dd>
@@ -25054,7 +26418,11 @@ the order they are declared.</div>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.DoubleBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.DoubleBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedLengthDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.FixedLengthDecimalBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</div>
+</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedSizeBinaryBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.FixedSizeBinaryBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FixedWidthTypeBinaryBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.FixedWidthTypeBinaryBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
@@ -25062,13 +26430,23 @@ the order they are declared.</div>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.FloatBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.FloatBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntBackedDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.IntBackedDecimalBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</div>
+</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.IntegerBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.IntegerBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBackedDecimalBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.LongBackedDecimalBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">will be removed in 1.4.0</span></div>
+</div>
+</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.LongBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.LongBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampInt96BatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.TimestampInt96BatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.TimestampMillisBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.TimestampMillisBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/arrow/vectorized/parquet/VectorizedColumnIterator.VarWidthTypeBatchReader.html" title="class in org.apache.iceberg.arrow.vectorized.parquet"><span class="typeNameLink">VectorizedColumnIterator.VarWidthTypeBatchReader</span></a> - Class in <a href="org/apache/iceberg/arrow/vectorized/parquet/package-summary.html">org.apache.iceberg.arrow.vectorized.parquet</a></dt>
@@ -26102,6 +27480,8 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/DataFiles.Builder.html#withSplitOffsets-java.util.List-">withSplitOffsets(List&lt;Long&gt;)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/DataFiles.Builder.html" title="class in org.apache.iceberg">DataFiles.Builder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/FileMetadata.Builder.html#withSplitOffsets-java.util.List-">withSplitOffsets(List&lt;Long&gt;)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/FileMetadata.Builder.html" title="class in org.apache.iceberg">FileMetadata.Builder</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/responses/ErrorResponse.Builder.html#withStackTrace-java.lang.Throwable-">withStackTrace(Throwable)</a></span> - Method in class org.apache.iceberg.rest.responses.<a href="org/apache/iceberg/rest/responses/ErrorResponse.Builder.html" title="class in org.apache.iceberg.rest.responses">ErrorResponse.Builder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/rest/responses/ErrorResponse.Builder.html#withStackTrace-java.util.List-">withStackTrace(List&lt;String&gt;)</a></span> - Method in class org.apache.iceberg.rest.responses.<a href="org/apache/iceberg/rest/responses/ErrorResponse.Builder.html" title="class in org.apache.iceberg.rest.responses">ErrorResponse.Builder</a></dt>
@@ -26283,8 +27663,6 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#WRITE">WRITE</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html#write-T-">write(T)</a></span> - Method in interface org.apache.spark.sql.connector.iceberg.write.<a href="org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html" title="interface in org.apache.spark.sql.connector.iceberg.write">DeltaWriter</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#WRITE_AUDIT_PUBLISH_ENABLED">WRITE_AUDIT_PUBLISH_ENABLED</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#WRITE_AUDIT_PUBLISH_ENABLED_DEFAULT">WRITE_AUDIT_PUBLISH_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
@@ -26315,12 +27693,30 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#WRITE_METADATA_LOCATION">WRITE_METADATA_LOCATION</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_NAMESPACE_TAG_ENABLED">WRITE_NAMESPACE_TAG_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Used by <a href="org/apache/iceberg/aws/glue/GlueCatalog.html" title="class in org.apache.iceberg.aws.glue"><code>GlueCatalog</code></a> to tag objects when writing.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_NAMESPACE_TAG_ENABLED_DEFAULT">WRITE_NAMESPACE_TAG_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/io/FileIOMetricsContext.html#WRITE_OPERATIONS">WRITE_OPERATIONS</a></span> - Static variable in interface org.apache.iceberg.io.<a href="org/apache/iceberg/io/FileIOMetricsContext.html" title="interface in org.apache.iceberg.io">FileIOMetricsContext</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteOptions.html#WRITE_PARALLELISM">WRITE_PARALLELISM</a></span> - Static variable in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteOptions.html" title="class in org.apache.iceberg.flink">FlinkWriteOptions</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#WRITE_PARTITION_SUMMARY_LIMIT">WRITE_PARTITION_SUMMARY_LIMIT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#WRITE_PARTITION_SUMMARY_LIMIT_DEFAULT">WRITE_PARTITION_SUMMARY_LIMIT_DEFAULT</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TABLE_TAG_ENABLED">WRITE_TABLE_TAG_ENABLED</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Used by <a href="org/apache/iceberg/aws/glue/GlueCatalog.html" title="class in org.apache.iceberg.aws.glue"><code>GlueCatalog</code></a> to tag objects when writing.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TABLE_TAG_ENABLED_DEFAULT">WRITE_TABLE_TAG_ENABLED_DEFAULT</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#WRITE_TAGS_PREFIX">WRITE_TAGS_PREFIX</a></span> - Static variable in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>
+<div class="block">Used by <a href="org/apache/iceberg/aws/s3/S3FileIO.html" title="class in org.apache.iceberg.aws.s3"><code>S3FileIO</code></a> to tag objects when writing.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/mr/InputFormatConfig.html#WRITE_TARGET_FILE_SIZE">WRITE_TARGET_FILE_SIZE</a></span> - Static variable in class org.apache.iceberg.mr.<a href="org/apache/iceberg/mr/InputFormatConfig.html" title="class in org.apache.iceberg.mr">InputFormatConfig</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/TableProperties.html#WRITE_TARGET_FILE_SIZE_BYTES">WRITE_TARGET_FILE_SIZE_BYTES</a></span> - Static variable in class org.apache.iceberg.<a href="org/apache/iceberg/TableProperties.html" title="class in org.apache.iceberg">TableProperties</a></dt>
@@ -26411,10 +27807,16 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/BinPackStrategy.html#writeMaxFileSize--">writeMaxFileSize()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/BinPackStrategy.html" title="class in org.apache.iceberg.actions">BinPackStrategy</a></dt>
 <dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
 <div class="block">Estimates a larger max target file size than our target size used in task creation to avoid
  tasks which are predicted to have a certain size, but exceed that target size when serde is
  complete creating tiny remainder files.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#writeMaxFileSize--">writeMaxFileSize()</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>
+<div class="block">Estimates a larger max target file size than the target size used in task creation to avoid
+ creating tiny remainder files.</div>
+</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetastoreTableOperations.html#writeNewMetadata-org.apache.iceberg.TableMetadata-int-">writeNewMetadata(TableMetadata, int)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetastoreTableOperations.html" title="class in org.apache.iceberg">BaseMetastoreTableOperations</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/BaseMetastoreTableOperations.html#writeNewMetadataIfRequired-boolean-org.apache.iceberg.TableMetadata-">writeNewMetadataIfRequired(boolean, TableMetadata)</a></span> - Method in class org.apache.iceberg.<a href="org/apache/iceberg/BaseMetastoreTableOperations.html" title="class in org.apache.iceberg">BaseMetastoreTableOperations</a></dt>
@@ -26440,12 +27842,20 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.WriteOrderingSpecContext.html#WriteOrderingSpecContext-org.antlr.v4.runtime.ParserRuleContext-int-">WriteOrderingSpecContext(ParserRuleContext, int)</a></span> - Constructor for class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.WriteOrderingSpecContext.html" title="class in org.apache.s [...]
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/FlinkWriteConf.html#writeParallelism--">writeParallelism()</a></span> - Method in class org.apache.iceberg.flink.<a href="org/apache/iceberg/flink/FlinkWriteConf.html" title="class in org.apache.iceberg.flink">FlinkWriteConf</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/flink/sink/FlinkSink.Builder.html#writeParallelism-int-">writeParallelism(int)</a></span> - Method in class org.apache.iceberg.flink.sink.<a href="org/apache/iceberg/flink/sink/FlinkSink.Builder.html" title="class in org.apache.iceberg.flink.sink">FlinkSink.Builder</a></dt>
 <dd>
 <div class="block">Configuring the write parallel number for iceberg stream writer.</div>
 </dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/avro/ValueWriters.StructWriter.html#writer-int-">writer(int)</a></span> - Method in class org.apache.iceberg.avro.<a href="org/apache/iceberg/avro/ValueWriters.StructWriter.html" title="class in org.apache.iceberg.avro">ValueWriters.StructWriter</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteConf.html#writeRequirements--">writeRequirements()</a></span> - Method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteConf.html" title="class in org.apache.iceberg.spark">SparkWriteConf</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/spark/SparkWriteUtil.html#writeRequirements-org.apache.iceberg.Table-org.apache.iceberg.DistributionMode-boolean-">writeRequirements(Table, DistributionMode, boolean)</a></span> - Static method in class org.apache.iceberg.spark.<a href="org/apache/iceberg/spark/SparkWriteUtil.html" title="class in org.apache.iceberg.spark">SparkWriteUtil</a></dt>
+<dd>
+<div class="block">Builds requirements for batch and micro-batch writes such as append or overwrite.</div>
+</dd>
 <dt><a href="org/apache/iceberg/io/WriteResult.html" title="class in org.apache.iceberg.io"><span class="typeNameLink">WriteResult</span></a> - Class in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/io/WriteResult.Builder.html" title="class in org.apache.iceberg.io"><span class="typeNameLink">WriteResult.Builder</span></a> - Class in <a href="org/apache/iceberg/io/package-summary.html">org.apache.iceberg.io</a></dt>
@@ -26478,8 +27888,14 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/parquet/Parquet.WriteBuilder.html#writeSupport-org.apache.parquet.hadoop.api.WriteSupport-">writeSupport(WriteSupport&lt;?&gt;)</a></span> - Method in class org.apache.iceberg.parquet.<a href="org/apache/iceberg/parquet/Parquet.WriteBuilder.html" title="class in org.apache.iceberg.parquet">Parquet.WriteBuilder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#writeTableTagEnabled--">writeTableTagEnabled()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html#writeTags--">writeTags()</a></span> - Method in class org.apache.iceberg.aws.s3.<a href="org/apache/iceberg/aws/s3/S3FileIOProperties.html" title="class in org.apache.iceberg.aws.s3">S3FileIOProperties</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/iceberg/puffin/PuffinWriter.html#writtenBlobsMetadata--">writtenBlobsMetadata()</a></span> - Method in class org.apache.iceberg.puffin.<a href="org/apache/iceberg/puffin/PuffinWriter.html" title="class in org.apache.iceberg.puffin">PuffinWriter</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html#wronglySized-T-">wronglySized(T)</a></span> - Method in class org.apache.iceberg.actions.<a href="org/apache/iceberg/actions/SizeBasedFileRewriter.html" title="class in org.apache.iceberg.actions">SizeBasedFileRewriter</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html#WS">WS</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsLexer.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsLexer</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html#WS">WS</a></span> - Static variable in class org.apache.spark.sql.catalyst.parser.extensions.<a href="org/apache/spark/sql/catalyst/parser/extensions/IcebergSqlExtensionsParser.html" title="class in org.apache.spark.sql.catalyst.parser.extensions">IcebergSqlExtensionsParser</a></dt>
@@ -26520,6 +27936,8 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/YearsFunction.DateToYearsFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">YearsFunction.DateToYearsFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampNtzToYearsFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">YearsFunction.TimestampNtzToYearsFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/iceberg/spark/functions/YearsFunction.TimestampToYearsFunction.html" title="class in org.apache.iceberg.spark.functions"><span class="typeNameLink">YearsFunction.TimestampToYearsFunction</span></a> - Class in <a href="org/apache/iceberg/spark/functions/package-summary.html">org.apache.iceberg.spark.functions</a></dt>
 <dd>&nbsp;</dd>
 </dl>
diff --git a/javadoc/org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html b/javadoc/org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html
index 3677e4d5..63091eb0 100644
--- a/javadoc/org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html
+++ b/javadoc/org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html
@@ -17,8 +17,8 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":42,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":10,"i30":42,"i31":10,"i32":10,"i33":10,"i34":10,"i35":10};
-var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"],32:["t6","Deprecated Methods"]};
+var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":10,"i30":10,"i31":10,"i32":10,"i33":10,"i34":10};
+var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
 var tableTab = "tableTab";
@@ -148,6 +148,10 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 <td class="colFirst"><code>protected static java.util.List&lt;java.lang.String&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#DELETE_SCAN_WITH_STATS_COLUMNS">DELETE_SCAN_WITH_STATS_COLUMNS</a></span></code>&nbsp;</td>
 </tr>
+<tr class="altColor">
+<td class="colFirst"><code>protected static java.util.List&lt;java.lang.String&gt;</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#SCAN_COLUMNS">SCAN_COLUMNS</a></span></code>&nbsp;</td>
+</tr>
 </table>
 </li>
 </ul>
@@ -158,7 +162,7 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 </a>
 <h3>Method Summary</h3>
 <table class="memberSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
-<caption><span id="t0" class="activeTableTab"><span>All Methods</span><span class="tabEnd">&nbsp;</span></span><span id="t2" class="tableTab"><span><a href="javascript:show(2);">Instance Methods</a></span><span class="tabEnd">&nbsp;</span></span><span id="t4" class="tableTab"><span><a href="javascript:show(8);">Concrete Methods</a></span><span class="tabEnd">&nbsp;</span></span><span id="t6" class="tableTab"><span><a href="javascript:show(32);">Deprecated Methods</a></span><span class="t [...]
+<caption><span id="t0" class="activeTableTab"><span>All Methods</span><span class="tabEnd">&nbsp;</span></span><span id="t2" class="tableTab"><span><a href="javascript:show(2);">Instance Methods</a></span><span class="tabEnd">&nbsp;</span></span><span id="t4" class="tableTab"><span><a href="javascript:show(8);">Concrete Methods</a></span><span class="tabEnd">&nbsp;</span></span></caption>
 <tr>
 <th class="colFirst" scope="col">Modifier and Type</th>
 <th class="colLast" scope="col">Method and Description</th>
@@ -239,15 +243,10 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 </td>
 </tr>
 <tr id="i12" class="altColor">
-<td class="colFirst"><code>protected ThisT</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#newRefinedScan-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-org.apache.iceberg.Schema-org.apache.iceberg.TableScanContext-">newRefinedScan</a></span>(<a href="../../../org/apache/iceberg/TableOperations.html" title="interface in org.apache.iceberg">TableOperations</a>&nbsp;ignored,
-              <a href="../../../org/apache/iceberg/Table.html" title="interface in org.apache.iceberg">Table</a>&nbsp;newTable,
-              <a href="../../../org/apache/iceberg/Schema.html" title="class in org.apache.iceberg">Schema</a>&nbsp;newSchema,
-              org.apache.iceberg.TableScanContext&nbsp;newContext)</code>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>&nbsp;
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; use newRefinedScan(Table, Schema, TableScanContext)
-     instead.</span></div>
-</div>
+<td class="colFirst"><code>ThisT</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#metricsReporter-org.apache.iceberg.metrics.MetricsReporter-">metricsReporter</a></span>(<a href="../../../org/apache/iceberg/metrics/MetricsReporter.html" title="interface in org.apache.iceberg.metrics">MetricsReporter</a>&nbsp;reporter)</code>
+<div class="block">Create a new scan that will report scan metrics to the provided reporter in addition to
+ reporters maintained by the scan.</div>
 </td>
 </tr>
 <tr id="i13" class="rowColor">
@@ -341,38 +340,30 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#table--">table</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i30" class="altColor">
-<td class="colFirst"><code>protected <a href="../../../org/apache/iceberg/TableOperations.html" title="interface in org.apache.iceberg">TableOperations</a></code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#tableOps--">tableOps</a></span>()</code>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>&nbsp;
-<div class="block"><span class="deprecationComment">will be removed in 1.3.0; avoid using TableOperations for scans or use BaseTable</span></div>
-</div>
-</td>
-</tr>
-<tr id="i31" class="rowColor">
 <td class="colFirst"><code>protected <a href="../../../org/apache/iceberg/Schema.html" title="class in org.apache.iceberg">Schema</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#tableSchema--">tableSchema</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i32" class="altColor">
+<tr id="i31" class="rowColor">
 <td class="colFirst"><code>protected <a href="../../../org/apache/iceberg/MetadataTableType.html" title="enum in org.apache.iceberg">MetadataTableType</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#tableType--">tableType</a></span>()</code>
 <div class="block">Type of scan being performed, such as <a href="../../../org/apache/iceberg/MetadataTableType.html#ALL_DATA_FILES"><code>MetadataTableType.ALL_DATA_FILES</code></a> when scanning a
  table's <a href="../../../org/apache/iceberg/AllDataFilesTable.html" title="class in org.apache.iceberg"><code>AllDataFilesTable</code></a>.</div>
 </td>
 </tr>
-<tr id="i33" class="rowColor">
+<tr id="i32" class="altColor">
 <td class="colFirst"><code>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#targetSplitSize--">targetSplitSize</a></span>()</code>
 <div class="block">Returns the target split size for this scan.</div>
 </td>
 </tr>
-<tr id="i34" class="altColor">
+<tr id="i33" class="rowColor">
 <td class="colFirst"><code><a href="../../../org/apache/iceberg/TableScan.html" title="interface in org.apache.iceberg">TableScan</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#useRef-java.lang.String-">useRef</a></span>(java.lang.String&nbsp;ref)</code>
 <div class="block">Create a new <a href="../../../org/apache/iceberg/TableScan.html" title="interface in org.apache.iceberg"><code>TableScan</code></a> from this scan's configuration that will use the given
  reference.</div>
 </td>
 </tr>
-<tr id="i35" class="rowColor">
+<tr id="i34" class="altColor">
 <td class="colFirst"><code><a href="../../../org/apache/iceberg/TableScan.html" title="interface in org.apache.iceberg">TableScan</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDataFilesTable.AllDataFilesTableScan.html#useSnapshot-long-">useSnapshot</a></span>(long&nbsp;scanSnapshotId)</code>
 <div class="block">Create a new <a href="../../../org/apache/iceberg/TableScan.html" title="interface in org.apache.iceberg"><code>TableScan</code></a> from this scan's configuration that will use the given snapshot
@@ -406,7 +397,7 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 <!--   -->
 </a>
 <h3>Methods inherited from interface&nbsp;org.apache.iceberg.<a href="../../../org/apache/iceberg/Scan.html" title="interface in org.apache.iceberg">Scan</a></h3>
-<code><a href="../../../org/apache/iceberg/Scan.html#caseSensitive-boolean-">caseSensitive</a>, <a href="../../../org/apache/iceberg/Scan.html#filter--">filter</a>, <a href="../../../org/apache/iceberg/Scan.html#filter-org.apache.iceberg.expressions.Expression-">filter</a>, <a href="../../../org/apache/iceberg/Scan.html#ignoreResiduals--">ignoreResiduals</a>, <a href="../../../org/apache/iceberg/Scan.html#includeColumnStats--">includeColumnStats</a>, <a href="../../../org/apache/iceberg/ [...]
+<code><a href="../../../org/apache/iceberg/Scan.html#caseSensitive-boolean-">caseSensitive</a>, <a href="../../../org/apache/iceberg/Scan.html#filter--">filter</a>, <a href="../../../org/apache/iceberg/Scan.html#filter-org.apache.iceberg.expressions.Expression-">filter</a>, <a href="../../../org/apache/iceberg/Scan.html#ignoreResiduals--">ignoreResiduals</a>, <a href="../../../org/apache/iceberg/Scan.html#includeColumnStats--">includeColumnStats</a>, <a href="../../../org/apache/iceberg/ [...]
 </ul>
 </li>
 </ul>
@@ -422,6 +413,15 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 <!--   -->
 </a>
 <h3>Field Detail</h3>
+<a name="SCAN_COLUMNS">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>SCAN_COLUMNS</h4>
+<pre>protected static final&nbsp;java.util.List&lt;java.lang.String&gt; SCAN_COLUMNS</pre>
+</li>
+</ul>
 <a name="DELETE_SCAN_COLUMNS">
 <!--   -->
 </a>
@@ -672,17 +672,6 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 </dl>
 </li>
 </ul>
-<a name="tableOps--">
-<!--   -->
-</a>
-<ul class="blockList">
-<li class="blockList">
-<h4>tableOps</h4>
-<pre>@Deprecated
-protected&nbsp;<a href="../../../org/apache/iceberg/TableOperations.html" title="interface in org.apache.iceberg">TableOperations</a>&nbsp;tableOps()</pre>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>&nbsp;<span class="deprecationComment">will be removed in 1.3.0; avoid using TableOperations for scans or use BaseTable</span></div>
-</li>
-</ul>
 <a name="table--">
 <!--   -->
 </a>
@@ -755,21 +744,6 @@ protected&nbsp;<a href="../../../org/apache/iceberg/TableOperations.html" title=
 <pre>protected&nbsp;java.util.concurrent.ExecutorService&nbsp;planExecutor()</pre>
 </li>
 </ul>
-<a name="newRefinedScan-org.apache.iceberg.TableOperations-org.apache.iceberg.Table-org.apache.iceberg.Schema-org.apache.iceberg.TableScanContext-">
-<!--   -->
-</a>
-<ul class="blockList">
-<li class="blockList">
-<h4>newRefinedScan</h4>
-<pre>@Deprecated
-protected&nbsp;ThisT&nbsp;newRefinedScan(<a href="../../../org/apache/iceberg/TableOperations.html" title="interface in org.apache.iceberg">TableOperations</a>&nbsp;ignored,
-                                           <a href="../../../org/apache/iceberg/Table.html" title="interface in org.apache.iceberg">Table</a>&nbsp;newTable,
-                                           <a href="../../../org/apache/iceberg/Schema.html" title="class in org.apache.iceberg">Schema</a>&nbsp;newSchema,
-                                           org.apache.iceberg.TableScanContext&nbsp;newContext)</pre>
-<div class="block"><span class="deprecatedLabel">Deprecated.</span>&nbsp;<span class="deprecationComment">will be removed in 1.3.0; use newRefinedScan(Table, Schema, TableScanContext)
-     instead.</span></div>
-</li>
-</ul>
 <a name="option-java.lang.String-java.lang.String-">
 <!--   -->
 </a>
@@ -1002,7 +976,7 @@ protected&nbsp;ThisT&nbsp;newRefinedScan(<a href="../../../org/apache/iceberg/Ta
 <a name="splitOpenFileCost--">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>splitOpenFileCost</h4>
 <pre>public&nbsp;long&nbsp;splitOpenFileCost()</pre>
@@ -1014,6 +988,22 @@ protected&nbsp;ThisT&nbsp;newRefinedScan(<a href="../../../org/apache/iceberg/Ta
 </dl>
 </li>
 </ul>
+<a name="metricsReporter-org.apache.iceberg.metrics.MetricsReporter-">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>metricsReporter</h4>
+<pre>public&nbsp;ThisT&nbsp;metricsReporter(<a href="../../../org/apache/iceberg/metrics/MetricsReporter.html" title="interface in org.apache.iceberg.metrics">MetricsReporter</a>&nbsp;reporter)</pre>
+<div class="block"><span class="descfrmTypeLabel">Description copied from interface:&nbsp;<code><a href="../../../org/apache/iceberg/Scan.html#metricsReporter-org.apache.iceberg.metrics.MetricsReporter-">Scan</a></code></span></div>
+<div class="block">Create a new scan that will report scan metrics to the provided reporter in addition to
+ reporters maintained by the scan.</div>
+<dl>
+<dt><span class="overrideSpecifyLabel">Specified by:</span></dt>
+<dd><code><a href="../../../org/apache/iceberg/Scan.html#metricsReporter-org.apache.iceberg.metrics.MetricsReporter-">metricsReporter</a></code>&nbsp;in interface&nbsp;<code><a href="../../../org/apache/iceberg/Scan.html" title="interface in org.apache.iceberg">Scan</a>&lt;ThisT,T extends <a href="../../../org/apache/iceberg/ScanTask.html" title="interface in org.apache.iceberg">ScanTask</a>,G extends <a href="../../../org/apache/iceberg/ScanTaskGroup.html" title="interface in org.apache [...]
+</dl>
+</li>
+</ul>
 </li>
 </ul>
 </li>
diff --git a/javadoc/org/apache/iceberg/AllDeleteFilesTable.AllDeleteFilesTableScan.html b/javadoc/org/apache/iceberg/AllDeleteFilesTable.AllDeleteFilesTableScan.html
index f70f8fd1..ceccfe31 100644
--- a/javadoc/org/apache/iceberg/AllDeleteFilesTable.AllDeleteFilesTableScan.html
+++ b/javadoc/org/apache/iceberg/AllDeleteFilesTable.AllDeleteFilesTableScan.html
@@ -17,8 +17,8 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":42,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":10,"i30":42,"i31":10,"i32":10,"i33":10,"i34":10,"i35":10};
-var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"],32:["t6","Deprecated Methods"]};
+var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":10,"i30":10,"i31":10,"i32":10,"i33":10,"i34":10};
+var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
 var tableTab = "tableTab";
@@ -148,6 +148,10 @@ extends <a href="../../../org/apache/iceberg/SnapshotScan.html" title="class in
 <td class="colFirst"><code>protected static java.util.List&lt;java.lang.String&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDeleteFilesTable.AllDeleteFilesTableScan.html#DELETE_SCAN_WITH_STATS_COLUMNS">DELETE_SCAN_WITH_STATS_COLUMNS</a></span></code>&nbsp;</td>
 </tr>
+<tr class="altColor">
+<td class="colFirst"><code>protected static java.util.List&lt;java.lang.String&gt;</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../org/apache/iceberg/AllDeleteFilesTable.AllDeleteFilesTableScan.html#SCAN_COLUMNS">SCAN_COLUMNS</a></span></code>&nbsp;</td>
+</tr>
 </table>
... 41978 lines suppressed ...