PHOENIX Changelog

Release 4.16.0 - Unreleased (as of 2021-02-06)

IMPORTANT ISSUES:

JIRASummaryPriorityComponent
PHOENIX-5265[UMBRELLA] Phoenix Test should use object based Plan for result comparison instead of using hard-corded comparisonMajor.
PHOENIX-4412Tephra transaction context visibility level returns null instead of SNAPSHOT_ALLCritical.
PHOENIX-5446Support Protobuf shaded clients (thin + thick)Major.
PHOENIX-4866UDFs get error: org.apache.phoenix.schema.FunctionNotFoundException: ERROR 6001 (42F01): Function undefinedBlocker.

NEW FEATURES:

JIRASummaryPriorityComponent
PHOENIX-6213Extend Cell Tags to Delete object.Major.
PHOENIX-6186Store table metadata last modified timestamp in PTable / System.CatalogMajor.
PHOENIX-5628Phoenix Function to Return HBase Row Key of Column CellMajor.

IMPROVEMENTS:

JIRASummaryPriorityComponent
PHOENIX-6114Create shaded phoenix-pherf and remove lib dir from assemblyMajorcore
PHOENIX-6182IndexTool to verify and repair every index rowMajor.
PHOENIX-6250Fix ViewMetadataIT test flapperMajor.
PHOENIX-6327Consolidate Junit test categoriesMinorcore
PHOENIX-6276Log when hconnection is getting closed in ConnectionQueryServicesImplMajorcore
PHOENIX-5841When data columns get TTLed, we need inline index validation to publish a metric for thisMajor.
PHOENIX-6307Build and release official binary distributions with each HBase profileMajorcore
PHOENIX-6311Using phoenix-level table exists check in ViewUtil.getSystemTableForChildLinksMajor.
PHOENIX-6211Paged scan filtersCritical.
PHOENIX-6275Handle JVM exit gracefully in unit testsMajor.
PHOENIX-6265Fix GlobalIndexOptimizationIT test flapperMajor.
PHOENIX-6255Fix IndexScrutinyIT test flapperMajor.
PHOENIX-6256Fix MaxConcurrentConnectionsIT test flapperMajor.
PHOENIX-6259Fix IndexExtendedIT test flapperMajor.
PHOENIX-6258Fix IndexScrutinyToolIT test flapperMajor.
PHOENIX-6252Fix BackwardCompatibilityIT test flapperMajor.
PHOENIX-6251Fix ConcurrentMutationsExtendedIT.testConcurrentUpsertsWithNoIndexedColumns timout issueMajor.
PHOENIX-6245Update tephra dependency version to 0.16.0Majorcore
PHOENIX-6082No need to do checkAndPut when altering properties for a table or view with column-encoding enabledMajor.
PHOENIX-6242Remove remaining commons-logging referencesMinorcore
PHOENIX-6086Take a snapshot of all SYSTEM tables before attempting to upgrade themCritical.
PHOENIX-6237Relocate javax. classes in phoenix-clientMajorcore
PHOENIX-6231Update Omid to 1.0.2Majorcore
PHOENIX-5895Leverage WALCellFilter in the SystemCatalogWALEntryFilter to replicate system catalog tableMinorcore
PHOENIX-6155Prevent doing direct upserts into SYSTEM.TASK from the clientMajor.
PHOENIX-6207Paged server side grouped aggregate operationsMajor.
PHOENIX-5998Paged server side ungrouped aggregate operationsMajor.
PHOENIX-6212Improve SystemCatalogIT.testSystemTableSplit() to ensure no splitting occurs when splitting is disabledMajor.
PHOENIX-6184Emit ageOfUnverifiedRow metric during read repairsMinorcore
PHOENIX-6209Remove unused estimateParallelLevel()Minorcore
PHOENIX-6208Backport the assembly changes in PHOENIX-6178 to 4.xMajorcore
PHOENIX-6126All createViewAddChildLink requests will go to the same region of SYSTEM.CHILD_LINKMinor.
PHOENIX-6167Adding maxMutationCellSizeBytes config and exceptionTrivial.
PHOENIX-6181IndexRepairRegionScanner to verify and repair every global index rowMajor.
PHOENIX-6129Optimize tableExists() call while retrieving correct MUTEX tableMajor.
PHOENIX-6202New column in index gets added as PK with CASCADE INDEXMajor.
PHOENIX-6172Updating VIEW_INDEX_ID column type and ts in Syscat with a 4.16 upgrade scriptMajor.
PHOENIX-6189DATA_EXCEEDS_MAX_CAPACITY exception error string should contain column name instead of actual valueTrivial.
PHOENIX-6125Make sure SYSTEM.TASK does not splitMajor.
PHOENIX-6151Switch phoenix-client to shade-by-default modeMajorcore
PHOENIX-6185OPERATION_TIMED_OUT#newException method swallows the exception message and root cause exception.Majorcore
PHOENIX-6160Simplifying concurrent mutation handling for global IndexesMajor.
PHOENIX-6173Archive test artifacts in Jenkins multibranch postcommit jobMajorcore
PHOENIX-6128Remove unused getAdmin() call inside CQSI.init()Minor.
PHOENIX-6055Improve error reporting for index validation when there are “Not matching index rows”Major.
PHOENIX-5909Table and index-level metrics for indexing coprocsMajor.
PHOENIX-6112Coupling of two classes only use loggerMinorcore
PHOENIX-5957Index rebuild should remove old index rows with higher timestampMajor.
PHOENIX-5896Implement incremental rebuild along the failed regions in IndexToolMajor.
PHOENIX-6093adding hashcode to phoenix pherf Column classMinor.
PHOENIX-6102Better isolation for CI jobs an ASF JenkinsMajor.
PHOENIX-6034Optimize InListITMajorcore
PHOENIX-6059Adding more pagination testsMinor.
PHOENIX-6063Remove bugus jline and sqlline dependency from phoenix-coreMajorcore
PHOENIX-5928Index rebuilds without replaying data table mutationsMajor.
PHOENIX-6037Change default HBase profile to 1.3 in 4.xMajorcore
PHOENIX-5760Pherf Support Sequential Datatypes for INTEGER type fields and have fixed row distributionMinor.
PHOENIX-5883Add HBase 1.6 compatibility module to 4.x branchMajor.
PHOENIX-5789try to standardize on a JSON libraryMinorcore
PHOENIX-5975Index rebuild/verification page size should be configurable from IndexToolMajor.
PHOENIX-5951IndexTool output logging for past-max-lookback rows should be configurableMajor.
PHOENIX-5897SingleKeyValueTuple.toString() returns unexpected resultMinor.
PHOENIX-5793Support parallel init and fast null return for SortMergeJoinPlan.Minor.
PHOENIX-5956Optimize LeftSemiJoin For SortMergeJoinMajor.
PHOENIX-5875Optional logging for IndexTool verificationMajor.
PHOENIX-5910IndexTool verification-only runs should have counters for unverified rowsMajor.
PHOENIX-5931PhoenixIndexFailurePolicy throws NPE if cause of IOE is nullMinor.
PHOENIX-5256Remove queryserver related scripts/files as the former has its own repoTrivial.
PHOENIX-5899Index writes and verifications should contain information of underlying cause of failureMajor.
PHOENIX-5892Add code coverage steps in build documentationMajor.
PHOENIX-5891Ensure that code coverage does not drop with subsequent commitsMajor.
PHOENIX-5842Code Coverage tool for PhoenixMajor.
PHOENIX-5878IndexTool should not fail jobs when the only errors are due to rows out of MaxLookbackMajor.
PHOENIX-5808Improve shaded artifact naming convetionsMajorcore
PHOENIX-4521Allow Pherf scenario to define per query max allowed query execution duration after which thread is interruptedMajor.
PHOENIX-5748Simplify index update generation code for consistent global indexesMajor.
PHOENIX-5794Create a threshold for non async index creation, that can be modified in configsMajor.
PHOENIX-5814disable trimStackTraceMajorconnectors, core, omid, queryserver, tephra
PHOENIX-5746Update release documentation to include versions informationMajor.
PHOENIX-5734IndexScrutinyTool should not report rows beyond maxLookBack ageMajor.
PHOENIX-5751Remove redundant IndexUtil#isGlobalIndexCheckEnabled() calls for immutable data tablesMajor.
PHOENIX-5641Decouple phoenix-queryserver from phoenix-coreMajor.
PHOENIX-5633Add table name info to scan loggingMajor.
PHOENIX-5720Multiple scans on the same table region cause incorrect IndexTool countersMajor.
PHOENIX-5697Avoid resource leakage with try-with-resourcesMajor.
PHOENIX-5703Add MAVEN_HOME toPATH in jenkins buildMajor.
PHOENIX-5694Add MR job counters for IndexTool inline verificationMajor.
PHOENIX-5634Use ‘phoenix.default.update.cache.frequency’ from connection properties at query timeMinor.
PHOENIX-5645BaseScannerRegionObserver should prevent compaction from purging very recently deleted cellsMajor.
PHOENIX-5674IndexTool to not write already correct index rowsMajor.
PHOENIX-5454Phoenix scripts start foreground java processes as child processesMinor.
PHOENIX-5658IndexTool to verify index rows inlineMajor.
PHOENIX-5630MAX_MUTATION_SIZE_EXCEEDED and MAX_MUTATION_SIZE_BYTES_EXCEEDED SQLExceptions should print existing sizeMinor.
PHOENIX-5646Correct and update the release documentationMajor.
PHOENIX-5614Remove unnecessary instances of ClassNotFoundException thrown stemming from various QueryUtil APIsMinor.

BUG FIXES:

JIRASummaryPriorityComponent
PHOENIX-6360phoenix-core has compile dependency on phoenix-hbase-compatBlockercore
PHOENIX-5874IndexTool does not set TTL on its log tables correctlyMajor.
PHOENIX-6078Remove Internal Phoenix Connections from parent LinkedQueue when closedMajor.
PHOENIX-5872Close Internal Phoenix Connections that were running during cancelMajor.
PHOENIX-6339Older client using aggregate queries shows incorrect results.Blocker.
PHOENIX-6273Add support to handle MR Snapshot restore externallyMajorcore
PHOENIX-6288Minicluster startup problems on JenkinsCritical.
PHOENIX-6330SystemCatalogRegionObserver isn't added when cluster is initialized with isNamespaceMappingEnabled=trueCriticalcore
PHOENIX-6319remove cp python logic from the release scriptMajor.
PHOENIX-3710Cannot use lowername data table name with indextoolMinor.
PHOENIX-6298Use timestamp of PENDING_DISABLE_COUNT to calculate elapse time for PENDING_DISABLE stateMajor.
PHOENIX-6148[SchemaExtractionTool]DDL parsing exception in Phoenix in view nameMajor.
PHOENIX-6295Fix non-static inner classes for better memory managementMajor.
PHOENIX-3499Enable null value for quote character for CSVBulkLoad toolMajor.
PHOENIX-3633null pointer exception when subsquery for not exists returns empty result setMajor.
PHOENIX-6293PHOENIX-6193 breaks projects depending on the phoenix-client artifactBlockercore
PHOENIX-6296Synchronize @Parameters, @BeforeClass and @AfterClass methods take 2Criticalcore
PHOENIX-6286Extend syscat RegionSplitPolicies from the default Policy for the HBase branchMajor.
PHOENIX-6287Fix incorrect log in ParallelIterators.submitWorkMajor.
PHOENIX-6283MutableIndexExtendedIT#testCompactDisabledIndex consistently fails with HBase 2.3Blockercore
PHOENIX-6267View Index PK Fixed Width Field TruncationBlocker.
PHOENIX-6274Flaky test TableSnapshotReadsMapReduceIT.testMapReduceSnapshotsMultiRegionMajor.
PHOENIX-6263Few Table references are leakedMajor.
PHOENIX-6218Rows deleted count for client side deletes is incorrect for immutable tables with indexesMajor.
PHOENIX-6058When maxLookback is not enabled, IndexTool should not do deep verificationBlocker.
PHOENIX-6241ViewIndexId sequences collide with ones created on the pre-4.15 versionBlocker.
PHOENIX-5921Phoenix Index verification logging Exception with huge huge rowMinor.
PHOENIX-5712Got SYSCAT ILLEGAL_DATA exception after created tenant index on viewBlocker.
PHOENIX-6232Correlated subquery should not push to RegionServer as the probe side of the Hash joinMajor.
PHOENIX-6239NullPointerException when index table does not use COLUMN_ENCODED_BYTESMajor.
PHOENIX-5860Throw exception which region is closing or splitting when delete dataMajorcore
PHOENIX-5960Creating a view on a non-existent table throws the wrong exceptionMinor.
PHOENIX-6223could not find or load main class sqline.SqLineMinor.
PHOENIX-5920Skip SYSTEM TABLE checks while creating phoenix connection if client has set the DoNotUpgrade configMajor.
PHOENIX-6233QueryTimeoutIT fails sometimes.Minor.
PHOENIX-6224Support Correlated IN SubqueryMajor.
PHOENIX-6230IT suite hangs on ViewConcurrencyAndFailureITCriticalcore
PHOENIX-6228Admin resources are not closed in some placesMajor.
PHOENIX-6191Creating a view which has its own new columns should also do checkAndPut checks on SYSTEM.MUTEXCritical.
PHOENIX-6221Getting CNF while creating transactional table with OmidBlockeromid
PHOENIX-6123Old clients cannot query a view if the parent has an indexBlocker.
PHOENIX-5955OrphanViewToolIT is flappingMajor.
PHOENIX-5472Typos in the docs descriptionMinor.
PHOENIX-5669Remove hack for PHOENIX-3121Major.
PHOENIX-6203CQS.getTable(byte[] tableName) does not throw TNFE even if table doesn't existMajor.
PHOENIX-5940Pre-4.15 client cannot connect to 4.15+ server after SYSTEM.CATALOG region has splitBlocker.
PHOENIX-6091Calling MetaDataProtocol.getVersion() on a 4.16 timestamp gives version as 4.15.xMinor.
PHOENIX-6032When phoenix.allow.system.catalog.rollback=true, a view still sees data from a column that was droppedBlocker.
PHOENIX-5210NullPointerException when alter options of a table that is appendOnlySchemaMajor.
PHOENIX-6158create table/view should not update VIEW_INDEX_ID_DATA_TYPE columnMajor.
PHOENIX-6179Relax the MaxLookBack age checks during an upgradeCritical.
PHOENIX-6087Phoenix Connection leak in UpgradeUtil.addViewIndexToParentLinks()Major.
PHOENIX-6030When phoenix.allow.system.catalog.rollback=true, a view still sees data for columns that were dropped from its parent viewBlocker.
PHOENIX-6002Fix connection leaks throughout instances where we use QueryUtil.getConnectionOnServerMajor.
PHOENIX-6124Block adding/dropping a column on a parent view for clients <4.15 and for clients that have phoenix.allow.system.catalog.rollback=trueBlocker.
PHOENIX-6192UpgradeUtil.syncUpdateCacheFreqAllIndexes() does not use tenant-specific connection to resolve tenant viewsMajor.
PHOENIX-6197AggregateIT and StoreNullsIT hangsBlockercore
PHOENIX-6142Make DDL operations resilient to orphan parent->child linking rows in SYSTEM.CHILD_LINKBlocker.
PHOENIX-6188Jenkins job history uses too much storageBlockerconnectors, core
PHOENIX-6193PHOENIX-6151 slows down shadingCriticalcore
PHOENIX-6194Build failure due to missing slf4j dependency in phoenix-toolsMajor.
PHOENIX-5839CompatUtil#setStopRow semantics problemMajorcore
PHOENIX-6169IT suite never finishes on 4.x with HBase 1.3 or 1.4Blockercore
PHOENIX-6159Phoenix-pherf writes the result file even disableRuntimeResult flag is trueMajor.
PHOENIX-6153Table Map Reduce job after a Snapshot based job fails with CorruptedSnapshotExceptionMajorcore
PHOENIX-6168PHOENIX-6143 breaks tests on linuxMajorcore
PHOENIX-6122Upgrade jQuery to 3.5.1Majorcore
PHOENIX-6143Get Phoenix Tracing Webapp workMajorcore
PHOENIX-6075DDLs issued via a tenant-specific connection do not write SYSTEM.MUTEX cellsBlocker.
PHOENIX-6136javax.servlet.UnavailableException thrown when using Spark connectorMajorcore, spark-connector
PHOENIX-6072SYSTEM.MUTEX not created with a TTL on a fresh cluster connected to by a 4.15+ clientBlocker.
PHOENIX-6130StatementContext.subqueryResults should be thread safeMajor.
PHOENIX-6069We should check that the parent table key is in the region in the MetaDataEndpointImpl.dropTable codeMajor.
PHOENIX-5171SkipScan incorrectly filters composite primary key which the key range contains all valuesBlocker.
PHOENIX-6115Avoid scanning prior row state for uncovered local indexes on immutable tables.Major.
PHOENIX-6106Speed up ConcurrentMutationsExtendedITMajor.
PHOENIX-5986DropTableWithViewsIT.testDropTableWithChildViews is flapping againMajor.
PHOENIX-6094Update jacoco plugin version to 0.8.5.Major.
PHOENIX-6090Local indexes get out of sync after changes for global consistent indexesBlocker.
PHOENIX-6073IndexTool IndexDisableLoggingType can't be set to NONEMinor.
PHOENIX-6077PHOENIX-5946 breaks mvn verifyBlockercore
PHOENIX-5958Diverged view created via an older client still sees dropped column dataBlocker.
PHOENIX-5969Read repair reduces the number of rows returned for LIMIT queriesMajor.
PHOENIX-6022RVC Offset does not handle trailing nulls properlyMajor.
PHOENIX-6045Delete that should qualify for index path does not use index when multiple indexes are available.Major.
PHOENIX-6023Wrong result when issuing query for an immutable table with multiple column familiesMajor.
PHOENIX-6013RVC Offset does not handle coerced literal nulls properly.Major.
PHOENIX-6011ServerCacheClient throw NullPointerExceptionMajor.
PHOENIX-6026Fix BackwardCompatibilityIT so it can run locallyMajor.
PHOENIX-5976Cannot drop a column when the index view is involvedBlocker.
PHOENIX-6017Hadoop QA Precommit build keeps failing with release audit warning for phoenix-server/dependency-reduced-pom.xmlMajor.
PHOENIX-5924RVC Offset does not handle variable length fields exclusive scan boundary correctlyMajor.
PHOENIX-5981Wrong multiple counting of resultSetTimeMs and wallclockTimeMs in OverallQueryMetricsMajor.
PHOENIX-6000Client side DELETEs should use local indexes for filteringMajor.
PHOENIX-5984Query timeout counter is not updated in all timeouts casesMajor.
PHOENIX-5935Select with non primary keys and PHOENIX_ROW_TIMESTAMP() in where clause failsMajor.
PHOENIX-5967phoenix-client transitively pulling in phoenix-coreCritical.
PHOENIX-5996IndexRebuildRegionScanner.prepareIndexMutationsForRebuild may incorrectly delete index row when a delete and put mutation with the same timestampMajor.
PHOENIX-6001Incremental rebuild/verification can result in missing rows and false positivesCritical.
PHOENIX-5997Phoenix Explain Plan for Deletes does not clearly differentiate between server side and client side paths.Minor.
PHOENIX-5995Index Rebuild page size is not honored in case of point deletesMajor.
PHOENIX-5779SplitSystemCatalogIT tests fail with Multiple Regions errorMajor.
PHOENIX-5937Order by on nullable column sometimes filters rowsMajorcore
PHOENIX-5898Phoenix function CURRENT_TIME() returns wrong result when view indexes are used.Major.
PHOENIX-5970ViewUtil.dropChildViews may cause HConnection leak which may cause ITtests hangeMajor.
PHOENIX-5905Reset user to hbase by changing rpc context before getting user permissions on access controller serviceMajor.
PHOENIX-5902Document or fix new compat jar behavior.Blocker.
PHOENIX-5942ParameterizedIndexUpgradeIT is too slowMinor.
PHOENIX-5932View Index rebuild results in surplus rows from other view indexesMajor.
PHOENIX-5922IndexUpgradeTool should always re-enable tables on failureMajor.
PHOENIX-5656Make Phoenix scripts work with Python 3Critical.
PHOENIX-5929IndexToolForNonTxGlobalIndexIT.testDisableOutputLogging is flappingMajor.
PHOENIX-5884Join query return empty result when filters for both the tables are presentMajor.
PHOENIX-5863Upsert into view against a table with index throws exception when 4.14.3 client connects to 4.16 serverBlocker.
PHOENIX-4753Remove the need for users to have Write access to the Phoenix SYSTEM STATS TABLE to drop tablesMajor.
PHOENIX-5580Wrong values seen when updating a view for a table that has an indexMajor.
PHOENIX-5864RuleGeneratorTest unit test seem to be failingMajor.
PHOENIX-5743Concurrent read repairs on the same index row should be idempotentCritical.
PHOENIX-5807Index rows without empty column should be treated as unverifiedMajor.
PHOENIX-5799Inline Index Verification Output APIMajor.
PHOENIX-5810PhoenixMRJobSubmitter is not working on a cluster with a single yarn RMMajor.
PHOENIX-5816IndexToolTimeRangeIT hangs foreverBlockercore
PHOENIX-5802Connection leaks in UPSERT SELECT/DELETE paths due to MutatingParallelIteratorFactory iterator not being closedMajor.
PHOENIX-5801Connection leak when creating a view with a where conditionMajor.
PHOENIX-5776Phoenix pherf unit tests failingMajor.
PHOENIX-5698Phoenix Query with RVC IN list expression generates wrong scan with non-pk ordered pksMajor.
PHOENIX-5797RVC Offset does not work with tenant views on global indexesMinor.
PHOENIX-5790Add Apache license header to compatible_client_versions.jsonMinor.
PHOENIX-5718GetTable builds a table excluding the given clientTimeStampMajor.
PHOENIX-5785Remove TTL check in QueryCompiler when doing an SCN / Lookback queryMajor.
PHOENIX-5673The mutation state is silently getting cleared on the execution of any DDLCritical.
PHOENIX-5065Inconsistent treatment of NULL and empty stringMajor.
PHOENIX-5753Fix erroneous query result when RVC is clipped with desc columnMajor.
PHOENIX-5768Supporting partial overwrites for immutable tables with indexesCritical.
PHOENIX-5731Loading bulkload hfiles should not be blocked if the upsert select happening for differet table.Major.
PHOENIX-5766PhoenixMetricsIT failure in 4.x for HBase 1.3Major.
PHOENIX-5636Improve the error message when client connects to server with higher major versionMinor.
PHOENIX-5745Fix QA false negativesMajor.
PHOENIX-5737Hadoop QA run says no tests even though there are added IT testsMinor.
PHOENIX-5537Phoenix-4701 made hard coupling between phoenix.log.level and getting request metrics.Minor.
PHOENIX-5529Creating a grand-child view on a table with an index failsMajor.
PHOENIX-5695Phoenix website build.sh should return when child script has errorsMajor.
PHOENIX-5724Use exec permission in Phoenix ACLs only when execute check enabledMajor.
PHOENIX-5691create index is failing when phoenix acls enabled and ranger is enabledMajor.
PHOENIX-5440multiple warnings when building phoenixMinor.
PHOENIX-5704Covered column updates are not generated for previously deleted data table rowCritical.
PHOENIX-5708GlobalIndexChecker returns unverified index row cellsMajor.
PHOENIX-5706IndexTool verification reports failure when data row has no covered column valuesMajor.
PHOENIX-5512IndexTool returns error after rebuilding a DISABLED indexMajor.
PHOENIX-5677Replace System.currentTimeMillis with EnvironmentEdgeManager in non-test codeMajor.
PHOENIX-5692SCN verification breaks with non-default column familiesMajor.
PHOENIX-5676Inline-verification from IndexTool does not handle TTL/row-expiryMajor.
PHOENIX-5666IndexRegionObserver incorrectly updates PostIndexUpdateFailure metricMajor.
PHOENIX-5654String values (ALWAYS and NEVER) don't work for connection level config phoenix.default.update.cache.frequencyMajor.
PHOENIX-5650IndexUpgradeTool does not rebuild view indexesMajor.
PHOENIX-5655ServerCache using table map is not correctly removedMajor.
PHOENIX-5096Local index region pruning is not working as expected.Major.
PHOENIX-5637Queries with SCN return expired rowsMajor.
PHOENIX-5640Pending disable count should not be increased for rebuild write failuresMajor.
PHOENIX-4824Update BRANCH_NAMES in dev/test-patch.propertiesMajor.

TESTS:

JIRASummaryPriorityComponent
PHOENIX-5719testIndexRebuildTask test is failing on pre-commit and master buildMajor.
PHOENIX-5296Ensure store file reader refcount is zero at end of relevant unit testsMajor.
PHOENIX-6300Fix PartialIndexRebuilderIT.testIndexWriteFailureDisablingIndex test flapperMajor.
PHOENIX-6302Fix ConcurrentUpsertsWithoutIndexedColsIT flapperMajor.
PHOENIX-6297Fix IndexMetadataIT.testAsyncRebuildAll test flapperMajor.
PHOENIX-6301Fix BackwardCompatibilityIT.testSystemTaskCreationWithIndexAsyncRebuild test flapperMajor.
PHOENIX-6289Flaky test UpsertSelectIT.testUpsertSelectWithNoIndexMajor.
PHOENIX-6284Flaky test UpgradeIT.testConcurrentUpgradeThrowsUpgradeInProgressExceptionMajor.
PHOENIX-6183Page size tests are not propagating test override values to serverMajor.
PHOENIX-5747Add upsert tests for immutable table indexesMinor.
PHOENIX-6246Flaky test PointInTimeQueryITMajor.
PHOENIX-5973IndexToolForNonTxGlobalIndexIT - Stabilize and speed upMajor.
PHOENIX-5607Client-server backward compatibility testsBlocker.
PHOENIX-5671Add tests for ViewUtilMinor.
PHOENIX-5616Speed up ParameterizedIndexUpgradeToolITMinor.
PHOENIX-5617Allow using the server side JDBC client in Phoenix Sandbox.Major.

SUB-TASKS:

JIRASummaryPriorityComponent
PHOENIX-6342RoundRobinResultIterator doesn't close itself when result size = fetchsize-1Blockercore
PHOENIX-6329Eliminate or serialize minicluster restart operations in Integration testsMajorcore
PHOENIX-6220CREATE INDEX shouldn't ignore IMMUTABLE_STORAGE_SCHEME and COLUMN_ENDCODED_BYTESMajor.
PHOENIX-6120Change IndexMaintainer for SINGLE_CELL_ARRAY_WITH_OFFSETS indexes. Currently it assumes data and index table having the same storage and encoding format.Major.
PHOENIX-6219GlobalIndexChecker should work for index:SINGLE_CELL_ARRAY_WITH_OFFSETS and data:ONE_CELL_PER_COLUMNMajor.
PHOENIX-6292Extend explain plan object based comparison to majority remaining testsMajor.
PHOENIX-5435Annotate HBase WALs with Phoenix MetadataMajor.
PHOENIX-6269Extend explain plan object based comparison to some more testsMajor.
PHOENIX-5592MapReduce job to asynchronously delete rows where the VIEW_TTL has expired.Major.
PHOENIX-5728ExplainPlan with plan as attributes object, use it for BaseStatsCollectorITMajor.
PHOENIX-5601PHOENIX-5601 Add a new coprocessor for PHOENIX_TTL - PhoenixTTLRegionObserverMajor.
PHOENIX-6171Child views should not be allowed to override the parent view PHOENIX_TTL attribute.Major.
PHOENIX-6170PHOENIX_TTL spec should be in seconds instead of millisecondsMajor.
PHOENIX-6101Avoid duplicate work between local and global indexesMajor.
PHOENIX-6097Improve LOCAL index consistency testsMinor.
PHOENIX-5933Rename VIEW_TTL property to be PHOENIX_TTLMajor.
PHOENIX-5317Upserting rows into child views with pk fails when the base view has an index on it.Major.
PHOENIX-5678Cleanup anonymous inner classes used for BaseMutationPlanMajor.
PHOENIX-5501Add support for VIEW_TTL table property during DDLMajor.

OTHER:

JIRASummaryPriorityComponent
PHOENIX-6147Copy Github PR discussions to JIRAMajor.
PHOENIX-6107Discuss speed up of BaseQueryITMajor.
PHOENIX-6065Add OWASP dependency check, and update the flagged direct dependenciesMajorconnectors, core, queryserver
PHOENIX-6309Use maven enforcer to ban importsMajor.
PHOENIX-6282Generate PB files inline with build and remove checked in filesMajor.
PHOENIX-6261Reorganise project structure to make mvn versions:set workMajorconnectors, core
PHOENIX-6137Update Omid to 1.0.2 and Tephra to 0.16 in 4.xMajorcore
PHOENIX-6196Update phoenix.mutate.maxSizeBytes to accept long valuesMajor.
PHOENIX-6146Run precommit checks on github PRsMajorcore
PHOENIX-5032add Apache Yetus to PhoenixMajor.
PHOENIX-6056Migrate from builds.apache.org by August 15Critical.
PHOENIX-5962Stabilize buildsMajor.
PHOENIX-5818Add documentation for query timeoutDuration attribute in Pherf scenariosMinor.
PHOENIX-5825Remove PhoenixCanaryTool and CanaryTestResult from phoenix repoMajorcore, queryserver
PHOENIX-5822Move Python driver to queryserver repoMajorcore, queryserver
PHOENIX-5762Update jacksonMajor.
PHOENIX-5767Add 4.x branch to the precommit script configurationBlocker.
PHOENIX-5721Unify 4.x branchesMajor.