Impala 4.5.0 Change Log
New Feature
- [IMPALA-889] - Add trim() function matching ANSI
SQL definition
- [IMPALA-10408] - Build against Apache official
versions
- [IMPALA-12648] - Support killing queries and
sessions programatically
- [IMPALA-12732] - Add support for MERGE
statements for Iceberg tables
- [IMPALA-12785] - Exposing control of the
event-processor by SQL commands
- [IMPALA-13038] - Support profile tab for
imported query profiles
- [IMPALA-13064] - Install services from RPM/DEB
packages
- [IMPALA-13137] - Add additional client fetch
metrics columns to the queries page
- [IMPALA-13208] - Add cluster id to the
membership and request-queue topic names
- [IMPALA-13288] - OAuth AuthN Support for Impala
backend
- [IMPALA-13233] - Represent phases of each
instance separately on the webUI's query timeline
Improvement
- [IMPALA-2945] - Pre-aggregation cardinality
estimates do not take into account data distribution
- [IMPALA-5792] - Eliminate duplicate beeswax
python code
- [IMPALA-8042] - Better selectivity estimate for
BETWEEN
- [IMPALA-11265] - Iceberg tables have a large
memory footprint in catalog cache
- [IMPALA-12093] - impala-shell should preserve
all cookies by default
- [IMPALA-12165] - Add support for compiling C++
code with -gsplit-dwarf
- [IMPALA-12216] - Print timestamp for
impala-shell errors
- [IMPALA-12363] - Upgrade re2 to version
2023-03-01 or higher
- [IMPALA-12370] - Add an option to customize
timezone when working with UNIXTIME_MICROS columns of Kudu tables
- [IMPALA-12390] - Enable performance related
clang-tidy checks
- [IMPALA-12461] - Avoid write lock on the table
during self-event detection
- [IMPALA-12541] - Compile toolchain GCC with
--enable-linker-build-id to add Build ID to binaries
- [IMPALA-12554] - Create only one Ranger policy
for GRANT statement
- [IMPALA-12607] - Bump GBN to get HMS thift API
change HIVE-27499
- [IMPALA-12684] - Use
IMPALA_COMPRESSED_DEBUG_INFO=true by default
- [IMPALA-12686] - Build the toolchain with basic
debug information (-g1)
- [IMPALA-12737] - Include List of Referenced
Columns in Query Log Table
- [IMPALA-12800] - Queries with many nested
inline views see performance issues with ExprSubstitutionMap
- [IMPALA-12886] - Bump GoogleTest to 1.14.0
- [IMPALA-12950] - Improve error message in case
of out-of-range numeric conversions
- [IMPALA-13001] - Add graceful and force
shutdown for packaging script.
- [IMPALA-13014] - Upgrade Maven to 3.9.6 for
resolver fixes and improvements
- [IMPALA-13031] - Enhancing logging for spilling
configuration with local buffer directory details
- [IMPALA-13072] - Toolchain: Add retries for
uploading artifacts to the s3 buckets
- [IMPALA-13073] - Toolchain builds should pass
VERBOSE=1 into make
- [IMPALA-13075] - Setting very high BATCH_SIZE
can blow up memory usage of fragments
- [IMPALA-13083] - Clarify
REASON_MEM_LIMIT_TOO_LOW_FOR_RESERVATION error message
- [IMPALA-13088] - Speedup IcebergDeleteBuilder
- [IMPALA-13106] - Support larger imported query
profile sizes through compression
- [IMPALA-13109] - Use RoaringBitmap in
IcebergDeleteNode
- [IMPALA-13115] - Always add the query id in the
error message to clients
- [IMPALA-13120] - Failed table loads are not
tried to load again even though hive metastore is UP
- [IMPALA-13148] - Show the number of in-progress
Catalog operations
- [IMPALA-13168] - Add README file for setting up
Trino
- [IMPALA-13189] - Reset imported query profiles
database instead of clearing the object store
- [IMPALA-13194] - Fast-serialize position delete
records
- [IMPALA-13201] - Queries Against System Tables
Must Not Be Subject to Admission Control
- [IMPALA-13209] - ExchangeNode's
ConvertRowBatchTime can be high
- [IMPALA-13254] - Optimizing incremental reload
performance of Iceberg tables
- [IMPALA-13293] - LocalCatalog's
waitForCatalogUpdate() sleeps too much
- [IMPALA-13308] - Build toolchain GCC with
profile guided optimization
- [IMPALA-13312] - Use client address from
X-Forwarded-For Header in Ranger Audit Logs
- [IMPALA-13319] - Avoid duplicate exec option
declaration in py.test
- [IMPALA-13323] - Remove redundant tests in
test_join_queries.py
- [IMPALA-13325] - Use RowBatch::CopyRows in
IcebergDeleteNode
- [IMPALA-13371] - Avoid throwing exceptions in
FileSystemUtil::FindFileInPath()
- [IMPALA-13372] - Declare batch_size dimension
for TestAggregationQueriesRunOnce
- [IMPALA-13396] - Unify temporary dir management
in CustomClusterTestSuite
- [IMPALA-13405] - Lower AggregationNode
cardinality by analyzing estimate of source Tuple
- [IMPALA-13412] - Switch
impala.tuple-cache.entries-in-use-bytes from UNIT to BYTES
- [IMPALA-13415] - Add a reporting mode that can
proceed past query failures in run_test_case()
- [IMPALA-13427] - Make the statestore HA
rpc's socket connection timeout tunable
- [IMPALA-13433] - Make query_test/test_sfs.py
resilient to HMS failure to create database directories
- [IMPALA-13465] - Trace TupleId further to
reduce Agg cardinality
- [IMPALA-13501] - Conflicting commits to Iceberg
tables leave uncommitted orphan files
- [IMPALA-13507] - Add param to disable glog
buffering in with_args fixture
- [IMPALA-13509] - Avoid duplicate deepcopy
during hash partitioning in KrpcDataStreamSender
- [IMPALA-13512] - Print .test file name if
PlannerTest fail
- [IMPALA-13516] - Calcite Planner: Fix explicit
cast issues
- [IMPALA-13535] - Add script to restore stats on
PlannerTest files
- [IMPALA-13543] - Make tpcds_partitioned
eligible for single_node_perf_run.py
- [IMPALA-13556] - Log GetRuntimeProfile and
GetExecSummary at VLOG_QUERY
- [IMPALA-13565] - Add general AI support to
ai_generate_text built-in function
- [IMPALA-13567] - Update RowsRead counter more
frequently.
- [IMPALA-13585] - Make pip_download.py
interruptible
- [IMPALA-13617] - Rename c_last_review_date to
c_last_review_date_sk
- [IMPALA-13620] - Lower default parallelism of
compute_table_stats.py
- [IMPALA-13628] - PeriodicCounterUpdater should
use impala::Thread
- [IMPALA-13636] - TestTpcdsInsert ignores
file_format from test vector
- [IMPALA-13637] - Create a backend flag to
control tuple-analysis in AggregationNode
- [IMPALA-13641] - Parquet specific counters
should not exist if not reading any parquet file
- [IMPALA-13642] - Several test vector is being
ignored in test_scanners.py
- [IMPALA-13643] -
HDFS_SCANNER_THREAD_CHECK_SOFT_MEM_LIMIT is ineffective in MT_DOP > 0
- [IMPALA-13658] - Cache aggregate results below
exchange
- [IMPALA-13665] - Parallelize TestDecimalFuzz
- [IMPALA-13668] - Add default_test_protocol
parameter to conftest.py
- [IMPALA-13683] - Add env var to skip infra
tests and verifiers.
- [IMPALA-13694] - Add
ImpalaConnection.reset_configuration method.
- [IMPALA-13747] - unique_database fixture may
taint ImpalaTestSuite.client
Bug
- [IMPALA-9441] - TestHS2.test_get_schemas is
flaky in local catalog mode
- [IMPALA-10451] -
TestAvroSchemaResolution.test_avro_schema_resolution fails when bumping Hive to have HIVE-24157
- [IMPALA-11298] - Compare only the short
username when checking session user against connection user
- [IMPALA-11431] -
TestComputeStatsWithNestedTypes.test_compute_stats_with_structs fails in an exhaustive build
- [IMPALA-11761] -
test_partition_dir_removed_inflight fails with "AssertionError: REFRESH should fail"
- [IMPALA-11934] - TestBatchReadingFromRemote
seems to be flaky in the Ozone build
- [IMPALA-11943] - Performance regression in utf8
string functions due to utf8_mode checks
- [IMPALA-12146] - Memory reserved doesn't
get updated if an executor backend gets abnormally terminated
- [IMPALA-12277] - metadata reload of INSERT
failed by NullPointerException: Invalid partition name
- [IMPALA-12336] - Testcases failed with
"Memory is likely oversubscribed"
- [IMPALA-12345] - Add user quotas to Admission
Control
- [IMPALA-12559] - Support x5c Parameter in JSON
Web Keys (JWK)
- [IMPALA-12616] -
test_restart_catalogd_while_handling_rpc_response* tests fail not reaching expected states
- [IMPALA-12680] - NullPointerException in
addHmsPartitions() during MetastoreEventsProcessor switch state from PAUSED to ACTIVE
- [IMPALA-12712] - INVALIDATE METADATA
<table> should set a better createEventId
- [IMPALA-12758] - Event Processor is ignoring
the prev_id while reloading the existing partitions
- [IMPALA-12771] - Impala catalogd events-skipped
may mark the wrong number
- [IMPALA-12792] - Wrong indentation in
DataSourceScanNode.getNodeExplainString
- [IMPALA-12850] - Add better error message for
REFRESH iceberg_tbl PARTITION(...)
- [IMPALA-12856] - IllegalStateException in
processing RELOAD events due to malformed HMS Partition objects
- [IMPALA-12857] - Add flag to enable
merge-on-read even if tables are configured with copy-on-write
- [IMPALA-12861] - File formats are confused when
Iceberg tables has mixed formats
- [IMPALA-12937] -
test_admission_controller.py::test_mem_limit failed in exhaustive build
- [IMPALA-12943] - Document User Quota Model for
Admission control
- [IMPALA-12967] - Testcase fails at
test_migrated_table_field_id_resolution due to "Table does not exist"
- [IMPALA-12997] - test_query_log tests get stuck
trying to write to the log
- [IMPALA-13028] - libkudu_client.so is not
stripped in the DEB/RPM packages
- [IMPALA-13034] - Add logs for slow HTTP
requests dumping the profile
- [IMPALA-13035] - Querying metadata tables from
non-Iceberg tables throws IllegalArgumentException
- [IMPALA-13040] - SIGSEGV in
QueryState::UpdateFilterFromRemote
- [IMPALA-13049] - Add dependency management for
the log4j2 version
- [IMPALA-13057] - Incorporate tuple/slot
information into the tuple cache key
- [IMPALA-13058] -
TestRuntimeFilters.test_basic_filters failed in exhaustive mode on ARM builds
- [IMPALA-13059] - Testcase fails at
test_migrated_table_field_id_resolution due to unmatched column number or metadata file for version 2 is missing
- [IMPALA-13067] - Some regex make the tests
unconditionally pass
- [IMPALA-13076] - Add pstack and jstack to
Impala docker images
- [IMPALA-13077] - Equality predicate on
partition column and uncorrelated subquery doesn't reduce the cardinality estimate
- [IMPALA-13082] - Use separate versions for
jackson-databind vs jackson-core, etc.
- [IMPALA-13085] - Add warning and NULL out
DECIMAL values in Iceberg metadata tables
- [IMPALA-13086] - Cardinality estimate of
AggregationNode should consider predicates on group-by columns
- [IMPALA-13089] - Patch for IMPALA-12559 breaks
compilation on Ubuntu 16 and CentOS 7
- [IMPALA-13091] -
query_test.test_iceberg.TestIcebergV2Table.test_metadata_tables fails on an expected constant
- [IMPALA-13102] - Loading tables with illegal
stats failed
- [IMPALA-13105] - Multiple imported query
profiles fail to import/clear at once
- [IMPALA-13107] - Invalid TExecPlanFragmentInfo
received by executor with instance number as 0
- [IMPALA-13111] - impala-gdb.py's
find-query-ids/find-fragment-instances return unusable query ids
- [IMPALA-13119] - CostingSegment.java is
initialized with wrong cost
- [IMPALA-13128] - disk-file-test hangs on ARM +
UBSAN test jobs
- [IMPALA-13129] - Hit DCHECK when skipping
MIN_MAX runtime filter
- [IMPALA-13130] - Under heavy load, Impala does
not prioritize data stream operations
- [IMPALA-13131] - Azure OpenAI API expects
'api-key' instead of 'Authorization' in the request header
- [IMPALA-13132] - Ozone jobs see intermittent
termination of Ozone manager / HMS fails to start
- [IMPALA-13134] - DDL hang with SYNC_DDL enabled
when Catalogd is changed to standby status
- [IMPALA-13138] - Never smallify existing
StringValue objects, only new ones during DeepCopy
- [IMPALA-13143] -
TestCatalogdHA.test_catalogd_failover_with_sync_ddl times out expecting query failure
- [IMPALA-13144] -
TestIcebergTable.test_migrated_table_field_id_resolution fails with Disk I/O error
- [IMPALA-13146] - Javascript tests sometimes
fail to download NodeJS
- [IMPALA-13150] - Possible buffer overflow in
StringVal::CopyFrom()
- [IMPALA-13151] -
DataStreamTestSlowServiceQueue.TestPrioritizeEos fails on ARM
- [IMPALA-13152] - IllegalStateException in
computing processing cost when there are predicates on analytic output columns
- [IMPALA-13154] - Some tables are missing in
Top-N Tables with Highest Memory Requirements
- [IMPALA-13159] - Running queries been cancelled
after statestore failover
- [IMPALA-13161] - impalad crash --
impala::DelimitedTextParser<true>::ParseFieldLocations
- [IMPALA-13167] - Impala's coordinator could
not be connected after a restart in custom cluster test in the ASAN build
- [IMPALA-13170] -
InconsistentMetadataFetchException due to database dropped when showing databases
- [IMPALA-13179] - Disable tuple caching when
using non-deterministic functions
- [IMPALA-13181] - Disable tuple caching for
locations that have a limit
- [IMPALA-13185] - Tuple cache keys need to
incorporate runtime filter information
- [IMPALA-13186] - Tuple cache keys should
incorporate information about related query options
- [IMPALA-13193] - RuntimeFilter on parquet
dictionary should evaluate null values
- [IMPALA-13195] - Failed test:
test_migrated_table_field_id_resolution with missing metadata file
- [IMPALA-13196] - Query timeline page can not
display normally when Knox proxying is being used
- [IMPALA-13203] - ExprRewriter did not rewrite
'id = 0 OR false' as expected
- [IMPALA-13207] - The 'sys' database for
system tables blacklisted by default
- [IMPALA-13214] -
test_shell_commandline..test_removed_query_option failed with assertion failure
- [IMPALA-13222] - Impala S3 test runs leave
stale files in the .Trash subtree on S3
- [IMPALA-13226] - TupleCacheInfo unintentionally
overwrites Object.finalize()
- [IMPALA-13231] - Some auto-generated files for
ranger are not ignored by Git
- [IMPALA-13232] - Loading external data sources
fails in JDK11 builds
- [IMPALA-13252] - Filter update log message
prints TUniqueId in non-standard format
- [IMPALA-13262] - Predicate pushdown causes
incorrect results in join condition
- [IMPALA-13270] - Bug when comparing
ExprSubstitutionMap.size()
- [IMPALA-13272] - Analytic function of
collections can lead to crash
- [IMPALA-13274] - Crash in
impala::RowDescriptor::TupleIsNullable(int)
- [IMPALA-13277] - test_create_cache_many_tables
fails with 'InvalidOperationException: Alter table in REMOTE database is not allowed'
- [IMPALA-13279] - In some environments, code
coverage produces an empty report
- [IMPALA-13280] - Cluster of memory
oversubscription errors
- [IMPALA-13286] - Zero-sized rows in
BufferedTupleStream can cause impalad to crash
- [IMPALA-13291] - finalize.sh reports that
py.test was oom killed in test run
- [IMPALA-13295] - Undefined name 'index'
in tests/util/workload_management.py
- [IMPALA-13296] - Hive to Iceberg
table-migration: pre-check column compatibility
- [IMPALA-13298] -
TestRPCTimeout.test_miss_complete_cb: RPC Failed: Could Not Connect
- [IMPALA-13300] - Maven Could Not Acquire
Lock(s)
- [IMPALA-13302] - Some ExprRewriteRule results
are not analyzed, leading to unmaterialized slots from reAnalyze
- [IMPALA-13303] - File listing could still be
recursive even if impala.disable.recursive.listing is true
- [IMPALA-13309] - Toolchain Kudu build fails
unable to find gradle-scalafmt
- [IMPALA-13310] - Add the value of the http
‘X-Forwarded-For’ header to the runtime profile
- [IMPALA-13311] - Hive3 INSERT failed by
ClassNotFoundException: org.apache.tez.runtime.api.Event
- [IMPALA-13313] - Potential deadlock in
ImpalaServer::ExpireQueries()
- [IMPALA-13315] - Test_tuple_cache_tpc_queries
failing
- [IMPALA-13316] -
test_local_catalog_no_event_processing failing for impala asf asan
- [IMPALA-13317] - Test_tuple_cache_tpc_queries
failing
- [IMPALA-13322] - Cannot Alter Table
sys.impala_query_live
- [IMPALA-13328] - Failed to build the
impala_quickstart_client docker image
- [IMPALA-13330] - test_nested_types.py does not
exercise orc_schema_resolution
- [IMPALA-13334] - test_sort.py hit DCHECK when
max_sort_run_size>0
- [IMPALA-13340] - COPY TESTCASE in LocalCatalog
mode doesn't dump the partition and file metadata
- [IMPALA-13341] - Fix mismatch exec option
values in py.test files
- [IMPALA-13343] -
TestTPCHJoinQueries.test_outer_joins create duplicate table
- [IMPALA-13344] - Impala rewrites may be
incomplete
- [IMPALA-13347] - TSAN failure in backend tests
after IMPALA-12737
- [IMPALA-13349] - Fix remaining tests that have
unexercised exec option dimensions
- [IMPALA-13350] - Workload Management flush on
interval test failed
- [IMPALA-13364] - Schema resolution doesn't
work for migrated partitioned Iceberg tables that have complex types
- [IMPALA-13377] - test_recover_partitions.py
does not exercise its vector
- [IMPALA-13378] - Impalad crash in
RowDescriptor::InitTupleIdxMap()
- [IMPALA-13383] -
TestIcebergTable.test_create_table_like_table failed in exhaustive mode
- [IMPALA-13384] - Precommit jobs
*-build-only[-ARM] became a lot slower
- [IMPALA-13388] -
TestStatestoredHA.test_statestored_auto_failover failed in UBSAN ARM
- [IMPALA-13390] -
TestExchangeMemUsage::test_exchange_mem_usage_scaling is flaky again
- [IMPALA-13391] - Need to exclude
log4j-slf4j-impl coming from hadoop-cloud-storage
- [IMPALA-13397] -
TestBannedLogMessages.test_no_tuniqueid fail due to log line from TransactionKeepalive.java
- [IMPALA-13399] - Thrift RPCs for Statestore
heartbeat timed out randomly in UBSAN build
- [IMPALA-13407] - Codegen fails with struct in
TOP-N
- [IMPALA-13408] - use a specific flag for the
topic prefix cluster identifier.
- [IMPALA-13411] - DCHECK can fire for scan nodes
that produce zero-length tuples
- [IMPALA-13431] -
custom_cluster.test_breakpad.TestLogging.test_excessive_cerr_ignore_pid fails on UBSAN
- [IMPALA-13432] -
TestIcebergTable.test_migrated_table_field_id_resolution_complex fails with type difference
- [IMPALA-13445] - Cost-based planning can reduce
writer parallelism too much
- [IMPALA-13448] - Impala should log the reason
why it fails to open a log file
- [IMPALA-13452] - Remove Java test dependencies
from compile scope
- [IMPALA-13462] - CalcitePlanner: add support
for specific functions used in tpcds queries
- [IMPALA-13463] - Impala should ignore case of
Iceberg schema elements
- [IMPALA-13467] - test_min_max_filters() failed
due to NullPointerException
- [IMPALA-13469] - test_query_cpu_count_on_insert
seems to be flaky
- [IMPALA-13471] - test_enable_reading_puffin()
seems to fail in the Ozone build
- [IMPALA-13477] - CTAS query should set
request_pool in QueryStateRecord
- [IMPALA-13480] - PlannerTest.testAggregation
should VALIDATE_CARDINALITY
- [IMPALA-13484] - Querying an Iceberg table with
TIMESTAMP_LTZ can cause data loss
- [IMPALA-13500] -
test_invalidate_stale_partition_on_reload is flaky
- [IMPALA-13505] - NullPointerException in
Analyzer.resolveActualPath with Calcite planner
- [IMPALA-13510] - Unset the environment variable
for tuple cache tests
- [IMPALA-13526] - Inconsistent Agg node stats
recomputation.
- [IMPALA-13536] - Tests failing in
TestWorkloadManagementInitWait on Ozone
- [IMPALA-13539] -
TestCalcitePlanner.test_calcite_frontend fails on non-HDFS test jobs
- [IMPALA-13560] -
test_admission_controller_with_quota_configs fails with assertion error
- [IMPALA-13561] -
test_read_mixed_format_position_deletes fails with newer Hive versions
- [IMPALA-13589] - SELECT INPUT__FILE__NAME can
crash Impala
- [IMPALA-13592] - OpenSSL rebase to 3.2 in RHEL
/ Rocky 9.5 breaks Impala
- [IMPALA-13596] - Verify Admission Control
configuration at startup
- [IMPALA-13597] - Precommit step
gerrit-auto-critique fails unconditionally
- [IMPALA-13598] - OPTIMIZE redundantly
accumulates memory in HDFS WRITER
- [IMPALA-13600] -
custom_cluster.test_shell_jwt_auth.TestImpalaShellJWTAuth.test_jwt_auth_valid fails intermittently
- [IMPALA-13605] - Upgrade Spring framework to
5.3.39 for bug and CVE fixes
- [IMPALA-13608] - TestIcebergTable.test_catalogs
failed in exhaustive mode
- [IMPALA-13619] - Update commons-lang3
- [IMPALA-13622] - Precondition hit when
tpch.customer stats are missing
- [IMPALA-13634] - ImpalaTestSuite.cleanup_db()
should keep the original sync_ddl value
- [IMPALA-13635] -
TestEventProcessingError.test_event_processor_error_global_invalidate fails in year 2025
- [IMPALA-13638] - Translate apostrophe to
underscore in Prometheus metric names.
- [IMPALA-13644] - Generalize and move
getPerInstanceNdvForCpuCosting into AggregationNode.
- [IMPALA-13655] - UPDATE redundantly accumulates
memory in HDFS WRITER
- [IMPALA-13656] - MERGE redundantly accumulates
memory in HDFS WRITER
- [IMPALA-13662] - ARM build of Impala fails on
Rocky 9
- [IMPALA-13664] - Lower
datanucleus.connectionPool.maxPoolSize to 20.
- [IMPALA-13672] - Migrate
query_test/test_kudu.py to use hs2 protocol.
- [IMPALA-13678] - Validate remote_submit_time
against coordinator time
- [IMPALA-13680] - Some SSL tests hang with
OpenSsl 3.2 .RHEL 9.5
- [IMPALA-13689] - Some Webserver tests fail with
newer curl version
- [IMPALA-13691] - Processing INSERT event failed
by partition values mismatch
- [IMPALA-13693] - Loading ext-data-sources fails
on Rocky 9.5 with postgresql permission issues
- [IMPALA-13701] - Make
test_invalidate_stale_partition_on_reload more deterministic
- [IMPALA-13705] - Environment specific errors in
test_encryption_exprs
- [IMPALA-13728] -
OpenSSLUtilTest.ValidateInitialize failed by AES_128_GCM not supported
- [IMPALA-13736] - Potential Use After Free in
ExecutorGroup
- [IMPALA-13742] - Failed to build RPM packages
on CentOS7 and Redhat8
- [IMPALA-13759] - Hive ACID table base folder
identification procedure is inconsistent with Hive
- [IMPALA-13761] -
TestAdmissionControllerWithACService.test_coord_only_pool_exec_groups fail
- [IMPALA-13768] - Redundant Iceberg delete
records are shuffled around which cause error "Invalid file path arrived at builder"
- [IMPALA-13769] - Use Hive ACID metadata files
when detecting base dirs created by compaction
- [IMPALA-13770] - Updating Iceberg tables with
UDFs crashes Impala
- [IMPALA-13771] - ASAN Test Failure in
cluster-membership-mgr-test
Task
- [IMPALA-6311] - Evaluate smaller FPP for Bloom
filters
- [IMPALA-12769] - test_query_cancel_exception
failed in ASAN build
- [IMPALA-12906] - Incorporate run time scan
range information into the tuple cache key
- [IMPALA-12907] - Add test for TPC-H / TPC-DS
queries with tuple caching
- [IMPALA-12908] - Add a correctness verification
mode for tuple caching
- [IMPALA-12921] - Consider adding support for
locally built Ranger
- [IMPALA-12939] - Improve default for
IMPALA_BUILD_THREADS
- [IMPALA-12985] - Use the new constructor when
instantiating RangerAccessRequestImpl
- [IMPALA-13044] - Upgrade bouncycastle to 1.78
- [IMPALA-13046] - Rework Iceberg mixed format
delete test for Hive optimization
- [IMPALA-13051] - Speed up test_query_log test
runs
- [IMPALA-13053] - Update test_max_nesting_depth
test to write Orc with Impala
- [IMPALA-13121] - Move the toolchain to a newer
version of ccache
- [IMPALA-13175] - Upgrade Spring framework to
5.3.37 for bug and CVE fixes
- [IMPALA-13180] - Upgrade postgresql to 42.5.5
- [IMPALA-13188] - Add test that compute stats
does not result in a different tuple cache key
- [IMPALA-13230] - Add a way to dump stack traces
for impala-shell while it is running
- [IMPALA-13240] - Add tools to detect
incompatible changes in catalog and statestore service
- [IMPALA-13243] - Update Dropwizard Metrics to
supported version
- [IMPALA-13253] - Add option to use TCP
keepalives for client connections
- [IMPALA-13264] - bin/coverage_helper.sh should
always use gcov from the toolchain
- [IMPALA-13294] - Add option to use long polling
for get_state/GetOperationStatus
- [IMPALA-13301] - Upgrade aircompressor
- [IMPALA-13305] - Better Thrift/FlatBuffers
compatibility checks based on AST parsing
- [IMPALA-13393] - Cleanup outdated maven config
- [IMPALA-13395] - Adds
USE_APACHE_COMPONENTS=true in all-build-options job
- [IMPALA-13402] - Avoid starting cluster for
skipped tests in test_tuple_cache
- [IMPALA-13406] - Upgrade curl to latest version
(8.10.1)
- [IMPALA-13426] - Log Java debug sleeps in dev
environment
- [IMPALA-13446] - Bump CDP GBN to get new Ranger
functionality
- [IMPALA-13497] - Add profile counters for bytes
written / read from the tuple cache
- [IMPALA-13502] - Constructor cleanup
- [IMPALA-13503] - Support CustomClusterTestSuite
with single cluster for a class
- [IMPALA-13518] - Show target name of COMMIT_TXN
events in logs
- [IMPALA-13551] - Produce impala-shell tarball
using pip install
- [IMPALA-13603] - TestQueryLive.test_query_live
fails with AnalysisException: Could not resolve path: 'sys.impala_query_live'
- [IMPALA-13618] - Move to commons-lang3
- [IMPALA-13639] - test_query_cancel_exception
can fail if prior test query has not completed
Sub-task
- [IMPALA-11491] - Support BINARY nested in
complex types in select list
- [IMPALA-11889] - Document changes introduced by
Hive's ESRI geospatial functions
- [IMPALA-12651] - Add support to BINARY type
Iceberg Metadata table columns
- [IMPALA-12754] - Update Impala document to
cover external jdbc table
- [IMPALA-12786] - Optimize count(*) for JSON
scans
- [IMPALA-12789] - Fix unit-test code
JdbcDataSourceTest.java
- [IMPALA-12867] - Filter files to OPTIMIZE based
on file size
- [IMPALA-12872] - Support basic queries using
Calcite on the frontend
- [IMPALA-12899] - Temporary workaround for
BINARY in complex types
- [IMPALA-12934] - Import parser files from
Calcite into Impala
- [IMPALA-12935] - Allow function parsing for
Impala Calcite planner
- [IMPALA-12940] - Implement filtering conditions
- [IMPALA-12947] - Implement Values and Union
Calcite RelNodes
- [IMPALA-12954] - Implement Sort capability
- [IMPALA-12964] - Implement aggregation
capability
- [IMPALA-12973] - Add support for BINARY in
complex types in Iceberg metadata tables
- [IMPALA-13018] - Fix
test_tpcds_queries.py/TestTpcdsQueryForJdbcTables.test_tpcds-decimal_v2-q80a failure
- [IMPALA-13019] - Add query option to keep DBCP
DataSource objects in cache for longer time
- [IMPALA-13022] - Need infrastructure to handle
implicit casting for functions
- [IMPALA-13079] - Add support for FLOAT/DOUBLE
in Iceberg metadata tables
- [IMPALA-13101] - test_data_source_tables fails
with Data source does not exist
- [IMPALA-13123] - Add a way to run tests with
python 3
- [IMPALA-13124] - Migrate tests that use the
'unittest' package to use normal pytest base class
- [IMPALA-13197] - Implement analytic functions
- [IMPALA-13205] - Use separate merge query when
there are no delete or update cases listed
- [IMPALA-13211] - Add negative test for Parquet
Byte Stream Split encoding
- [IMPALA-13246] - Smallify strings during
broadcast exchange
- [IMPALA-13247] - Support Reading Puffin files
for the current snapshot
- [IMPALA-13256] - SQLDataException in external
JDBC table query request
- [IMPALA-13324] - Rewrite complex merge queries
for IcebergMergeImpl
- [IMPALA-13361] - INSERT *, UPDATE * syntax for
MERGE statement
- [IMPALA-13362] - WHEN NOT MATCHED BY SOURCE
syntax for MERGE statement
- [IMPALA-13368] - Drop dependency on
platform.linux_distribution to support Python 3.8
- [IMPALA-13370] - Read Puffin stats from
metadata.json property if available
- [IMPALA-13425] - Using Calcite planner for
Iceberg tables crashes impalad
- [IMPALA-13429] - Calcite planner: Outer join
query with nonequi conjunct crashes Impala server
- [IMPALA-13430] - Calcite planner: test_exprs
test_expr_child_limit runs slow
- [IMPALA-13441] - Support explain statement in
Calcite Planner
- [IMPALA-13455] - Calcite planner: convert
expressions to normal form for performance
- [IMPALA-13456] - Calcite planner: Fix issues
with quotes
- [IMPALA-13457] - Calcite planner: fix
datetime/interval issues for tpcds queries
- [IMPALA-13459] - Calcite planner: duplicate
table in a query fails
- [IMPALA-13461] - Calcite planner: Need some
translation rules to get tpcds queries to work
- [IMPALA-13468] - Calcite planner: fix
aggregation.test queries
- [IMPALA-13482] - Calcite planner: Bug fixes for
an analytics.test
- [IMPALA-13494] - Calcite planner: group_concat
failing with distinct
- [IMPALA-13495] - Calcite planner: Make
exceptions easier to classify
- [IMPALA-13541] - Calcite planner: Fix
explicit_cast regression in tpcds 32
- [IMPALA-13594] - Read Puffin stats also from
older snapshots
Test
- [IMPALA-13055] - Some Iceberg metadata table
tests doesn't assert
- [IMPALA-13386] - Fix test_metastore_service.py
after HIVE-27984
Documentation
- [IMPALA-11328] - Mistmatch on max_errors
documentation
- [IMPALA-11663] - Outdated documentation for
MT_DOP
- [IMPALA-13036] - Document Iceberg metadata
tables
- [IMPALA-13071] - Update the doc of Impala
components
- [IMPALA-13220] - Document DROP PARTITION for
Iceberg tables
- [IMPALA-13250] - Document
ENABLED_RUNTIME_FILTER_TYPES query option
- [IMPALA-13257] - Add doc for unnest() function
and querying arrays
- [IMPALA-13259] - [DOC] Coordinators'
Subscription to Statestore Topics- impala-membership and impala-request-queue
- [IMPALA-13271] - Ranger Impala Authorization |
Non-recursive policy
- [IMPALA-13276] - Revise the documentation of
query option 'RUNTIME_FILTER_WAIT_TIME_MS'
- [IMPALA-13376] - Slight documentation mistake
for AGG_MEM_CORRELATION_FACTOR
- [IMPALA-13392] - Document File Filtering in
OPTIMIZE Statement
- [IMPALA-13410] - Document reading Puffin files
- [IMPALA-13588] - Update Puffin reading doc
after IMPALA-13370