You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@impala.apache.org by gi...@apache.org on 2021/03/31 03:29:26 UTC

[impala] branch dependabot/pip/infra/python/deps/psutil-5.6.6 updated (ba6b911 -> d9eed9c)

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

github-bot pushed a change to branch dependabot/pip/infra/python/deps/psutil-5.6.6
in repository https://gitbox.apache.org/repos/asf/impala.git.


 discard ba6b911  Bump psutil from 5.6.3 to 5.6.6 in /infra/python/deps
     add f684ed7  IMPALA-10252: fix invalid runtime filters for outer joins
     add 69578db  IMPALA-9985/IMPALA-10378: Bump toolchain to include Centos 8.2
     add b5ba793  IMPALA-10360: Allow simple limit to be treated as sampling hint
     add a850cd3  IMPALA-10361: Use field id to resolve columns for Iceberg tables
     add c04de99  IMPALA-10343: increase control_service_queue_mem_limit
     add a3da5c5  IMPALA-10383: Fix data race on AdmissionController::queue_nodes_
     add 07f3ae3  IMPALA-10066: Fix test_cancellation_mid_command flakiness
     add eceec36  IMPALA-10385: Fix RPM repo ID capitalization for Centos 8.3
     add eb8b118  IMPALA-10384: Make partition names consistent between BE and FE
     add 4c0bdba  IMPALA-9865: part 1: basic profile log parser
     add 87b95a5  IMPALA-10386: Don't allow PARTITION BY SPEC for non-Iceberg tables
     add a8ac9f8  IMPALA-10390: impala-profile-tool JSON output
     add 9dd0abb  IMPALA-10287: Include parallelism in cost comparison of broadcast vs partition
     add d1f4a4c  IMPALA-10393: Iceberg field id-based column resolution fails in ASAN builds
     add a7e71b4  IMPALA-10358: Correct Iceberg type mappings
     add ec6070a  IMPALA-10391: Fix LIRS edge case for single unprotected entry
     add 8de7bf7  IMPALA-10398: Altering an Iceberg table might throw NullPointerException
     add 10fe4b6  IMPALA-10381: Fix overloading of --ldap_passwords_in_clear_ok
     add 296ed74  IMPALA-10380: INSERT INTO Iceberg tables with 'IDENTITY' partitions only
     add 6cb7cec  IMPALA-10237: Support Bucket and Truncate partition transforms as built-in functions
     add 1b86313  IMPALA-10211 (Part 1): Add support for role-related statements
     add 2fccd82  IMPALA-6671: Skip locked tables from topic updates
     add 6b292bd  IMPALA-10336: Coordinator return incorrect error to client
     add 3f2eab8  IMPALA-9966: Add missing breaks in SetQueryOption
     add 4099a60  IMPALA-10317: Add query option that limits huge joins at runtime
     add 29069b9  IMPALA-9550: Fix flakiness in TestResultSpoolingFetchSize.test_fetch
     add a6a2440  IMPALA-10374: Limit iteration at BufferedTupleStream::DebugString
     add 43b6093  IMPALA-10117: Skip calls to FsPermissionCache for blob stores
     add 5baadd1  IMPALA-10406: Query with analytic functions doesn't need to materialize the predicates bounded to kudu
     add a5f6c26  IMPALA-2536: Make ColumnType constructor explicit
     add 03af0b2  IMPALA-10422: EXPLAIN statements leak ACID transactions and locks
     add 4968055  IMPALA-10182: Don't add inferred identity predicates to SELECT node
     add 1d5fe27  IMPALA-6434: Add support to decode RLE_DICTIONARY encoded pages
     add 868a01d  IMPALA-6101: call DataStreamMgr::Cancel() once per query
     add e7839c4  IMPALA-10416: Add raw string mode for testfiles to verify non-ascii results
     add 200d366  IMPALA-10412: ConvertToCNFRule can be applied to view table
     add 0c7e5a4  IMPALA-10388: [DOCS] add limitations on mask functions
     add 799bc22  IMPALA-10424: Fix race on not_admitted_reason in AdmissionController
     add 44bade8  IMPALA-10091: [DOCS] add REFRESH_UPDATED_HMS_PARTITIONS query option
     add 35bae93  IMPALA-10427: Remove SkipIfS3.eventually_consistent pytest marker
     add 425e424  IMPALA-9687 Improve estimates for number of hosts in Kudu plans
     add ab6b796  IMPALA-10027: configurable default anonymous user
     add aa48651  IMPALA-9975 (part 1): Various refactors for admission control daemon
     add 1093a56  IMPALA-10368: Support required/optional property when creating Iceberg table
     add 91adb33  IMPALA-9975 (part 2): Introduce new admission control daemon
     add 696dafe  IMPALA-10426: Fix crash when inserting invalid timestamps
     add 5fddbb5  IMPALA-9865: part 2/2: add verbosity to profile tool
     add 9bb7157  IMPALA-10387: Add missing overloads of mask functions used in Ranger default masking policies
     add 90f3b2f  IMPALA-10432: INSERT INTO Iceberg tables with partition transforms
     add 8ecb61e  IMPALA-10259: Fixed DCHECK error for backend in terminal state
     add 4c6cf4b  IMPALA-10434: Fix impala-shell's unicode regressions on Python2
     add cdf5108  IMPALA-10441: Skip test_bytes_read_per_column if not on local minicluster
     add ac7f605  IMPALA-10421: [DOCS] Documented the JOIN_ROWS_PRODUCED_LIMIT query option
     add 5852a00  IMPALA-10440: Import Theta functionality from DataSketches
     add 18acca9  IMPALA-10435: Extend 'compute incremental stats' syntax to support a list of columns
     add 1ada739  IMPALA-10296: Fix analytic limit pushdown when predicates are present
     add 6d4756d  IMPALA-10448: Build impala-profile-tool early for Docker-based tests
     add 2644203  IMPALA-10147: Avoid getting a file handle for data cache hits
     add e8720b4  IMPALA-2019(Part-1): Provide UTF-8 support in length, substring and reverse functions
     add 3b763b5  IMPALA-10447: Add a newline when exporting shell output to a file.
     add eb85c6e  IMPALA-9793: Impala quickstart cluster with docker-compose
     add f4584dd  IMPALA-10404: Update docs to reflect RLE_DICTIONARY support
     add 08367e9  IMPALA-10452: CREATE Iceberg tables with old PARTITIONED BY syntax
     add 4ae847b  IMPALA-10382: fix invalid outer join simplification
     add 4c828b6  IMPALA-8306: clarify wording on /sessions UI
     add 39c424d  IMPALA-10454: Bump --ssl_minimum_version to tls1.2
     add f086d5c  IMPALA-10462: Include org/apache/hive/hadoop/common/type/* in impala-minimal-hive-exec
     add 646b0e0  IMPALA-10456: Implement TRUNCATE for Iceberg tables
     add a81c6a7  IMPALA-10460: Impala should write normalized paths in Iceberg manifests
     add 1a38924  IMPALA-9588: Add extra logging to cancel tests
     add 91fd8fd  [config] bump toolchain build id
     add b5e2a0c  IMPALA-9224: Blacklist nodes with faulty disk for spilling
     add f8ed3f6  IMPALA-10472 flag for Kudu connection negotiation timeout
     add 60f8f87  IMPALA-10274: Initialize impala-python as part of the CMake build
     add e71ea69  IMPALA-10459: Remove workarounds for MAPREDUCE-6441
     add 93d4348  IMPALA-10389: impala-profile-tool container
     add 0473e1b  IMPALA-10473: Fix wrong analytic results on constant partition/order by exprs
     add a3f4411  IMPALA-10223: Implement INSERT OVERWRITE for Iceberg tables
     add 81d5377  IMPALA-10475: [DOCS] elaborate SYNC_DDL option
     add 701714b  IMPALA-10379: Add missing HiveLexer classes to shared-deps
     add 8551805  IMPALA-9586: update query option docs for mt_dop
     add 1f7b413  IMPALA-8721: re-enable test_hive_impala_interop
     add f888d36  IMPALA-10397 : Reduce flakiness in test_single_workload
     add 79bee3b  IMPALA-10469: push quickstart to apache repo
     add b42c649  IMPALA-9979: part 2: partitioned top-n
     add 24a3f00  IMPALA-10470: Add link to quickstart container from README
     add 6fe3466  IMPALA-9382: part 3/3 clean up runtime profile v2 text output
     add 4721978  IMPALA-4805: Avoid hash exchange before analytic function if appropriate
     add baf81de  IMPALA-9745: Propagate source type when doing constant propagation
     add dc133d9  IMPALA-10499: Fix failing test_misc
     add 9736e4c  IMPALA-10389: (supplement) Add impala-profile-tool to build by default
     add 490aff5  IMPALA-10497: Fix flakiness in test_no_fd_caching_on_cached_data.
     add 65c6a81  IMPALA-10463: Implement ds_theta_sketch() and ds_theta_estimate() functions
     add 08cb4d3  IMPALA-10496: SAML implementation in Impala
     add a55661d  IMPALA-10509: Add tool to visualize Impala query plan from profile
     add ebb2e06  IMPALA-10325: Parquet scan should use min/max statistics to skip pages based on equi-join predicate
     add 5b0675f  IMPALA-10161: User LDAP Search bind support
     add 4a65fcf  IMPALA-10516: Bump up the versions of jackson databind and slf4j
     add c5e8c97  IMPALA-10519: Allow setting of num_reactors for KuduClient
     add 7f60990  IMPALA-10467: Implement ds_theta_union() function
     add 9c990de  IMPALA-10496: Remove checking port in FLAGS_saml2_sp_callback_url
     add 7c8e3eb  IMPALA-10485: part(1): make ORC column reader creation independent of schema resolution
     add 85e39e1  IMPALA-9867: Add Support for Spilling to S3: Milestone 1
     add d271baa  IMPALA-10515: Refactoring to support external frontend.
     add 89a5fc7  IMPALA-10501: Hit DCHECK in parquet-column-readers.cc: def_levels_.CacheRemaining() <= num_buffered_values_
     add 47850f1  IMPALA-10510: Change code to help with third party extensions
     add 15fd8c9  IMPALA-10536: Fix saml2_callback_token_ttl's description
     add c004cc6  IMPALA-10525: Add param to BuiltinsDb to defer initialization
     add b9593d5  IMPALA-9767: Do not clean up filter while PublishFilter is ongoing
     add 8059af8  IMPALA-10371: test_java_udfs crash impalad if result spooling is enabled
     add c8d94e6  IMPALA-10504: Add tracing for remote block reads
     add 20d4df3  IMPALA-10496: Bump springframework dependency to 4.3.29
     add f13170e  IMPALA-10527: Fix DiskIoMgrTest.WriteToRemotePartialFileSuccess failed in tsan build
     add 285cea9  IMPALA-10526: Fix BufferPoolTest.Multi8RandomSpillToRemoteMix failed in sanitizer builds
     add bead2ed  IMPALA-10533: Fix TestScratchDir.test_scratch_dirs_mix_local_and_remote_dir_spill_local_only seems flaky
     add d038e39  IMPALA-10505: Avoid creating misleading audit logs
     add 9f1b527  IMPALA-10531: Fix TmpFileMgrTest.TestCompressBufferManagementEncryptedRemoteUpload failed in exhaustive release build
     add 16493c0  IMPALA-10532 TestOverlapMinMaxFilters.test_overlap_min_max_filters seems flaky
     add 466c260  IMPALA-10547: Restore TPC-DS "reason" table missing from Kudu schema
     add 801efdc  IMPALA-10492: Lower default MAX_CNF_EXPRS query option
     add 49ac55f  IMPALA-9856: Enable result spooling by default.
     add 3554b07  IMPALA-10524: Changes to HdfsPartition for third party extensions.
     add a47700e  IMPALA-10450: Catalogd crashes due to exception in ThriftDebugString
     add ca17e30  IMPALA-10550: Add External Frontend service port
     add d89c04b  IMPALA-10529: Fix hit DCHECK in DiskIoMgr::AssignQueue in core-s3 build
     add 06fbb0d  IMPALA-10571: ImpalaJdbcClient might silently choose a different driver than the one specified
     add b2088b3  IMPALA-10555: Fix Hit DCHECK in TmpFileGroup::RecoverWriteError
     add 2039746  IMPALA-10576: Add refresh authorization to make a test case less flaky
     add a29d06d  IMPALA-9218: Add support for locally compiled Hive
     add 1a01bfe  IMPALA-10377: Improve the accuracy of resource estimation
     add 0d22e89  IMPALA-10520: Implement ds_theta_intersect() function
     add 311938b  IMPALA-10535: Add interface to ImpalaServer for execution of externally compiled statements
     add b3d95d8  IMPALA-10522: Support external use of frontend libraries
     add 2e53c11  IMPALA-10546: Add ImpalaServer interface to retrieve BackendConfig from impalad
     add d5f67fc  IMPALA-10523: Fix impala-shell crash in printing error messages that contain UTF-8 characters
     add 6c6b0ee  IMPALA-10222: CREATE TABLE AS SELECT for Iceberg tables
     add 2dfc68d  IMPALA-7712: Support Google Cloud Storage
     add 47219ec  IMPALA-10565: Adjust result spooling memory based on scratch_limit
     add 37ec96e  IMPALA-10559: Fix flakiness in TestScratchLimit.
     add c60a626  IMPALA-10503: testdata load hits hive memory limit errors during hive inserts
     add 573c60a  IMPALA-10367: Impala-shell internal error - UnboundLocalError, local variable 'retry_msg' referenced before assign
     add 768722b  IMPALA-10551: Add result sink support for external frontends
     add 122bd9e  IMPALA-10553: External Frontend CTAS support
     add 3e82501  IMPALA-10558: Implement ds_theta_exclude() function
     add c823f17  IMPALA-10577: Add retrying of AdmitQuery
     add decb79d  IMPALA-10518: Add ImpalaServer interface to retrieve executor membership.
     add 231d41a  IMPALA-10549: Register transactions from external frontend DML
     add ac4984b  Revert "IMPALA-10503: testdata load hits hive memory limit errors during hive inserts"
     add 6162343  IMPALA-10512: ALTER TABLE ADD PARTITION should bump the write id for ACID tables
     add 98de1c5  IMPALA-9234: Support Ranger row filtering policies
     add 879986e  IMPALA-10552: Support external frontends supplying timeline for profile
     add c9d7bcb  IMPALA-9661: Avoid introducing unused columns in table masking view
     add a0f7768  IMPALA-10483: Support subqueries in Ranger masking policies
     add e5d5dbc  Update Paramiko to 2.4.2.
     add b28da05  IMPALA-10592: prevent pytest from hanging at exit.
     add 410c3e7  IMPALA-10564: Return error when inserting an invalid decimal value
     add 622e3c9  IMPALA-10580: Implement ds_theta_union_f() function
     add 452c2f1  IMPALA-10604: Allow setting KuduClient's verbose log level directly
     add e3bafcb  IMPALA-10590: Introduce admission service heartbeat mechanism
     add 5b27b7c  IMPALA-10598: Deflake test_cache_reload_validation
     add 281a47c  IMPALA-10564 (part 2): Fixed test_ctas_exprs failure for S3 build
     add 0b79464  IMPALA-10397: Fix test_single_workload
     add 2e5589d  IMPALA-10116: Allow unwrapping a builtin cast function similar to CastExpr
     add cf463f2  IMPALA-10609: Fix NPE in resolving table masks in StmtMetadataLoader
     add 8f8668a  IMPALA-10593: Conditionally skip runtime filter for outer joins
     add 77d6acd  IMPALA-10581: Implement ds_theta_intersect_f() function
     add dbc2fc1  IMPALA-10597: Enable setting 'iceberg.file_format'
     add 7198f07  IMPALA-10605: Deflake test_refresh_native
     add 103774a  Update Python requests package to 2.20.0
     add 45fb0fb  IMPALA-10397: De-flake test_single_workload
     add 1142c7b  IMPALA-10606: Simplify impala-python virtualenv bootstrapping
     add 9670c14  IMPALA-10606 (part 2): Clean up ordering of requirements.txt
     add e7fc18c  IMPALA-10608: Update kudu-python version and remove some unused packages
     add d9eed9c  Bump psutil from 5.6.3 to 5.6.6 in /infra/python/deps

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   (ba6b911)
            \
             N -- N -- N   refs/heads/dependabot/pip/infra/python/deps/psutil-5.6.6 (d9eed9c)

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:
 CMakeLists.txt                                     |     8 +-
 README-build.md                                    |    11 +
 README.md                                          |    10 +-
 be/generated-sources/gen-cpp/CMakeLists.txt        |     2 +
 be/src/benchmarks/expr-benchmark.cc                |     2 +-
 be/src/benchmarks/hash-benchmark.cc                |     2 +-
 be/src/catalog/catalog-server.cc                   |    26 +-
 be/src/catalog/catalog.cc                          |     2 +-
 be/src/catalog/catalogd-main.cc                    |    50 +-
 be/src/codegen/gen_ir_descriptions.py              |    10 +-
 be/src/codegen/impala-ir.cc                        |     1 +
 be/src/codegen/llvm-codegen-test.cc                |     2 +-
 be/src/codegen/llvm-codegen.cc                     |     3 +-
 be/src/common/CMakeLists.txt                       |     1 +
 be/src/common/daemon-env.cc                        |    79 +
 be/src/common/daemon-env.h                         |    64 +
 be/src/common/global-flags.cc                      |    14 +-
 be/src/common/init.cc                              |    33 +-
 be/src/common/init.h                               |     4 +-
 be/src/exec/exec-node.cc                           |     3 +-
 be/src/exec/exec-node.h                            |     1 +
 be/src/exec/grouping-aggregator.cc                 |     2 +-
 be/src/exec/hash-table-test.cc                     |     6 +-
 be/src/exec/hash-table.cc                          |     2 +-
 be/src/exec/hash-table.h                           |     5 +
 be/src/exec/hdfs-orc-scanner.cc                    |     8 +-
 be/src/exec/hdfs-orc-scanner.h                     |     8 +-
 be/src/exec/hdfs-scan-node-base.cc                 |     3 +
 be/src/exec/hdfs-scan-node-base.h                  |    10 +-
 be/src/exec/hdfs-scanner-ir.cc                     |     2 +-
 be/src/exec/hdfs-scanner.cc                        |    16 +-
 be/src/exec/hdfs-scanner.h                         |    31 +-
 be/src/exec/hdfs-table-sink.cc                     |   137 +-
 be/src/exec/hdfs-table-sink.h                      |    26 +-
 be/src/exec/hdfs-text-table-writer.cc              |     1 +
 be/src/exec/kudu-table-sink.cc                     |     1 +
 be/src/exec/kudu-util.cc                           |    23 +-
 be/src/exec/orc-column-readers.cc                  |   109 +-
 be/src/exec/orc-column-readers.h                   |    23 +-
 be/src/exec/orc-metadata-utils.cc                  |    62 -
 be/src/exec/orc-metadata-utils.h                   |    10 -
 be/src/exec/parquet/hdfs-parquet-scanner.cc        |   438 +-
 be/src/exec/parquet/hdfs-parquet-scanner.h         |    73 +
 be/src/exec/parquet/hdfs-parquet-table-writer.cc   |    47 +-
 be/src/exec/parquet/hdfs-parquet-table-writer.h    |     6 +
 be/src/exec/parquet/parquet-column-chunk-reader.cc |     2 +
 be/src/exec/parquet/parquet-column-readers.cc      |    32 +-
 be/src/exec/parquet/parquet-column-stats.cc        |    16 +
 be/src/exec/parquet/parquet-column-stats.h         |    11 +
 be/src/exec/parquet/parquet-common.h               |     7 +
 be/src/exec/parquet/parquet-level-decoder.h        |     7 +
 be/src/exec/parquet/parquet-metadata-utils.cc      |    39 +-
 be/src/exec/parquet/parquet-metadata-utils.h       |    12 +-
 be/src/exec/partitioned-hash-join-builder.cc       |     6 +
 be/src/exec/scan-node.cc                           |     2 +-
 be/src/exec/topn-node-ir.cc                        |   165 +-
 be/src/exec/topn-node.cc                           |   561 +-
 be/src/exec/topn-node.h                            |   353 +-
 be/src/exprs/CMakeLists.txt                        |     8 +-
 be/src/exprs/aggregate-functions-ir.cc             |   322 +
 be/src/exprs/aggregate-functions-test.cc           |    15 +
 be/src/exprs/aggregate-functions.h                 |    25 +
 be/src/exprs/case-expr.cc                          |     3 +-
 be/src/exprs/compound-predicates.cc                |     6 +-
 be/src/exprs/datasketches-common.cc                |    46 +
 be/src/exprs/datasketches-common.h                 |    15 +
 be/src/exprs/datasketches-functions-ir.cc          |    93 +
 be/src/exprs/datasketches-functions.h              |    29 +
 be/src/exprs/datasketches-test.cc                  |    58 +
 be/src/exprs/expr-test.cc                          |   272 +-
 be/src/exprs/hive-udf-call-ir.cc                   |     2 +-
 be/src/exprs/hive-udf-call.cc                      |    20 +-
 be/src/exprs/hive-udf-call.h                       |    12 +-
 be/src/exprs/iceberg-functions-ir.cc               |   216 +
 be/src/exprs/iceberg-functions-test.cc             |   593 +
 be/src/exprs/iceberg-functions.h                   |   109 +
 be/src/exprs/is-not-empty-predicate.cc             |     8 +-
 be/src/exprs/mask-functions-ir.cc                  |    59 +
 be/src/exprs/mask-functions.h                      |    38 +
 be/src/exprs/null-literal.h                        |     2 +-
 be/src/exprs/scalar-expr-evaluator.cc              |     4 +-
 be/src/exprs/slot-ref.h                            |     6 +-
 be/src/exprs/string-functions-ir.cc                |   103 +
 be/src/exprs/string-functions.h                    |     6 +
 be/src/exprs/valid-tuple-id.cc                     |     2 +-
 be/src/rpc/auth-provider.h                         |     6 +-
 be/src/rpc/authentication-test.cc                  |    13 +
 be/src/rpc/authentication-util.cc                  |    10 +-
 be/src/rpc/authentication.cc                       |   273 +-
 be/src/rpc/authentication.h                        |    16 +
 be/src/rpc/hs2-http-test.cc                        |     8 +-
 be/src/rpc/impala-service-pool.cc                  |     7 +-
 be/src/rpc/impala-service-pool.h                   |     3 +-
 be/src/rpc/rpc-mgr-kerberized-test.cc              |     9 +-
 be/src/rpc/rpc-mgr-test.cc                         |     9 +-
 be/src/rpc/rpc-mgr-test.h                          |     6 +-
 be/src/rpc/rpc-mgr.cc                              |     5 +-
 be/src/rpc/rpc-mgr.h                               |     4 +-
 be/src/rpc/thrift-server.h                         |     5 +
 be/src/runtime/buffered-tuple-stream-test.cc       |    66 +-
 be/src/runtime/buffered-tuple-stream.cc            |    12 +-
 be/src/runtime/buffered-tuple-stream.h             |     6 +-
 be/src/runtime/bufferpool/buffer-pool-test.cc      |    58 +
 be/src/runtime/coordinator-backend-state.cc        |    31 +-
 be/src/runtime/coordinator-backend-state.h         |    12 +
 be/src/runtime/coordinator-filter-state.h          |     3 +
 be/src/runtime/coordinator.cc                      |   129 +-
 be/src/runtime/coordinator.h                       |    30 +
 be/src/runtime/data-stream-test.cc                 |    14 +-
 be/src/runtime/date-test.cc                        |     8 +-
 be/src/runtime/date-value.cc                       |    18 +
 be/src/runtime/date-value.h                        |     7 +
 be/src/runtime/debug-options.h                     |     1 +
 be/src/runtime/descriptors.cc                      |    10 +-
 be/src/runtime/descriptors.h                       |    15 +-
 be/src/runtime/dml-exec-state.cc                   |     3 +-
 be/src/runtime/exec-env.cc                         |   180 +-
 be/src/runtime/exec-env.h                          |    35 +-
 be/src/runtime/fragment-instance-state.cc          |    37 +-
 be/src/runtime/fragment-instance-state.h           |    16 +-
 be/src/runtime/hdfs-fs-cache.cc                    |    20 +-
 be/src/runtime/hdfs-fs-cache.h                     |     8 +-
 be/src/runtime/io/CMakeLists.txt                   |     2 +
 be/src/runtime/io/disk-file.cc                     |    69 +
 be/src/runtime/io/disk-file.h                      |   261 +
 be/src/runtime/io/disk-io-mgr-test.cc              |   716 +-
 be/src/runtime/io/disk-io-mgr.cc                   |   266 +-
 be/src/runtime/io/disk-io-mgr.h                    |    45 +-
 be/src/runtime/io/error-converter.cc               |    61 +
 be/src/runtime/io/error-converter.h                |     9 +-
 be/src/runtime/io/file-writer.h                    |    80 +
 be/src/runtime/io/hdfs-file-reader.cc              |    89 +-
 be/src/runtime/io/hdfs-file-reader.h               |     5 +
 be/src/runtime/io/local-file-system.cc             |    45 +-
 be/src/runtime/io/local-file-system.h              |    18 +-
 be/src/runtime/io/local-file-writer.cc             |    96 +
 .../{string-value.cc => io/local-file-writer.h}    |    32 +-
 be/src/runtime/io/request-context.cc               |    67 +-
 be/src/runtime/io/request-context.h                |    17 +-
 be/src/runtime/io/request-ranges.h                 |   146 +-
 be/src/runtime/io/scan-range.cc                    |   105 +-
 be/src/runtime/krpc-data-stream-mgr.cc             |    21 +-
 be/src/runtime/krpc-data-stream-mgr.h              |    17 +-
 be/src/runtime/lib-cache.cc                        |    11 +-
 be/src/runtime/lib-cache.h                         |     4 +-
 be/src/runtime/query-driver.cc                     |    25 +
 be/src/runtime/query-driver.h                      |     3 +
 be/src/runtime/query-exec-params.cc                |    19 +-
 be/src/runtime/query-exec-params.h                 |     7 +
 be/src/runtime/query-state.cc                      |    25 +-
 be/src/runtime/query-state.h                       |     9 +-
 be/src/runtime/raw-value-test.cc                   |    87 +-
 be/src/runtime/raw-value.h                         |     8 +
 be/src/runtime/row-batch-serialize-test.cc         |    23 +-
 be/src/runtime/runtime-filter-ir.cc                |    22 +-
 be/src/runtime/runtime-state.h                     |     1 +
 be/src/runtime/string-value-test.cc                |    12 +
 be/src/runtime/string-value.cc                     |    12 +
 be/src/runtime/string-value.h                      |     4 +
 be/src/runtime/test-env.h                          |     7 +-
 be/src/runtime/timestamp-test.cc                   |     8 +-
 be/src/runtime/timestamp-value.cc                  |    30 +
 be/src/runtime/timestamp-value.h                   |    11 +-
 be/src/runtime/tmp-file-mgr-internal.h             |   346 +-
 be/src/runtime/tmp-file-mgr-test.cc                |   643 +-
 be/src/runtime/tmp-file-mgr.cc                     |  1215 +-
 be/src/runtime/tmp-file-mgr.h                      |   270 +-
 be/src/runtime/types.cc                            |    12 +-
 be/src/runtime/types.h                             |     4 +-
 be/src/scheduling/CMakeLists.txt                   |     2 +
 be/src/scheduling/admission-control-client.cc      |    10 +-
 be/src/scheduling/admission-control-service.cc     |    78 +-
 be/src/scheduling/admission-control-service.h      |    10 +-
 be/src/scheduling/admission-controller-test.cc     |     5 +-
 be/src/scheduling/admission-controller.cc          |   136 +-
 be/src/scheduling/admission-controller.h           |    86 +-
 be/src/scheduling/admissiond-env.cc                |   123 +
 be/src/scheduling/admissiond-env.h                 |    82 +
 be/src/scheduling/admissiond-main.cc               |    52 +
 be/src/scheduling/cluster-membership-mgr.cc        |    47 +-
 be/src/scheduling/cluster-membership-mgr.h         |     5 +
 .../scheduling/local-admission-control-client.cc   |     4 +-
 .../scheduling/remote-admission-control-client.cc  |   110 +-
 .../scheduling/remote-admission-control-client.h   |    28 +-
 be/src/service/CMakeLists.txt                      |     8 +-
 be/src/service/client-request-state.cc             |    26 +-
 be/src/service/client-request-state.h              |     4 +
 be/src/service/control-service.cc                  |    10 +-
 be/src/service/daemon-main.cc                      |     5 +
 be/src/service/data-stream-service.cc              |     3 +-
 be/src/service/fe-support.cc                       |    17 +-
 be/src/service/frontend.cc                         |    28 +-
 be/src/service/frontend.h                          |    23 +-
 be/src/service/hs2-util.cc                         |     7 +-
 be/src/service/impala-beeswax-server.cc            |    15 +-
 be/src/service/impala-hs2-server.cc                |   122 +-
 be/src/service/impala-http-handler.cc              |    64 +-
 be/src/service/impala-http-handler.h               |    26 +-
 be/src/service/impala-server.cc                    |   203 +-
 be/src/service/impala-server.h                     |    49 +-
 be/src/service/impalad-main.cc                     |     5 +-
 be/src/service/query-options-test.cc               |     7 +-
 be/src/service/query-options.cc                    |    77 +-
 be/src/service/query-options.h                     |    15 +-
 be/src/statestore/statestored-main.cc              |    44 +-
 be/src/testutil/desc-tbl-builder.h                 |     4 +
 be/src/testutil/in-process-servers.cc              |     2 +-
 .../thirdparty/datasketches/HllUnion-internal.hpp  |    28 -
 be/src/thirdparty/datasketches/README.md           |     9 +-
 be/src/thirdparty/datasketches/hll.hpp             |    15 -
 .../datasketches/kll_quantile_calculator_impl.hpp  |     2 +-
 be/src/thirdparty/datasketches/kll_sketch.hpp      |    12 +-
 be/src/thirdparty/datasketches/kll_sketch_impl.hpp |    10 +-
 be/src/thirdparty/datasketches/theta_a_not_b.hpp   |    73 +
 .../thirdparty/datasketches/theta_a_not_b_impl.hpp |    83 +
 .../thirdparty/datasketches/theta_intersection.hpp |    88 +
 .../datasketches/theta_intersection_impl.hpp       |   130 +
 be/src/thirdparty/datasketches/theta_sketch.hpp    |   533 +
 .../thirdparty/datasketches/theta_sketch_impl.hpp  |   939 +
 be/src/thirdparty/datasketches/theta_union.hpp     |   122 +
 .../thirdparty/datasketches/theta_union_impl.hpp   |   109 +
 be/src/thirdparty/murmurhash/MurmurHash3.cpp       |   335 +
 be/src/thirdparty/murmurhash/MurmurHash3.h         |    40 +
 be/src/thirdparty/murmurhash/README.md             |     9 +
 be/src/transport/THttpServer.cpp                   |   152 +-
 be/src/transport/THttpServer.h                     |    81 +-
 be/src/transport/THttpTransport.cpp                |     8 +
 be/src/transport/THttpTransport.h                  |     2 +
 be/src/udf/udf-internal.h                          |     4 +-
 be/src/udf/udf.cc                                  |    12 +-
 be/src/util/CMakeLists.txt                         |     4 +
 be/src/util/avro-util.cc                           |    14 +-
 be/src/util/backend-gflag-util.cc                  |   117 +-
 be/src/util/backend-gflag-util.h                   |     5 +-
 be/src/util/bit-util-test.cc                       |    70 +
 be/src/util/bit-util.h                             |    34 +
 be/src/util/cache/lirs-cache-test.cc               |    39 +
 be/src/util/cache/lirs-cache.cc                    |     7 +-
 be/src/util/debug-util.cc                          |    15 +
 be/src/util/debug-util.h                           |     9 +
 be/src/util/hdfs-util.cc                           |    58 +-
 be/src/util/hdfs-util.h                            |    25 +-
 be/src/util/impala-profile-tool.cc                 |   170 +
 be/src/util/jni-util.cc                            |     2 -
 be/src/util/ldap-search-bind.cc                    |   158 +
 be/src/util/ldap-search-bind.h                     |    62 +
 be/src/util/ldap-simple-bind.cc                    |   195 +
 be/src/util/{ldap-util.h => ldap-simple-bind.h}    |    45 +-
 be/src/util/ldap-util.cc                           |   297 +-
 be/src/util/ldap-util.h                            |    76 +-
 be/src/util/logging-support.cc                     |     2 +-
 be/src/util/mem-info.cc                            |    71 +
 be/src/util/mem-info.h                             |     7 +
 be/src/util/min-max-filter-ir.cc                   |    12 +-
 be/src/util/min-max-filter-test.cc                 |   235 +-
 be/src/util/min-max-filter.cc                      |   307 +-
 be/src/util/min-max-filter.h                       |   174 +-
 be/src/util/priority-queue.h                       |    12 +-
 be/src/util/runtime-profile-counters.h             |    37 +-
 be/src/util/runtime-profile-test.cc                |     2 +-
 be/src/util/runtime-profile.cc                     |   221 +-
 be/src/util/runtime-profile.h                      |    79 +-
 be/src/util/symbols-util-test.cc                   |    42 +-
 be/src/util/thrift-debug-util.h                    |    41 +
 be/src/util/tuple-row-compare.h                    |    30 +
 be/src/util/webserver-test.cc                      |     6 +-
 be/src/util/webserver.cc                           |    30 +-
 bin/bootstrap_system.sh                            |     4 +-
 bin/bootstrap_toolchain.py                         |     9 +-
 bin/compare_branches.py                            |     5 +-
 bin/create-test-configuration.sh                   |    17 +
 bin/diagnostics/experimental/plan-graph.py         |   633 +
 bin/gen_build_version.py                           |     4 +-
 bin/impala-config.sh                               |    33 +-
 .../init-impala-python.sh                          |    26 +-
 bin/jenkins/dockerized-impala-run-tests.sh         |     5 +-
 bin/load-data.py                                   |    22 +-
 bin/rat_exclude_files.txt                          |    13 +
 bin/run-jdbc-client.sh                             |     1 +
 bin/run_clang_tidy.sh                              |     2 +-
 bin/start-impala-cluster.py                        |    73 +-
 common/fbs/IcebergObjects.fbs                      |     9 +-
 common/function-registry/impala_functions.py       |    97 +-
 common/protobuf/admission_control_service.proto    |    29 +-
 common/protobuf/control_service.proto              |     7 +
 common/thrift/BackendGflags.thrift                 |    32 +
 common/thrift/CMakeLists.txt                       |    12 +-
 common/thrift/CatalogObjects.thrift                |     3 +
 common/thrift/CatalogService.thrift                |    16 +-
 common/thrift/DataSinks.thrift                     |    10 +
 common/thrift/Descriptors.thrift                   |     3 +
 common/thrift/Frontend.thrift                      |   155 +-
 common/thrift/ImpalaInternalService.thrift         |   595 +-
 common/thrift/ImpalaService.thrift                 |    91 +-
 common/thrift/PlanNodes.thrift                     |    40 +-
 .../{ImpalaInternalService.thrift => Query.thrift} |   344 +-
 common/thrift/Types.thrift                         |     2 +
 common/thrift/generate_error_codes.py              |     8 +
 common/thrift/metrics.json                         |   110 +
 docker/CMakeLists.txt                              |    92 +-
 docker/README.md                                   |   158 +-
 .../{impalad_coordinator => admissiond}/Dockerfile |    21 +-
 bin/impala-ipython => docker/docker-build.sh       |    26 +-
 docker/entrypoint.sh                               |     2 +-
 docker/impala_base/Dockerfile                      |    11 +
 .../Dockerfile                                     |    36 +-
 docker/impalad_coordinator/Dockerfile              |     2 +
 docker/publish_images_to_apache.sh                 |    80 +
 docker/quickstart-kudu-minimal.yml                 |   128 +
 .../quickstart-load-data.yml                       |    36 +-
 docker/quickstart.yml                              |   104 +
 docker/quickstart_client/Dockerfile                |    70 +
 docker/quickstart_client/data-load-entrypoint.sh   |    86 +
 .../quickstart_client/load_tpcds_kudu.sql          |   316 +-
 docker/quickstart_client/load_tpcds_parquet.sql    |  1248 +
 docker/quickstart_conf/hive-site.xml               |    74 +
 docker/quickstart_hms/Dockerfile                   |    67 +
 docker/quickstart_hms/hms-entrypoint.sh            |    68 +
 docker/setup_build_context.py                      |   110 +-
 bin/impala-ipython => docker/utility_entrypoint.sh |    23 +-
 docs/impala.ditamap                                |     2 +
 docs/shared/impala_common.xml                      |     5 +-
 docs/topics/impala_authorization.xml               |    26 +-
 ...ads.xml => impala_join_rows_produced_limit.xml} |    46 +-
 docs/topics/impala_num_nodes.xml                   |     5 +
 docs/topics/impala_num_scanner_threads.xml         |     4 +
 .../topics/impala_parquet_dictionary_filtering.xml |     8 +-
 docs/topics/impala_refresh_updated_hms.xml         |    72 +
 docs/topics/impala_ssl.xml                         |     7 +-
 docs/topics/impala_sync_ddl.xml                    |    14 +-
 fe/pom.xml                                         |    70 +
 fe/src/main/cup/sql-parser.cup                     |    30 +-
 .../analysis/AlterTableSetTblProperties.java       |    37 +-
 .../org/apache/impala/analysis/AlterViewStmt.java  |     2 -
 .../apache/impala/analysis/AnalysisContext.java    |    62 +-
 .../org/apache/impala/analysis/AnalyticExpr.java   |    27 +-
 .../org/apache/impala/analysis/AnalyticWindow.java |     5 +-
 .../java/org/apache/impala/analysis/Analyzer.java  |   255 +-
 .../org/apache/impala/analysis/ArithmeticExpr.java |     2 +-
 .../apache/impala/analysis/BinaryPredicate.java    |     5 +
 .../java/org/apache/impala/analysis/ColumnDef.java |     7 +
 .../apache/impala/analysis/CompoundPredicate.java  |    15 +-
 .../apache/impala/analysis/ComputeStatsStmt.java   |     5 +-
 .../impala/analysis/ConstantPredicateHandler.java  |    13 +-
 .../apache/impala/analysis/CopyTestCaseStmt.java   |     4 +-
 .../impala/analysis/CreateTableAsSelectStmt.java   |    23 +-
 .../apache/impala/analysis/CreateTableStmt.java    |    45 +
 .../org/apache/impala/analysis/CreateViewStmt.java |     2 -
 .../main/java/org/apache/impala/analysis/Expr.java |    56 +-
 .../org/apache/impala/analysis/FromClause.java     |    96 +-
 .../apache/impala/analysis/FunctionCallExpr.java   |     8 +-
 .../impala/analysis/IcebergPartitionField.java     |     9 +
 .../impala/analysis/IcebergPartitionSpec.java      |     5 +
 .../impala/analysis/IcebergPartitionTransform.java |     8 +
 .../org/apache/impala/analysis/InPredicate.java    |     3 +
 .../org/apache/impala/analysis/InlineViewRef.java  |    37 +-
 .../org/apache/impala/analysis/InsertStmt.java     |   194 +-
 .../apache/impala/analysis/IsNullPredicate.java    |     4 +
 .../java/org/apache/impala/analysis/Predicate.java |     5 +
 .../org/apache/impala/analysis/PrivilegeSpec.java  |     2 +-
 .../java/org/apache/impala/analysis/QueryStmt.java |    15 +-
 .../apache/impala/analysis/ResetMetadataStmt.java  |     3 +-
 .../org/apache/impala/analysis/SelectStmt.java     |    67 +-
 .../apache/impala/analysis/SetOperationStmt.java   |     6 +-
 .../java/org/apache/impala/analysis/SlotRef.java   |    14 +-
 .../java/org/apache/impala/analysis/SortInfo.java  |    12 +-
 .../org/apache/impala/analysis/StatementBase.java  |     5 +-
 .../apache/impala/analysis/StmtMetadataLoader.java |    54 +-
 .../java/org/apache/impala/analysis/StmtNode.java  |    10 +
 .../java/org/apache/impala/analysis/Subquery.java  |    12 +
 .../java/org/apache/impala/analysis/TableDef.java  |    29 +-
 .../java/org/apache/impala/analysis/TableRef.java  |    61 +-
 .../org/apache/impala/analysis/ToSqlUtils.java     |     5 +
 .../org/apache/impala/analysis/TruncateStmt.java   |     7 +-
 .../apache/impala/analysis/TupleDescriptor.java    |    12 +
 .../impala/analysis/TupleIsNullPredicate.java      |     2 +-
 .../org/apache/impala/analysis/WithClause.java     |     9 +
 .../authentication/saml/AuthTokenGenerator.java    |    19 +-
 .../saml/HiveSamlAuthTokenGenerator.java           |   149 +
 .../saml/HiveSamlGroupNameFilter.java              |    89 +
 .../authentication/saml/HiveSamlHttpServlet.java   |    88 +
 .../saml/HiveSamlRelayStateInfo.java}              |    30 +-
 .../saml/HiveSamlRelayStateStore.java              |   108 +
 .../impala/authentication/saml/HiveSamlUtils.java  |    20 +-
 .../saml/HttpSamlAuthenticationException.java      |    25 +-
 .../saml/HttpSamlNoGroupsMatchedException.java     |    18 +-
 .../authentication/saml/ImpalaSamlClient.java      |   214 +
 .../authentication/saml/NullSessionStore.java      |    65 +
 .../authentication/saml/WrappedWebContext.java     |   190 +
 .../impala/authorization/AuthorizationChecker.java |    12 +
 .../impala/authorization/AuthorizationContext.java |     5 +
 .../impala/authorization/AuthorizationFactory.java |     2 +-
 .../authorization/BaseAuthorizationChecker.java    |     3 +
 .../authorization/NoopAuthorizationFactory.java    |    13 +-
 .../org/apache/impala/authorization/TableMask.java |    75 +-
 .../ranger/RangerAuthorizationChecker.java         |   141 +-
 .../ranger/RangerAuthorizationContext.java         |    31 +-
 .../ranger/RangerAuthorizationFactory.java         |     5 +-
 .../ranger/RangerBufferAuditHandler.java           |    12 +-
 .../ranger/RangerCatalogdAuthorizationManager.java |   207 +-
 .../ranger/RangerImpaladAuthorizationManager.java  |    91 +-
 .../impala/authorization/ranger/RangerUtil.java    |    37 +
 .../java/org/apache/impala/catalog/BuiltinsDb.java |    87 +-
 .../java/org/apache/impala/catalog/Catalog.java    |    11 +-
 .../impala/catalog/CatalogServiceCatalog.java      |   320 +-
 .../java/org/apache/impala/catalog/Column.java     |    12 +-
 .../org/apache/impala/catalog/CtasTargetTable.java |   176 +
 .../org/apache/impala/catalog/FeFsPartition.java   |    17 +
 .../org/apache/impala/catalog/FeIcebergTable.java  |    28 +-
 .../org/apache/impala/catalog/HdfsPartition.java   |    33 +-
 .../catalog/HdfsPartitionLocationCompressor.java   |     2 +-
 .../java/org/apache/impala/catalog/HdfsTable.java  |   163 +-
 .../org/apache/impala/catalog/IcebergColumn.java   |    21 +-
 .../apache/impala/catalog/IcebergStructField.java  |    57 +
 .../org/apache/impala/catalog/IcebergTable.java    |    42 +-
 .../org/apache/impala/catalog/ImpaladCatalog.java  |     7 +
 .../org/apache/impala/catalog/ScalarFunction.java  |     6 +-
 .../java/org/apache/impala/catalog/StructType.java |    11 +
 .../main/java/org/apache/impala/catalog/Table.java |    91 +-
 .../org/apache/impala/catalog/TopicUpdateLog.java  |    18 +-
 .../org/apache/impala/catalog/Transaction.java     |    19 +-
 .../main/java/org/apache/impala/catalog/Type.java  |     8 +-
 .../impala/catalog/iceberg/IcebergCtasTarget.java  |   279 +
 .../org/apache/impala/catalog/local/LocalDb.java   |     2 +-
 .../impala/catalog/local/LocalFsPartition.java     |     5 +
 .../apache/impala/catalog/local/LocalFsTable.java  |     2 +-
 .../impala/catalog/local/LocalIcebergTable.java    |    40 +-
 .../apache/impala/catalog/local/LocalTable.java    |    11 +-
 .../org/apache/impala/common/FileSystemUtil.java   |    39 +-
 .../org/apache/impala/planner/AggregationNode.java |    48 +-
 .../apache/impala/planner/AnalyticEvalNode.java    |   253 +-
 .../org/apache/impala/planner/AnalyticPlanner.java |   236 +-
 .../impala/planner/CardinalityCheckNode.java       |     2 +-
 .../apache/impala/planner/DistributedPlanner.java  |   139 +-
 .../org/apache/impala/planner/HashJoinNode.java    |    30 +-
 .../apache/impala/planner/HdfsPartitionPruner.java |    39 +-
 .../org/apache/impala/planner/HdfsScanNode.java    |   193 +-
 .../org/apache/impala/planner/HdfsTableSink.java   |    48 +-
 .../org/apache/impala/planner/IcebergScanNode.java |    32 +-
 .../java/org/apache/impala/planner/JoinNode.java   |     2 +-
 .../org/apache/impala/planner/KuduScanNode.java    |    87 +-
 .../org/apache/impala/planner/PlanFragment.java    |     6 +-
 .../java/org/apache/impala/planner/PlanNode.java   |    53 +-
 .../org/apache/impala/planner/PlanRootSink.java    |    77 +-
 .../java/org/apache/impala/planner/Planner.java    |    58 +-
 .../org/apache/impala/planner/PlannerContext.java  |    13 +
 .../impala/planner/RuntimeFilterGenerator.java     |   113 +-
 .../java/org/apache/impala/planner/ScanNode.java   |    18 +-
 .../java/org/apache/impala/planner/SelectNode.java |    30 +-
 .../apache/impala/planner/SingleNodePlanner.java   |   172 +-
 .../java/org/apache/impala/planner/SortNode.java   |   243 +-
 .../org/apache/impala/planner/SubplanNode.java     |     2 +-
 .../java/org/apache/impala/planner/TableSink.java  |    14 +-
 .../apache/impala/rewrite/ConvertToCNFRule.java    |    13 +
 .../org/apache/impala/service/BackendConfig.java   |    49 +-
 .../apache/impala/service/CatalogOpExecutor.java   |   220 +-
 .../impala/service/DescribeResultFactory.java      |    26 +
 .../java/org/apache/impala/service/FeSupport.java  |    18 +-
 .../java/org/apache/impala/service/Frontend.java   |    84 +-
 .../impala/service/IcebergCatalogOpExecutor.java   |   183 +-
 .../org/apache/impala/service/JniFrontend.java     |    59 +
 .../org/apache/impala/util/AuthorizationUtil.java  |     4 +
 .../apache/impala/util/IcebergSchemaConverter.java |   242 +
 .../java/org/apache/impala/util/IcebergUtil.java   |   299 +-
 .../org/apache/impala/analysis/AnalyzeDDLTest.java |    13 +-
 .../apache/impala/analysis/AnalyzeStmtsTest.java   |     2 +-
 .../org/apache/impala/analysis/ParserTest.java     |    12 +
 .../authorization/AuthorizationStmtTest.java       |    10 +-
 .../authorization/AuthorizationTestBase.java       |     8 +-
 .../authorization/ranger/RangerAuditLogTest.java   |   328 +-
 .../catalog/CatalogObjectToFromThriftTest.java     |     4 +-
 .../impala/catalog/HdfsPartitionSdCompareTest.java |     4 +-
 .../catalog/events/EventsProcessorStressTest.java  |     2 -
 .../events/MetastoreEventsProcessorTest.java       |     6 +-
 .../org/apache/impala/common/FrontendFixture.java  |     5 +-
 .../org/apache/impala/common/FrontendTestBase.java |    13 +-
 .../impala/customcluster/LdapImpalaShellTest.java  |   101 +-
 .../apache/impala/customcluster/LdapJdbcTest.java  |     4 +-
 .../LdapSearchBindImpalaShellTest.java             |   122 +
 .../LdapSimpleBindImpalaShellTest.java             |    97 +
 .../impala/customcluster/LdapWebserverTest.java    |     3 +-
 .../org/apache/impala/planner/CardinalityTest.java |   236 +
 .../org/apache/impala/planner/PlannerTest.java     |    63 +-
 .../org/apache/impala/planner/PlannerTestBase.java |     5 +-
 .../apache/impala/planner/TpcdsPlannerTest.java    |   212 +-
 .../org/apache/impala/service/FrontendTest.java    |    22 +-
 .../java/org/apache/impala/service/JdbcTest.java   |     6 +-
 .../apache/impala/testutil/ImpalaJdbcClient.java   |    16 +-
 .../java/org/apache/impala/testutil/LdapUtil.java  |     3 +
 .../apache/impala/util/RandomHiveQueryRunner.java  |     7 -
 fe/src/test/resources/users.ldif                   |    16 +
 infra/python/bootstrap_virtualenv.py               |   121 +-
 infra/python/deps/extended-test-requirements.txt   |     2 +-
 infra/python/deps/kudu-requirements.txt            |     2 +-
 infra/python/deps/pip_download.py                  |     5 +-
 infra/python/deps/requirements.txt                 |    50 +-
 .../python/deps/setuptools-requirements.txt        |    10 +-
 java/executor-deps/pom.xml                         |     6 +
 java/pom.xml                                       |    13 +-
 java/shaded-deps/hive-exec/pom.xml                 |     4 +
 shell/impala_client.py                             |     2 +
 shell/impala_shell.py                              |    22 +-
 shell/shell_output.py                              |     1 +
 testdata/authentication/saml2_sso.jks              |   Bin 0 -> 3153 bytes
 testdata/authentication/saml2_sso_metadata.xml     |    22 +
 testdata/bin/compute-table-stats.sh                |     3 +-
 testdata/bin/create-load-data.sh                   |     4 +-
 testdata/bin/load-test-warehouse-snapshot.sh       |     9 +
 testdata/bin/run-all.sh                            |     8 +-
 testdata/bin/run-hive-server.sh                    |     3 +
 .../common/etc/hadoop/conf/core-site.xml.py        |     6 +
 testdata/data/README                               |    23 +
 testdata/data/alltypes_tiny_rle_dictionary.parquet |   Bin 0 -> 3646 bytes
 ...79bd6-4b97-4680-b4e1-52e93b6ce04e-00000.parquet |   Bin 0 -> 3855 bytes
 ...c9b7a-f42d-4245-b806-dfa7a792593f-00000.parquet |   Bin 0 -> 3855 bytes
 ...fe2d6-b0d9-42d6-bc95-15f52ecb29ad-00000.parquet |   Bin 0 -> 3855 bytes
 ...8e294-5992-48d9-a18e-08e129bb418c-00000.parquet |   Bin 0 -> 3854 bytes
 ...fcf22-3de2-489a-b1ec-d5141e75a8e8-00000.parquet |   Bin 0 -> 3855 bytes
 ...1dc85-b8f3-4cc2-a5c6-38b7fee49709-00000.parquet |   Bin 0 -> 3854 bytes
 ...510cc-e765-43bc-be03-c5561a8d50a3-00000.parquet |   Bin 0 -> 3855 bytes
 ...afc4a-b718-406d-a532-58fab5c8f85d-00000.parquet |   Bin 0 -> 3855 bytes
 ...a8e89-8aeb-4405-be64-76557432cf21-00000.parquet |   Bin 0 -> 3870 bytes
 ...d552a-fddc-42f3-adfd-ecba20a01d80-00000.parquet |   Bin 0 -> 3870 bytes
 ...7db43-3b9a-4a50-9946-d003cc1d461c-00000.parquet |   Bin 0 -> 3870 bytes
 ...895d0-1f42-4c30-989f-968802831077-00000.parquet |   Bin 0 -> 3870 bytes
 ...9ac6d-aeee-4c35-9f8a-1a03127d33b8-00000.parquet |   Bin 0 -> 3870 bytes
 ...a3ad9-737c-4416-a32c-501cc9a4aa90-00000.parquet |   Bin 0 -> 3870 bytes
 ...78795-ff6a-4a20-9fff-8dc4907c1ba7-00000.parquet |   Bin 0 -> 3887 bytes
 ...a35cb-22b5-4a5d-932b-89f222b0b2c7-00000.parquet |   Bin 0 -> 3887 bytes
 ...c4c8c-de16-487a-89b3-ee8e58b4fd07-00000.parquet |   Bin 0 -> 3884 bytes
 ...ba706-2ace-4d41-b475-6bda3ba72306-00000.parquet |   Bin 0 -> 3884 bytes
 ...5e226-5f8f-49b9-b998-039b8362b7a0-00000.parquet |   Bin 0 -> 3887 bytes
 ...c3538-052d-493e-9479-b59fc8aece0f-00000.parquet |   Bin 0 -> 3887 bytes
 .../4ceee3ab-8653-423c-b8ac-0ad5f7b0579b-m0.avro   |   Bin 0 -> 6481 bytes
 ...178-1-4ceee3ab-8653-423c-b8ac-0ad5f7b0579b.avro |   Bin 0 -> 2594 bytes
 .../metadata/v1.metadata.json                      |   125 +
 .../metadata/v2.metadata.json                      |   144 +
 .../metadata/version-hint.text                     |     0
 testdata/data/theta_sketches_from_hive.parquet     |   Bin 0 -> 5220 bytes
 testdata/data/theta_sketches_from_impala.parquet   |   Bin 0 -> 5171 bytes
 .../functional/functional_schema_template.sql      |   105 +
 .../datasets/functional/schema_constraints.csv     |     7 +-
 testdata/datasets/tpcds/tpcds_kudu_template.sql    |    12 +
 testdata/impala-profiles/README                    |    15 +
 .../impala_profile_log_tpcds_compute_stats         |     4 +
 ...a_profile_log_tpcds_compute_stats.expected.json |     4 +
 ...le_log_tpcds_compute_stats.expected.pretty.json | 33106 ++++++++++++++++++
 ...cds_compute_stats.expected.pretty_extended.json | 34557 +++++++++++++++++++
 ...la_profile_log_tpcds_compute_stats.expected.txt |  7991 +++++
 ...le_log_tpcds_compute_stats_default.expected.txt |  8854 +++++
 ...e_log_tpcds_compute_stats_extended.expected.txt |  9658 ++++++
 .../impala_profile_log_tpcds_compute_stats_v2      |     4 +
 ...log_tpcds_compute_stats_v2_default.expected.txt |  2449 ++
 ...og_tpcds_compute_stats_v2_extended.expected.txt |  3275 ++
 .../queries/PlannerTest/acid-scans.test            |     8 +-
 .../queries/PlannerTest/analytic-fns.test          |   295 +-
 .../PlannerTest/analytic-rank-pushdown.test        |  1678 +
 .../PlannerTest/bloom-filter-assignment.test       |    50 +-
 .../queries/PlannerTest/constant-folding.test      |    54 +-
 .../queries/PlannerTest/constant-propagation.test  |    67 +-
 .../queries/PlannerTest/disable-codegen.test       |    18 +-
 .../disable-runtime-overlap-filter.test            |    29 +
 ...k-join-detection-hdfs-num-rows-est-enabled.test |    12 +-
 .../queries/PlannerTest/fk-pk-join-detection.test  |    38 +-
 .../queries/PlannerTest/inline-view.test           |   180 +
 .../queries/PlannerTest/insert.test                |    62 +
 .../queries/PlannerTest/kudu-selectivity.test      |    28 +-
 .../PlannerTest/limit-pushdown-analytic.test       |   493 +-
 ....test => limit-pushdown-partitioned-top-n.test} |   501 +-
 .../queries/PlannerTest/max-row-size.test          |    90 +-
 ...-runtime-filters-hdfs-num-rows-est-enabled.test |     6 +-
 .../PlannerTest/min-max-runtime-filters.test       |    30 +-
 .../queries/PlannerTest/mt-dop-validation.test     |    62 +-
 .../queries/PlannerTest/optimize-simple-limit.test |   144 +-
 .../queries/PlannerTest/outer-to-inner-joins.test  |   156 +
 .../PlannerTest/parquet-filtering-disabled.test    |    30 +-
 .../queries/PlannerTest/parquet-filtering.test     |    58 +-
 .../queries/PlannerTest/partition-pruning.test     |    22 +-
 .../queries/PlannerTest/preagg-bytes-limit.test    |    18 +-
 .../queries/PlannerTest/resource-requirements.test |  1408 +-
 .../queries/PlannerTest/result-spooling.test       |    12 +-
 .../PlannerTest/runtime-filter-propagation.test    |    59 +-
 .../PlannerTest/runtime-filter-query-options.test  |   122 +-
 .../queries/PlannerTest/setoperation-rewrite.test  |    16 +-
 .../PlannerTest/sort-expr-materialization.test     |    58 +-
 .../PlannerTest/spillable-buffer-sizing.test       |   234 +-
 .../queries/PlannerTest/tablesample.test           |    44 +-
 .../queries/PlannerTest/tpcds-dist-method.test     |   538 +
 .../queries/PlannerTest/tpcds/tpcds-q01.test       |   108 +-
 .../queries/PlannerTest/tpcds/tpcds-q02.test       |   120 +-
 .../queries/PlannerTest/tpcds/tpcds-q03.test       |    42 +-
 .../queries/PlannerTest/tpcds/tpcds-q04.test       |   342 +-
 .../queries/PlannerTest/tpcds/tpcds-q05.test       |   560 +-
 .../queries/PlannerTest/tpcds/tpcds-q06.test       |   132 +-
 .../queries/PlannerTest/tpcds/tpcds-q07.test       |    82 +-
 .../queries/PlannerTest/tpcds/tpcds-q08.test       |    72 +-
 .../queries/PlannerTest/tpcds/tpcds-q09.test       |   468 +-
 .../queries/PlannerTest/tpcds/tpcds-q10a.test      |   114 +-
 .../queries/PlannerTest/tpcds/tpcds-q11.test       |   253 +-
 .../queries/PlannerTest/tpcds/tpcds-q12.test       |    66 +-
 .../queries/PlannerTest/tpcds/tpcds-q13.test       |   433 +-
 .../queries/PlannerTest/tpcds/tpcds-q14a.test      |   566 +-
 .../queries/PlannerTest/tpcds/tpcds-q14b.test      |   428 +-
 .../queries/PlannerTest/tpcds/tpcds-q15.test       |    78 +-
 .../queries/PlannerTest/tpcds/tpcds-q16.test       |    87 +-
 .../queries/PlannerTest/tpcds/tpcds-q17.test       |   113 +-
 .../queries/PlannerTest/tpcds/tpcds-q18.test       |   395 +-
 .../queries/PlannerTest/tpcds/tpcds-q19.test       |    76 +-
 .../queries/PlannerTest/tpcds/tpcds-q20.test       |    76 +-
 .../queries/PlannerTest/tpcds/tpcds-q21.test       |    50 +-
 .../queries/PlannerTest/tpcds/tpcds-q22.test       |   239 +-
 .../queries/PlannerTest/tpcds/tpcds-q23a.test      |  1127 +-
 .../queries/PlannerTest/tpcds/tpcds-q23b.test      |   377 +-
 .../queries/PlannerTest/tpcds/tpcds-q24a.test      |   210 +-
 .../queries/PlannerTest/tpcds/tpcds-q24b.test      |   210 +-
 .../queries/PlannerTest/tpcds/tpcds-q25.test       |   113 +-
 .../queries/PlannerTest/tpcds/tpcds-q26.test       |    77 +-
 .../queries/PlannerTest/tpcds/tpcds-q27.test       |   269 +-
 .../queries/PlannerTest/tpcds/tpcds-q28.test       |   195 +-
 .../queries/PlannerTest/tpcds/tpcds-q29.test       |   113 +-
 .../queries/PlannerTest/tpcds/tpcds-q30.test       |    91 +-
 .../queries/PlannerTest/tpcds/tpcds-q31.test       |   361 +-
 .../queries/PlannerTest/tpcds/tpcds-q32.test       |    71 +-
 .../queries/PlannerTest/tpcds/tpcds-q33.test       |   668 +-
 .../queries/PlannerTest/tpcds/tpcds-q34.test       |    62 +-
 .../queries/PlannerTest/tpcds/tpcds-q35a.test      |   146 +-
 .../queries/PlannerTest/tpcds/tpcds-q36.test       |   247 +-
 .../queries/PlannerTest/tpcds/tpcds-q37.test       |    65 +-
 .../queries/PlannerTest/tpcds/tpcds-q38.test       |   494 +-
 .../queries/PlannerTest/tpcds/tpcds-q39a.test      |   144 +-
 .../queries/PlannerTest/tpcds/tpcds-q39b.test      |   145 +-
 .../queries/PlannerTest/tpcds/tpcds-q40.test       |    67 +-
 .../queries/PlannerTest/tpcds/tpcds-q41.test       |    19 +-
 .../queries/PlannerTest/tpcds/tpcds-q42.test       |    42 +-
 .../queries/PlannerTest/tpcds/tpcds-q43.test       |    42 +-
 .../queries/PlannerTest/tpcds/tpcds-q44.test       |   362 +-
 .../queries/PlannerTest/tpcds/tpcds-q45.test       |   315 +-
 .../queries/PlannerTest/tpcds/tpcds-q46.test       |   114 +-
 .../queries/PlannerTest/tpcds/tpcds-q47.test       |   226 +-
 .../queries/PlannerTest/tpcds/tpcds-q48.test       |    84 +-
 .../queries/PlannerTest/tpcds/tpcds-q49.test       |    62 +-
 .../queries/PlannerTest/tpcds/tpcds-q50.test       |   102 +-
 .../queries/PlannerTest/tpcds/tpcds-q51.test       |   112 +-
 .../queries/PlannerTest/tpcds/tpcds-q52.test       |    42 +-
 .../queries/PlannerTest/tpcds/tpcds-q53.test       |    48 +-
 .../queries/PlannerTest/tpcds/tpcds-q54.test       |   148 +-
 .../queries/PlannerTest/tpcds/tpcds-q55.test       |    42 +-
 .../queries/PlannerTest/tpcds/tpcds-q56.test       |   134 +-
 .../queries/PlannerTest/tpcds/tpcds-q57.test       |   156 +-
 .../queries/PlannerTest/tpcds/tpcds-q58.test       |   228 +-
 .../queries/PlannerTest/tpcds/tpcds-q59.test       |   172 +-
 .../queries/PlannerTest/tpcds/tpcds-q60.test       |   686 +-
 .../queries/PlannerTest/tpcds/tpcds-q61.test       |   163 +-
 .../queries/PlannerTest/tpcds/tpcds-q62.test       |    48 +-
 .../queries/PlannerTest/tpcds/tpcds-q63.test       |    48 +-
 .../queries/PlannerTest/tpcds/tpcds-q64.test       |   409 +-
 .../queries/PlannerTest/tpcds/tpcds-q65.test       |   108 +-
 .../queries/PlannerTest/tpcds/tpcds-q66.test       |   163 +-
 .../queries/PlannerTest/tpcds/tpcds-q67.test       |   342 +-
 .../queries/PlannerTest/tpcds/tpcds-q68.test       |   114 +-
 .../queries/PlannerTest/tpcds/tpcds-q69.test       |   108 +-
 .../queries/PlannerTest/tpcds/tpcds-q70.test       |   384 +-
 .../queries/PlannerTest/tpcds/tpcds-q71.test       |   106 +-
 .../queries/PlannerTest/tpcds/tpcds-q72.test       |   156 +-
 .../queries/PlannerTest/tpcds/tpcds-q73.test       |    76 +-
 .../queries/PlannerTest/tpcds/tpcds-q74.test       |   250 +-
 .../queries/PlannerTest/tpcds/tpcds-q75.test       |   236 +-
 .../queries/PlannerTest/tpcds/tpcds-q76.test       |   112 +-
 .../queries/PlannerTest/tpcds/tpcds-q77.test       |   752 +-
 .../queries/PlannerTest/tpcds/tpcds-q78.test       |   139 +-
 .../queries/PlannerTest/tpcds/tpcds-q79.test       |    72 +-
 .../queries/PlannerTest/tpcds/tpcds-q80.test       |   815 +-
 .../queries/PlannerTest/tpcds/tpcds-q81.test       |   138 +-
 .../queries/PlannerTest/tpcds/tpcds-q82.test       |    82 +-
 .../queries/PlannerTest/tpcds/tpcds-q83.test       |   219 +-
 .../queries/PlannerTest/tpcds/tpcds-q84.test       |    60 +-
 .../queries/PlannerTest/tpcds/tpcds-q85.test       |   106 +-
 .../queries/PlannerTest/tpcds/tpcds-q86.test       |   202 +-
 .../queries/PlannerTest/tpcds/tpcds-q87.test       |   476 +-
 .../queries/PlannerTest/tpcds/tpcds-q88.test       |   404 +-
 .../queries/PlannerTest/tpcds/tpcds-q89.test       |    48 +-
 .../queries/PlannerTest/tpcds/tpcds-q90.test       |    98 +-
 .../queries/PlannerTest/tpcds/tpcds-q91.test       |    90 +-
 .../queries/PlannerTest/tpcds/tpcds-q92.test       |    70 +-
 .../queries/PlannerTest/tpcds/tpcds-q93.test       |    62 +-
 .../queries/PlannerTest/tpcds/tpcds-q94.test       |    76 +-
 .../queries/PlannerTest/tpcds/tpcds-q95.test       |   456 +-
 .../queries/PlannerTest/tpcds/tpcds-q96.test       |    68 +-
 .../queries/PlannerTest/tpcds/tpcds-q97.test       |    72 +-
 .../queries/PlannerTest/tpcds/tpcds-q98.test       |    80 +-
 .../queries/PlannerTest/tpcds/tpcds-q99.test       |    48 +-
 .../queries/PlannerTest/tpch-all.test              |   232 +-
 .../queries/PlannerTest/tpch-kudu.test             |    90 +-
 .../queries/PlannerTest/tpch-nested.test           |   256 +-
 .../queries/PlannerTest/union.test                 |    48 +-
 .../queries/QueryTest/acid-insert.test             |     3 +
 .../QueryTest/admission-max-min-mem-limits.test    |    22 +-
 .../QueryTest/admission-reject-mem-estimate.test   |     2 +-
 .../admission-reject-min-reservation.test          |    12 +-
 .../queries/QueryTest/alter-table.test             |    14 +-
 .../analytic-fns-tpcds-partitioned-topn.test       |   325 +
 .../queries/QueryTest/analytic-fns.test            |    21 +-
 .../queries/QueryTest/bloom_filters.test           |     6 +-
 .../queries/QueryTest/codegen-mem-limit.test       |     3 +
 .../QueryTest/compute-stats-incremental.test       |   315 +-
 .../queries/QueryTest/compute-stats.test           |     6 +-
 .../queries/QueryTest/create-table-like-table.test |     2 +-
 .../queries/QueryTest/create-table.test            |     6 +-
 .../queries/QueryTest/datasketches-theta.test      |   569 +
 .../queries/QueryTest/date-fileformat-support.test |    10 +-
 .../queries/QueryTest/date-partitioning.test       |    14 +-
 .../QueryTest/decimal-insert-overflow-exprs.test   |   116 +
 .../QueryTest/dedicated-coord-mem-estimates.test   |    18 +-
 .../queries/QueryTest/exchange-mem-scaling.test    |     2 +-
 .../queries/QueryTest/explain-level2.test          |     6 +-
 .../queries/QueryTest/explain-level3.test          |     2 +-
 .../queries/QueryTest/full-acid-rowid.test         |    32 +-
 .../queries/QueryTest/grant_revoke.test            |  1275 +
 .../queries/QueryTest/hdfs-caching.test            |     4 +-
 .../QueryTest/hdfs-scanner-thread-mem-scaling.test |     2 +-
 .../queries/QueryTest/iceberg-alter.test           |    70 +-
 .../queries/QueryTest/iceberg-create.test          |   132 +-
 .../queries/QueryTest/iceberg-ctas.test            |   105 +
 .../queries/QueryTest/iceberg-insert.test          |    23 -
 .../queries/QueryTest/iceberg-negative.test        |   106 +-
 .../queries/QueryTest/iceberg-overwrite.test       |   168 +
 .../iceberg-partition-transform-insert.test        |   869 +
 .../QueryTest/iceberg-partitioned-insert.test      |   252 +
 .../queries/QueryTest/iceberg-query.test           |   103 +
 .../queries/QueryTest/iceberg-truncate.test        |    82 +
 .../queries/QueryTest/inline-view.test             |    36 +
 .../functional-query/queries/QueryTest/insert.test |   256 +-
 .../queries/QueryTest/insert_null.test             |    16 +-
 .../queries/QueryTest/insert_overwrite.test        |    28 +-
 .../queries/QueryTest/insert_part_key.test         |     2 +-
 .../queries/QueryTest/insert_permutation.test      |    24 +-
 .../functional-query/queries/QueryTest/load.test   |     2 +-
 .../queries/QueryTest/min_max_filters.test         |     2 +-
 .../functional-query/queries/QueryTest/misc.test   |     9 +
 .../queries/QueryTest/multiple-filesystems.test    |     4 +-
 .../queries/QueryTest/outer-to-inner-joins.test    |    27 +
 .../queries/QueryTest/overlap_min_max_filters.test |   219 +
 .../QueryTest/parquet-int64-timestamps.test        |    40 +
 .../QueryTest/parquet-resolution-by-name.test      |     2 +-
 .../queries/QueryTest/parquet-rle-dictionary.test  |    16 +
 .../queries/QueryTest/partition-col-types.test     |    22 +-
 .../queries/QueryTest/partitioned-top-n.test       |    82 +
 .../queries/QueryTest/query-resource-limits.test   |    74 +
 .../QueryTest/range-constant-propagation.test      |    27 +-
 .../queries/QueryTest/ranger_alltypes_mask.test    |    58 +
 .../ranger_alltypes_mask_date_show_year.test       |    58 +
 .../QueryTest/ranger_alltypes_mask_hash.test       |    58 +
 .../QueryTest/ranger_alltypes_mask_none.test       |    58 +
 .../QueryTest/ranger_alltypes_mask_null.test       |    58 +
 .../ranger_alltypes_mask_show_first_4.test         |    58 +
 .../ranger_alltypes_mask_show_last_4.test          |    58 +
 .../queries/QueryTest/ranger_column_masking.test   |    16 +
 .../ranger_column_masking_and_row_filtering.test   |    72 +
 .../queries/QueryTest/ranger_row_filtering.test    |   501 +
 .../queries/QueryTest/runtime_filters.test         |    33 +
 .../QueryTest/runtime_row_filter_reservations.test |     4 +-
 .../queries/QueryTest/scratch-limit.test           |    44 +
 .../functional-query/queries/QueryTest/set.test    |     2 +-
 .../queries/QueryTest/show-create-table.test       |   128 +-
 .../queries/QueryTest/special-strings.test         |    82 +
 .../queries/QueryTest/spilling-aggs.test           |     2 +-
 .../QueryTest/spilling-broadcast-joins.test        |     2 +-
 ...gression-exhaustive-no-default-buffer-size.test |     2 +-
 .../queries/QueryTest/spilling.test                |    66 +
 .../queries/QueryTest/stats-extrapolation.test     |     4 +-
 .../queries/QueryTest/subquery.test                |     6 +-
 .../functional-query/queries/QueryTest/top-n.test  |    89 +
 .../queries/QueryTest/utf8-string-functions.test   |   116 +
 .../queries/limit-pushdown-analytic.test           |    96 +
 .../queries/primitive_orderby_all.test             |     2 +-
 .../queries/primitive_orderby_bigint.test          |     2 +-
 .../primitive_orderby_bigint_expression.test       |     2 +-
 .../queries/primitive_top-n_partitioned.test       |    45 +
 .../tpcds-insert/queries/partitioned-insert.test   |  1038 +-
 .../tpch/queries/limit-pushdown-analytic.test      |   149 +
 .../tpch/queries/runtime-profile-aggregated.test   |     2 +-
 tests/authorization/test_ranger.py                 |   548 +-
 tests/common/custom_cluster_test_suite.py          |     5 +-
 tests/common/impala_cluster.py                     |    49 +-
 tests/common/impala_service.py                     |     7 +
 tests/common/impala_test_suite.py                  |    88 +-
 tests/common/skip.py                               |    23 +-
 tests/common/test_result_verifier.py               |    95 +-
 tests/comparison/cluster.py                        |     2 +-
 tests/custom_cluster/test_admission_controller.py  |   152 +-
 tests/custom_cluster/test_auto_scaling.py          |    56 +-
 tests/custom_cluster/test_blacklist.py             |   180 +-
 tests/custom_cluster/test_client_ssl.py            |    77 +-
 tests/custom_cluster/test_coordinators.py          |     3 +-
 tests/custom_cluster/test_event_processing.py      |     4 +-
 tests/custom_cluster/test_hdfs_fd_caching.py       |    52 +-
 .../test_hive_parquet_codec_interop.py             |     9 +-
 .../custom_cluster/test_hive_text_codec_interop.py |     3 +-
 tests/custom_cluster/test_insert_behaviour.py      |     3 +-
 tests/custom_cluster/test_lineage.py               |     3 +-
 tests/custom_cluster/test_local_catalog.py         |     3 +-
 tests/custom_cluster/test_local_tz_conversion.py   |     3 +-
 tests/custom_cluster/test_metadata_replicas.py     |     2 +
 .../custom_cluster/test_parquet_max_page_header.py |     6 +-
 tests/custom_cluster/test_permanent_udfs.py        |     9 +-
 tests/custom_cluster/test_query_retries.py         |   163 +-
 tests/custom_cluster/test_restart_services.py      |     3 +-
 tests/custom_cluster/test_rpc_timeout.py           |     4 +-
 tests/custom_cluster/test_saml2_sso.py             |   312 +
 tests/custom_cluster/test_scratch_disk.py          |   202 +-
 .../test_thrift_debug_string_exception.py          |    51 +
 .../custom_cluster/test_topic_update_frequency.py  |   214 +
 tests/data_errors/test_data_errors.py              |     6 +-
 tests/experiments/test_targeted_perf.py            |     3 +
 tests/failure/test_failpoints.py                   |     5 +-
 tests/hs2/test_hs2.py                              |    17 +
 tests/metadata/test_catalogd_debug_actions.py      |     3 +-
 tests/metadata/test_compute_stats.py               |    15 +-
 tests/metadata/test_ddl.py                         |     3 +-
 tests/metadata/test_hdfs_encryption.py             |     4 +-
 tests/metadata/test_hdfs_permissions.py            |     3 +-
 tests/metadata/test_hms_integration.py             |     4 +-
 tests/metadata/test_metadata_query_statements.py   |     4 +-
 tests/metadata/test_partition_metadata.py          |     4 +-
 tests/metadata/test_refresh_partition.py           |     4 +-
 tests/metadata/test_reset_metadata.py              |     3 +-
 tests/metadata/test_show_create_table.py           |     5 +-
 tests/metadata/test_stale_metadata.py              |     7 +-
 tests/metadata/test_testcase_builder.py            |     3 +
 tests/metadata/test_views_compatibility.py         |     4 +-
 tests/observability/test_profile_tool.py           |    79 +
 tests/query_test/test_acid.py                      |    42 +-
 tests/query_test/test_aggregation.py               |     2 -
 tests/query_test/test_analytic_tpcds.py            |     5 +
 tests/query_test/test_datasketches.py              |     5 +
 tests/query_test/test_date_queries.py              |     3 +-
 tests/query_test/test_decimal_queries.py           |   111 +
 tests/query_test/test_hbase_queries.py             |     2 +
 tests/query_test/test_hdfs_caching.py              |    25 +-
 tests/query_test/test_iceberg.py                   |    59 +-
 tests/query_test/test_insert.py                    |     5 +-
 tests/query_test/test_insert_behaviour.py          |    10 +-
 tests/query_test/test_insert_parquet.py            |     4 +-
 tests/query_test/test_insert_permutation.py        |     2 -
 tests/query_test/test_join_queries.py              |     2 +
 tests/query_test/test_kudu.py                      |     3 +
 tests/query_test/test_limit_pushdown_analytic.py   |    24 +-
 tests/query_test/test_mem_usage_scaling.py         |    11 +-
 tests/query_test/test_nested_types.py              |     6 +-
 tests/query_test/test_observability.py             |     4 +-
 tests/query_test/test_partitioning.py              |     4 +-
 tests/query_test/test_queries.py                   |    13 +-
 tests/query_test/test_query_mem_limit.py           |     4 +
 tests/query_test/test_resource_limits.py           |     5 +-
 tests/query_test/test_result_spooling.py           |     2 +-
 tests/query_test/test_runtime_filters.py           |    22 +
 tests/query_test/test_scanners.py                  |    54 +-
 tests/query_test/test_scratch_limit.py             |    14 +
 tests/query_test/test_sort.py                      |     4 +-
 tests/query_test/test_udfs.py                      |     2 +-
 ...t_pushdown_analytic.py => test_utf8_strings.py} |    25 +-
 tests/shell/test_shell_client.py                   |     2 +-
 tests/shell/test_shell_commandline.py              |    56 +-
 tests/shell/test_shell_interactive.py              |    68 +-
 tests/stress/test_acid_stress.py                   |     5 +-
 tests/stress/test_ddl_stress.py                    |     4 +-
 tests/util/cancel_util.py                          |    13 +-
 tests/util/filesystem_utils.py                     |     3 +-
 tests/util/test_file_parser.py                     |     2 +
 www/sessions.tmpl                                  |    13 +-
 870 files changed, 157654 insertions(+), 14690 deletions(-)
 create mode 100644 be/src/common/daemon-env.cc
 create mode 100644 be/src/common/daemon-env.h
 create mode 100644 be/src/exprs/iceberg-functions-ir.cc
 create mode 100644 be/src/exprs/iceberg-functions-test.cc
 create mode 100644 be/src/exprs/iceberg-functions.h
 create mode 100644 be/src/runtime/io/disk-file.cc
 create mode 100644 be/src/runtime/io/disk-file.h
 create mode 100644 be/src/runtime/io/file-writer.h
 create mode 100644 be/src/runtime/io/local-file-writer.cc
 copy be/src/runtime/{string-value.cc => io/local-file-writer.h} (51%)
 create mode 100644 be/src/scheduling/admissiond-env.cc
 create mode 100644 be/src/scheduling/admissiond-env.h
 create mode 100644 be/src/scheduling/admissiond-main.cc
 create mode 100644 be/src/thirdparty/datasketches/theta_a_not_b.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_a_not_b_impl.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_intersection.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_intersection_impl.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_sketch.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_sketch_impl.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_union.hpp
 create mode 100644 be/src/thirdparty/datasketches/theta_union_impl.hpp
 create mode 100644 be/src/thirdparty/murmurhash/MurmurHash3.cpp
 create mode 100644 be/src/thirdparty/murmurhash/MurmurHash3.h
 create mode 100644 be/src/thirdparty/murmurhash/README.md
 create mode 100644 be/src/util/impala-profile-tool.cc
 create mode 100644 be/src/util/ldap-search-bind.cc
 create mode 100644 be/src/util/ldap-search-bind.h
 create mode 100644 be/src/util/ldap-simple-bind.cc
 copy be/src/util/{ldap-util.h => ldap-simple-bind.h} (65%)
 create mode 100644 be/src/util/thrift-debug-util.h
 create mode 100755 bin/diagnostics/experimental/plan-graph.py
 rename infra/python/deps/compiled-requirements.txt => bin/init-impala-python.sh (64%)
 mode change 100644 => 100755
 copy common/thrift/{ImpalaInternalService.thrift => Query.thrift} (78%)
 copy docker/{impalad_coordinator => admissiond}/Dockerfile (70%)
 copy bin/impala-ipython => docker/docker-build.sh (52%)
 copy docker/{impala_base => impala_profile_tool}/Dockerfile (61%)
 create mode 100755 docker/publish_images_to_apache.sh
 create mode 100644 docker/quickstart-kudu-minimal.yml
 rename infra/python/deps/stage2-requirements.txt => docker/quickstart-load-data.yml (59%)
 create mode 100644 docker/quickstart.yml
 create mode 100644 docker/quickstart_client/Dockerfile
 create mode 100755 docker/quickstart_client/data-load-entrypoint.sh
 copy testdata/datasets/tpcds/tpcds_kudu_template.sql => docker/quickstart_client/load_tpcds_kudu.sql (68%)
 create mode 100644 docker/quickstart_client/load_tpcds_parquet.sql
 create mode 100644 docker/quickstart_conf/hive-site.xml
 create mode 100644 docker/quickstart_hms/Dockerfile
 create mode 100755 docker/quickstart_hms/hms-entrypoint.sh
 copy bin/impala-ipython => docker/utility_entrypoint.sh (57%)
 copy docs/topics/{impala_num_scanner_threads.xml => impala_join_rows_produced_limit.xml} (50%)
 create mode 100644 docs/topics/impala_refresh_updated_hms.xml
 copy common/fbs/IcebergObjects.fbs => fe/src/main/java/org/apache/impala/authentication/saml/AuthTokenGenerator.java (69%)
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/HiveSamlAuthTokenGenerator.java
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/HiveSamlGroupNameFilter.java
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/HiveSamlHttpServlet.java
 copy fe/src/main/java/org/apache/impala/{authorization/AuthorizationContext.java => authentication/saml/HiveSamlRelayStateInfo.java} (60%)
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/HiveSamlRelayStateStore.java
 copy be/src/util/backend-gflag-util.h => fe/src/main/java/org/apache/impala/authentication/saml/HiveSamlUtils.java (66%)
 copy be/src/runtime/string-value.cc => fe/src/main/java/org/apache/impala/authentication/saml/HttpSamlAuthenticationException.java (68%)
 copy common/fbs/IcebergObjects.fbs => fe/src/main/java/org/apache/impala/authentication/saml/HttpSamlNoGroupsMatchedException.java (76%)
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/ImpalaSamlClient.java
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/NullSessionStore.java
 create mode 100644 fe/src/main/java/org/apache/impala/authentication/saml/WrappedWebContext.java
 create mode 100644 fe/src/main/java/org/apache/impala/catalog/CtasTargetTable.java
 create mode 100644 fe/src/main/java/org/apache/impala/catalog/IcebergStructField.java
 create mode 100644 fe/src/main/java/org/apache/impala/catalog/iceberg/IcebergCtasTarget.java
 create mode 100644 fe/src/main/java/org/apache/impala/util/IcebergSchemaConverter.java
 create mode 100644 fe/src/test/java/org/apache/impala/customcluster/LdapSearchBindImpalaShellTest.java
 create mode 100644 fe/src/test/java/org/apache/impala/customcluster/LdapSimpleBindImpalaShellTest.java
 rename bin/impala-ipython => infra/python/deps/setuptools-requirements.txt (75%)
 mode change 100755 => 100644
 create mode 100644 testdata/authentication/saml2_sso.jks
 create mode 100644 testdata/authentication/saml2_sso_metadata.xml
 create mode 100644 testdata/data/alltypes_tiny_rle_dictionary.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00001-1-13d79bd6-4b97-4680-b4e1-52e93b6ce04e-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00006-6-305c9b7a-f42d-4245-b806-dfa7a792593f-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00009-9-224fe2d6-b0d9-42d6-bc95-15f52ecb29ad-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00017-17-1a38e294-5992-48d9-a18e-08e129bb418c-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00023-23-74cfcf22-3de2-489a-b1ec-d5141e75a8e8-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00027-27-5f91dc85-b8f3-4cc2-a5c6-38b7fee49709-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00030-30-dc3510cc-e765-43bc-be03-c5561a8d50a3-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-08/action=view/00031-31-364afc4a-b718-406d-a532-58fab5c8f85d-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-09/action=click/00004-4-7a1a8e89-8aeb-4405-be64-76557432cf21-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-09/action=click/00014-14-765d552a-fddc-42f3-adfd-ecba20a01d80-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-09/action=click/00015-15-9957db43-3b9a-4a50-9946-d003cc1d461c-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-09/action=click/00019-19-1e1895d0-1f42-4c30-989f-968802831077-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-09/action=click/00020-20-bb59ac6d-aeee-4c35-9f8a-1a03127d33b8-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-09/action=click/00028-28-44ba3ad9-737c-4416-a32c-501cc9a4aa90-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-10/action=download/00003-3-31478795-ff6a-4a20-9fff-8dc4907c1ba7-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-10/action=download/00007-7-3b4a35cb-22b5-4a5d-932b-89f222b0b2c7-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-10/action=download/00011-11-a40c4c8c-de16-487a-89b3-ee8e58b4fd07-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-10/action=download/00012-12-ed4ba706-2ace-4d41-b475-6bda3ba72306-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-10/action=download/00022-22-57f5e226-5f8f-49b9-b998-039b8362b7a0-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/data/event_time_hour=2020-01-01-10/action=download/00025-25-5fec3538-052d-493e-9479-b59fc8aece0f-00000.parquet
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/metadata/4ceee3ab-8653-423c-b8ac-0ad5f7b0579b-m0.avro
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/metadata/snap-8063525763252762178-1-4ceee3ab-8653-423c-b8ac-0ad5f7b0579b.avro
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/metadata/v1.metadata.json
 create mode 100644 testdata/data/iceberg_test/hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test/metadata/v2.metadata.json
 copy testdata/data/iceberg_test/{iceberg_partitioned => hadoop_catalog/iceberg_resolution_test/functional_parquet/iceberg_resolution_test}/metadata/version-hint.text (100%)
 create mode 100644 testdata/data/theta_sketches_from_hive.parquet
 create mode 100644 testdata/data/theta_sketches_from_impala.parquet
 create mode 100644 testdata/impala-profiles/README
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats.expected.json
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats.expected.pretty.json
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats.expected.pretty_extended.json
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats.expected.txt
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats_default.expected.txt
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats_extended.expected.txt
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats_v2
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats_v2_default.expected.txt
 create mode 100644 testdata/impala-profiles/impala_profile_log_tpcds_compute_stats_v2_extended.expected.txt
 create mode 100644 testdata/workloads/functional-planner/queries/PlannerTest/analytic-rank-pushdown.test
 create mode 100644 testdata/workloads/functional-planner/queries/PlannerTest/disable-runtime-overlap-filter.test
 copy testdata/workloads/functional-planner/queries/PlannerTest/{limit-pushdown-analytic.test => limit-pushdown-partitioned-top-n.test} (66%)
 create mode 100644 testdata/workloads/functional-planner/queries/PlannerTest/tpcds-dist-method.test
 mode change 100644 => 100755 testdata/workloads/functional-planner/queries/PlannerTest/tpcds/tpcds-q43.test
 mode change 100644 => 100755 testdata/workloads/functional-planner/queries/PlannerTest/tpcds/tpcds-q44.test
 mode change 100644 => 100755 testdata/workloads/functional-planner/queries/PlannerTest/tpcds/tpcds-q56.test
 mode change 100644 => 100755 testdata/workloads/functional-planner/queries/PlannerTest/tpcds/tpcds-q60.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/analytic-fns-tpcds-partitioned-topn.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/datasketches-theta.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/decimal-insert-overflow-exprs.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/grant_revoke.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/iceberg-ctas.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/iceberg-overwrite.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/iceberg-partition-transform-insert.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/iceberg-partitioned-insert.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/iceberg-truncate.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/overlap_min_max_filters.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/parquet-rle-dictionary.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/partitioned-top-n.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask_date_show_year.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask_hash.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask_none.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask_null.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask_show_first_4.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_alltypes_mask_show_last_4.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_column_masking_and_row_filtering.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/ranger_row_filtering.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/scratch-limit.test
 create mode 100644 testdata/workloads/functional-query/queries/QueryTest/utf8-string-functions.test
 create mode 100644 testdata/workloads/functional-query/queries/limit-pushdown-analytic.test
 create mode 100644 testdata/workloads/targeted-perf/queries/primitive_top-n_partitioned.test
 create mode 100644 tests/custom_cluster/test_saml2_sso.py
 create mode 100644 tests/custom_cluster/test_thrift_debug_string_exception.py
 create mode 100644 tests/custom_cluster/test_topic_update_frequency.py
 create mode 100644 tests/observability/test_profile_tool.py
 copy tests/query_test/{test_limit_pushdown_analytic.py => test_utf8_strings.py} (52%)