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 22:06:17 UTC

[iceberg-docs] branch latest updated (b5f5ca45 -> 8bee6f6f)

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

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


 discard b5f5ca45 Add links to Iceberg 1.2.1 (#238)
    omit 919daf1f Fix branching and tagging images on latest branch (#232)
    omit 9ef99d55 Update latest branch to include branching/tagging docs and table migration docs (#229)
     add 30cafae0 Landing page and release notes updates for 1.2.1
     add 44cd4c13 Merge pull request #226 from danielcweeks/docs/1.2.1-landing
     add 3bed2378 Add graphs for table migration section (#220)
     add 803020e2 Add images for branching and tagging docs
     add 6c99f4df Merge pull request #208 from amogh-jahagirdar/branching-tagging-images
     add 7a704378 Deprecate Spark 3.1 (#227)
     add 9c5cc5b2 Copy latest docs from iceberg repo into iceberg-docs (#228)
     add a69e6a37 Add link to Iceberg 1.2.1 (#233)
     add 2dac2917 Docs: Update Iceberg Slack Join Link (#236)
     add c827f2d8 Update Slack invite link in header.html (#237)
     add 9b96cc17 Common docs for 1.3.0 (#241)
     add 8bfa72ad Versioned docs for 1.3.0 (#242)
     add 8bee6f6f Javadoc for 1.3.0 (#243)

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (b5f5ca45)
            \
             N -- N -- N   refs/heads/latest (8bee6f6f)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

Summary of changes:
 docs/config.toml                                   |    5 +-
 docs/content/aws.md                                |   72 +-
 docs/content/branching-and-tagging.md              |    3 +-
 docs/content/configuration.md                      |  104 +-
 docs/content/dell.md                               |    1 +
 docs/content/delta-lake-migration.md               |    1 +
 docs/content/evolution.md                          |    1 +
 docs/content/flink-actions.md                      |    1 +
 docs/content/flink-configuration.md                |   46 +-
 docs/content/flink-connector.md                    |    1 +
 docs/content/flink-ddl.md                          |    1 +
 docs/content/flink-getting-started.md              |    1 +
 docs/content/flink-queries.md                      |    1 +
 docs/content/flink-writes.md                       |    1 +
 docs/content/hive-migration.md                     |    1 +
 docs/content/hive.md                               |    4 +-
 docs/content/java-api-quickstart.md                |  125 +
 docs/content/java-api.md                           |    1 +
 docs/content/java-custom-catalog.md                |    1 +
 docs/content/jdbc.md                               |    1 +
 docs/content/maintenance.md                        |    1 +
 docs/content/nessie.md                             |    1 +
 docs/content/partitioning.md                       |    1 +
 docs/content/performance.md                        |    1 +
 docs/content/reliability.md                        |    1 +
 docs/content/schemas.md                            |    1 +
 docs/content/spark-configuration.md                |   29 +-
 docs/content/spark-ddl.md                          |   11 +-
 docs/content/spark-getting-started.md              |    1 +
 docs/content/spark-procedures.md                   |   46 +
 docs/content/spark-queries.md                      |   47 +-
 docs/content/spark-structured-streaming.md         |    5 +-
 docs/content/spark-writes.md                       |  176 +-
 docs/content/table-migration.md                    |    1 +
 iceberg-theme/layouts/partials/header.html         |    2 +-
 .../img/iceberg-in-place-metadata-migration.png    |  Bin 0 -> 31816 bytes
 .../static/img/iceberg-migrateaction-step1.png     |  Bin 0 -> 16223 bytes
 .../static/img/iceberg-migrateaction-step2.png     |  Bin 0 -> 29566 bytes
 .../static/img/iceberg-migrateaction-step3.png     |  Bin 0 -> 19704 bytes
 .../static/img/iceberg-snapshotaction-step1.png    |  Bin 0 -> 39814 bytes
 .../static/img/iceberg-snapshotaction-step2.png    |  Bin 0 -> 42512 bytes
 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} |  105 +-
 ...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 +-
 ...ocation.html => DictEncodedArrowConverter.html} |   39 +-
 .../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 +-
 .../AwsClientProperties.html}                      |  221 +-
 javadoc/org/apache/iceberg/aws/AwsProperties.html  | 1158 +++++++--
 .../apache/iceberg/aws/HttpClientProperties.html   |  666 +++++
 .../org/apache/iceberg/aws/RESTSigV4Signer.html    |    8 +-
 .../S3FileIOAwsClientFactories.html}               |   58 +-
 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}              |   65 +-
 .../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}                       |   96 +-
 .../iceberg/aws/{glue => util}/package-frame.html  |    6 +-
 .../{gcp/gcs => aws/util}/package-summary.html     |   23 +-
 .../{gcp/gcs => aws/util}/package-tree.html        |   20 +-
 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 +-
 .../Zorder.html => flink/FlinkSourceFilter.html}   |   60 +-
 .../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 +-
 .../iceberg/{io/FileInfo.html => hive/NoLock.html} |   80 +-
 .../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 +
 .../{nessie => inmemory}/package-summary.html      |   32 +-
 .../{snowflake => inmemory}/package-tree.html      |   23 +-
 .../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}                         |   45 +-
 .../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 +-
 .../iceberg/spark/FileScanTaskSetManager.html      |  313 ---
 javadoc/org/apache/iceberg/spark/IcebergSpark.html |    4 +-
 .../org/apache/iceberg/spark/PathIdentifier.html   |    4 +-
 ...html => PositionDeletesRewriteCoordinator.html} |   74 +-
 .../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 +-
 ...rkTableCache.html => SparkFunctionCatalog.html} |  142 +-
 .../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}                   |   97 +-
 .../{orc/ORC.html => spark/SparkWriteUtil.html}    |  134 +-
 .../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 +-
 ...rkPositionDeletesRewrite.DeleteTaskCommit.html} |   43 +-
 .../SparkPositionDeletesRewrite.html}              |   72 +-
 .../SparkPositionDeletesRewriteBuilder.html}       |   73 +-
 .../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 --
 .../connector/iceberg/write/DeltaWriteBuilder.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 ++++++---
 landing-page/content/common/join.md                |    2 +-
 .../content/common/multi-engine-support.md         |    2 +-
 landing-page/content/common/release-notes.md       |   24 +-
 landing-page/content/common/view-spec.md           |  329 ++-
 374 files changed, 17697 insertions(+), 12294 deletions(-)
 create mode 100644 iceberg-theme/static/img/iceberg-in-place-metadata-migration.png
 create mode 100644 iceberg-theme/static/img/iceberg-migrateaction-step1.png
 create mode 100644 iceberg-theme/static/img/iceberg-migrateaction-step2.png
 create mode 100644 iceberg-theme/static/img/iceberg-migrateaction-step3.png
 create mode 100644 iceberg-theme/static/img/iceberg-snapshotaction-step1.png
 create mode 100644 iceberg-theme/static/img/iceberg-snapshotaction-step2.png
 delete mode 100644 javadoc/org/apache/iceberg/actions/BaseExpireSnapshotsActionResult.html
 copy javadoc/org/apache/iceberg/actions/{MigrateTable.html => FileRewriter.html} (50%)
 copy javadoc/org/apache/iceberg/actions/{RewriteDataFiles.FileGroupInfo.html => RewriteDataFiles.FileGroupFailureResult.html} (70%)
 copy javadoc/org/apache/iceberg/actions/{RewritePositionDeleteFiles.Result.html => RewritePositionDeleteFiles.FileGroupInfo.html} (69%)
 copy javadoc/org/apache/iceberg/actions/{RewritePositionDeleteFiles.Result.html => RewritePositionDeleteFiles.FileGroupRewriteResult.html} (60%)
 copy javadoc/org/apache/iceberg/actions/{RewriteDataFilesCommitManager.CommitService.html => RewritePositionDeletesCommitManager.CommitService.html} (59%)
 copy javadoc/org/apache/iceberg/actions/{RewriteDataFilesCommitManager.html => RewritePositionDeletesCommitManager.html} (61%)
 copy javadoc/org/apache/iceberg/actions/{RewriteFileGroup.html => RewritePositionDeletesGroup.html} (51%)
 create mode 100644 javadoc/org/apache/iceberg/actions/SizeBasedDataRewriter.html
 create mode 100644 javadoc/org/apache/iceberg/actions/SizeBasedFileRewriter.html
 create mode 100644 javadoc/org/apache/iceberg/actions/SizeBasedPositionDeletesRewriter.html
 copy javadoc/org/apache/iceberg/arrow/{ArrowAllocation.html => DictEncodedArrowConverter.html} (73%)
 copy javadoc/org/apache/iceberg/arrow/vectorized/parquet/{VectorizedColumnIterator.TimestampMillisBatchReader.html => VectorizedColumnIterator.TimestampInt96BatchReader.html} (87%)
 copy javadoc/org/apache/iceberg/{dell/DellProperties.html => aws/AwsClientProperties.html} (56%)
 create mode 100644 javadoc/org/apache/iceberg/aws/HttpClientProperties.html
 copy javadoc/org/apache/iceberg/{util/DecimalUtil.html => aws/S3FileIOAwsClientFactories.html} (70%)
 copy javadoc/org/apache/iceberg/{spark/procedures/SparkProcedures.ProcedureBuilder.html => aws/s3/S3FileIOAwsClientFactory.html} (66%)
 create mode 100644 javadoc/org/apache/iceberg/aws/s3/S3FileIOProperties.html
 copy javadoc/org/apache/iceberg/{spark/source/SparkMetadataColumn.html => aws/util/RetryDetector.html} (67%)
 copy javadoc/org/apache/iceberg/aws/{glue => util}/package-frame.html (59%)
 copy javadoc/org/apache/iceberg/{gcp/gcs => aws/util}/package-summary.html (79%)
 copy javadoc/org/apache/iceberg/{gcp/gcs => aws/util}/package-tree.html (75%)
 copy javadoc/org/apache/iceberg/{expressions/Zorder.html => flink/FlinkSourceFilter.html} (67%)
 copy javadoc/org/apache/iceberg/{io/FileInfo.html => hive/NoLock.html} (75%)
 copy javadoc/org/apache/iceberg/{jdbc/JdbcCatalog.html => inmemory/InMemoryCatalog.html} (76%)
 copy javadoc/org/apache/iceberg/{io/ResolvingFileIO.html => inmemory/InMemoryFileIO.html} (55%)
 copy javadoc/org/apache/iceberg/{actions/BaseRewriteDataFilesFileGroupInfo.html => inmemory/InMemoryInputFile.html} (56%)
 create mode 100644 javadoc/org/apache/iceberg/inmemory/InMemoryOutputFile.html
 create mode 100644 javadoc/org/apache/iceberg/inmemory/package-frame.html
 copy javadoc/org/apache/iceberg/{nessie => inmemory}/package-summary.html (71%)
 copy javadoc/org/apache/iceberg/{snowflake => inmemory}/package-tree.html (62%)
 copy javadoc/org/apache/iceberg/{pig/PigParquetReader.html => metrics/MetricsReporters.html} (68%)
 copy javadoc/org/apache/iceberg/spark/{ChangelogIterator.html => ComputeUpdateIterator.html} (58%)
 delete mode 100644 javadoc/org/apache/iceberg/spark/FileScanTaskSetManager.html
 copy javadoc/org/apache/iceberg/spark/{FileRewriteCoordinator.html => PositionDeletesRewriteCoordinator.html} (65%)
 delete mode 100644 javadoc/org/apache/iceberg/spark/SparkDistributionAndOrderingUtil.html
 copy javadoc/org/apache/iceberg/spark/{SparkTableCache.html => SparkFunctionCatalog.html} (55%)
 copy javadoc/org/apache/iceberg/{metrics/Timer.Timed.html => spark/SparkWriteRequirements.html} (65%)
 copy javadoc/org/apache/iceberg/{orc/ORC.html => spark/SparkWriteUtil.html} (51%)
 copy javadoc/org/apache/iceberg/spark/actions/{RewriteManifestsSparkAction.html => RewritePositionDeleteFilesSparkAction.html} (65%)
 delete mode 100644 javadoc/org/apache/iceberg/spark/actions/SparkBinPackStrategy.html
 delete mode 100644 javadoc/org/apache/iceberg/spark/actions/SparkSortStrategy.html
 delete mode 100644 javadoc/org/apache/iceberg/spark/actions/SparkZOrderStrategy.html
 copy javadoc/org/apache/iceberg/spark/functions/{DaysFunction.TimestampToDaysFunction.html => DaysFunction.TimestampNtzToDaysFunction.html} (84%)
 copy javadoc/org/apache/iceberg/spark/functions/{HoursFunction.TimestampToHoursFunction.html => HoursFunction.TimestampNtzToHoursFunction.html} (85%)
 copy javadoc/org/apache/iceberg/spark/functions/{MonthsFunction.DateToMonthsFunction.html => MonthsFunction.TimestampNtzToMonthsFunction.html} (84%)
 copy javadoc/org/apache/iceberg/spark/functions/{YearsFunction.TimestampToYearsFunction.html => YearsFunction.TimestampNtzToYearsFunction.html} (84%)
 copy javadoc/org/apache/iceberg/spark/procedures/{RemoveOrphanFilesProcedure.html => RewritePositionDeleteFilesProcedure.html} (79%)
 copy javadoc/org/apache/iceberg/spark/{data/SparkValueWriters.html => source/SparkPositionDeletesRewrite.DeleteTaskCommit.html} (67%)
 copy javadoc/org/apache/iceberg/spark/{procedures/SparkProcedures.html => source/SparkPositionDeletesRewrite.html} (63%)
 copy javadoc/org/apache/iceberg/{flink/source/FlinkInputSplit.html => spark/source/SparkPositionDeletesRewriteBuilder.html} (64%)
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/DeltaBatchWrite.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/DeltaWrite.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/DeltaWriteBuilder.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/DeltaWriter.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/DeltaWriterFactory.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/ExtendedLogicalWriteInfo.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/SupportsDelta.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/package-frame.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/package-summary.html
 delete mode 100644 javadoc/org/apache/spark/sql/connector/iceberg/write/package-tree.html