You are viewing a plain text version of this content. The canonical link for it is here.
Posted to oak-commits@jackrabbit.apache.org by da...@apache.org on 2019/06/04 15:41:30 UTC

svn commit: r1860625 - /jackrabbit/oak/trunk/RELEASE-NOTES.txt

Author: davide
Date: Tue Jun  4 15:41:30 2019
New Revision: 1860625

URL: http://svn.apache.org/viewvc?rev=1860625&view=rev
Log:
Apache Jackrabbit Oak 1.14.0

release notes


Modified:
    jackrabbit/oak/trunk/RELEASE-NOTES.txt

Modified: jackrabbit/oak/trunk/RELEASE-NOTES.txt
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/RELEASE-NOTES.txt?rev=1860625&r1=1860624&r2=1860625&view=diff
==============================================================================
--- jackrabbit/oak/trunk/RELEASE-NOTES.txt (original)
+++ jackrabbit/oak/trunk/RELEASE-NOTES.txt Tue Jun  4 15:41:30 2019
@@ -1,4 +1,4 @@
-Release Notes -- Apache Jackrabbit Oak -- Version 1.12.0
+Release Notes -- Apache Jackrabbit Oak -- Version 1.14.0
 
 Introduction
 ------------
@@ -7,7 +7,7 @@ Jackrabbit Oak is a scalable, high-perfo
 repository designed for use as the foundation of modern world-class
 web sites and other demanding content applications.
 
-Apache Jackrabbit Oak 1.12.0 is an incremental feature release based
+Apache Jackrabbit Oak 1.14.0 is an incremental feature release based
 on and compatible with earlier stable Jackrabbit Oak 1.x
 releases. This release is considered stable and targeted for
 production use.
@@ -15,297 +15,205 @@ production use.
 The Oak effort is a part of the Apache Jackrabbit project.
 Apache Jackrabbit is a project of the Apache Software Foundation.
 
-Changes in Oak 1.12.0
+Changes in Oak 1.14.0
 ---------------------
 
 Technical task
 
-    [OAK-7960] - RDB: add to Oak documentation
-    [OAK-7970] - RDB*Store: add profile for DB2 11.1 JDBC driver
-    [OAK-7971] - RDB*Store: update DB2 JDBC reference to 4.19.77
-    [OAK-7978] - guava-latest profile defunct
-    [OAK-7979] - DeclaredMembershipPredicate does not compile with
-    Guava 20
-    [OAK-8002] - RDBDocumentStore: add RDB-specific
-    MissingLastRevSeeker
-    [OAK-8004] - oak-run: support "recovery" command for
-    RDBDocumentStore
-    [OAK-8016] - RDBDocumentStore: minor improvements to GZIP
-    compression of BLOB contents
-    [OAK-8043] - RDB: expose DDL generation functionality in oak-run
-    [OAK-8058] - RDB*Store: update Tomcat JDBC pool dependency to
-    8.5.38
-    [OAK-8069] - Log warning for too many transient modifications of
-    direct child nodes
-    [OAK-8071] - Logging to detect commits carrying over from previous
-    GC generation can block other threads from committing
-    [OAK-8074] - RDB*Store: update mysql-connector-java dependency to
-    8.0.15
-    [OAK-8080] - RDB*Store: move DB-specific config hints from Javadoc
-    into oak-doc
-    [OAK-8083] - RDB*Store: add SQLServer specific documentation
-    [OAK-8087] - RDB*Store: update mssql-jdbc driver reference to
-    7.2.1.jre8
-    [OAK-8147] - RDBBlobStore: add perf logging for JDBC read
+    [OAK-8201] - RDBDocumentStore in ReadOnly mode should never modify
+    persistence
+    [OAK-8251] - RDBBlobStore instantiated from ReadOnly
+    DocumentNodeStore should never modify persistence
+    [OAK-8257] - RDBDocumentStore: improve trace logging of batch
     operations
-    [OAK-8200] - MongoDocumentStore in ReadOnly mode should never
-    modify persistence
+    [OAK-8273] - RDBDocumentStore: createOrUpdate with less than 3 ops
+    suboptimal
+    [OAK-8281] - Improve coverage for
+    org.apache.jackrabbit.oak.security.authorization.composite
+    [OAK-8307] - RDBDocumentStore: add DEBUG logging when fetching
+    index metadata fails
+    [OAK-8311] - RDBDocumentStore: allow to turn off RDB-specific
+    MissingLastRevSeeker
+    [OAK-8332] - update Tomcat JDBC dependency to 8.5.41
+    [OAK-8337] - RDBDocumentStore: refactor index dumping code
+    [OAK-8338] - RDBDocumentStoreJDBC: fix theoretically possible NPE
+    in perflogging code
+    [OAK-8340] - Document use of oak-run for RDB
+    [OAK-8346] - RDBDocumentStore*: fix several potential but
+    improbable NPEs
+    [OAK-8349] - RDBDocumentStore*: "reset clusterId tool" in oak-run
+    [OAK-8368] - RDBDocumentNodeStoreBuilder: refactor
+    setRDBConnection for consistency
+    [OAK-8371] - Stop using deprecated DocumentMK.Builder in RDB tests
+    [OAK-8375] - DocumentNodeStoreBuilder should not instantiate
+    BlobStore instance before "build()"
+    [OAK-8378] - rdb/oak-run: update usage and documentation for
+    garbage command
 
 Bug
 
-    [OAK-6749] - Segment-Tar standby sync fails with "in-memory" blobs
-    present in the source repo
-    [OAK-7027] - Test failure:
-    ExternalPrivateStoreIT.testSyncFailingDueToTooShortTimeout
-    [OAK-7719] - CheckCommand should consistently use an alternative
-    journal if specified
-    [OAK-7938] - Test failure: MBeanIT.testClientAndServerEmptyConfig
-    [OAK-7951] - Datastore GC stats not updated with failure when "Not
-    all repositories have marked references available"
-    [OAK-7953] - Test failure:
-    JdbcToSegmentWithMetadataTest.validateMigration()
-    [OAK-7966] - Avoid adding excluded principal to cug policy
-    [OAK-7975] - Facet extraction fails while requesting multiple
-    facets and one of the requested facets doesn't have indexed values
-    [OAK-7982] - ACL.addEntry: check for mandatory restrictions only
-    respects single value restrictions
-    [OAK-7986] - Incorrect MongoDB URI in
-    ReplicaSetDefaultWriteConcernIT
-    [OAK-7987] -
-    LdapIdentityProviderImpl#getIdentity(ExternalIdentityRef) won't
-    work with useUidForExtId enabled
-    [OAK-7993] -
-    CompositeAuthorizationConfiguration.getRestrictionProvider()
-    should filter duplications
-    [OAK-7997] - Adding restrictions to ACLs yields empty results for
-    queries in Jackrabbit Oak
-    [OAK-8001] - Lucene index can be empty (no :data node) in
-    composite node store setup
-    [OAK-8003] - MongoDocumentStore does not log server details
-    [OAK-8006] - SegmentBlob#readLongBlobId might cause
-    SegmentNotFoundException on standby
-    [OAK-8007] - RDBDocumentStore: potential off-heap memory leakage
-    due to unclosed GzipInputStream
-    [OAK-8012] - Unmerged branch changes visible after restart
-    [OAK-8013] - [Direct Binary Access] DataRecordDownloadOptions
-    creates invalid Content-Disposition headers - Workaround
-    [OAK-8017] - Test failure: LastRevRecoveryRandomizedIT
-    [OAK-8023] - AccessControlManagerImpl can not handle repository
-    level when editing policies by principal
-    [OAK-8024] - oak-http generates invalid html
-    [OAK-8026] - Warn message when branch is created
-    [OAK-8033] - Node states sometimes refer to more than a single
-    generation of segments after a full compaction
-    [OAK-8035] - Debug logging when two or more indices have same or
-    very close cost amounts doesn't work in case both indices belong
-    to the same type of Query Index
-    [OAK-8044] - AccessControlManagerImpl.getEffectivePolicies returns
-    empty ACLs
-    [OAK-8045] - Allow for ranking being specified with
-    UserAuthenticatonFactory implementations
-    [OAK-8049] - AbstractSecurityTest: fix PartialValueFactory field
-    and it's usages.
-    [OAK-8051] - PersistentCache: error during open can lead to
-    incomplete initialization and subsequent NPEs
-    [OAK-8052] - PersistentCache: failure during construction may lead
-    to resource leak
-    [OAK-8054] - RepMembersConflictHandler creates property with wrong
-    type
-    [OAK-8060] - Incorrect read preference when parentId refers to
-    NodeDocument.NULL
-    [OAK-8063] - The cold standby client doesn't correctly handle
-    backward references
-    [OAK-8065] - AbstractSecurityTest.getAccessControlManager: should
-    use getNamePathMapper() instead of DEFAULT
-    [OAK-8070] - The date-based copy-versions directive doesn't work
-    correctly with include-paths
-    [OAK-8089] - DocumentNodeStore dispose can fail when duration of
-    final background ops exceeds lease time
-    [OAK-8091] - Build failure: artifact does not exist on remote
-    repository
-    [OAK-8092] - The cold standby server cannot handle blob requests
-    for long blob IDs
-    [OAK-8093] - AccessControlManagerImpl: respect local namespaces
-    when writing back ACEs
-    [OAK-8095] - VersionStorageEditor can prevent upgrade of version
-    store
-    [OAK-8101] - AccessControlValidator prevents alternative
-    authorization models to use restrictions
-    [OAK-8106] - High memory usage when large branch is reset
-    [OAK-8108] - Branch reset does not remove all branch commit
-    entries
-    [OAK-8117] - NPE when adding ACE with restrictions and remapped
-    namespaces
-    [OAK-8122] - MongoDocumentStore init may fail with authentication
-    [OAK-8124] - Sidegrade operation doesn't run security-related
-    commit hooks
-    [OAK-8126] - Load Lucene index files before writing to the index:
-    close directory
-    [OAK-8127] - TreeLocation: imcomplete Nullable/NotNull annotations
-    [OAK-8130] - Index corruption stats should get updated also when
-    no failing index remains
-    [OAK-8133] - Word SHA1 no longer allowed
-    [OAK-8161] - Build failure: Too many files with unapproved license
-    [OAK-8176] - Inaccurate calculation of RevisionVector memory
-    [OAK-8195] - AutoSaveEnabledManager.createSystemUser calls
-    createUser on delegatee
+    [OAK-8139] - DocumentDiscoveryLiteService hasBacklog silencing
+    must support maven version format
+    [OAK-8149] - java 12 javadoc fails with "unknown tag" for OSGi
+    version annotations in package-info
+    [OAK-8166] - Index definition with orderable property definitions
+    with and without functions breaks index
+    [OAK-8187] - Respect service ranking with AuthorizableNodeName,
+    AuthorizableActionProvider and RestrictionProvider
+    [OAK-8199] - DocumentStore in ReadOnly mode should never modify
+    persistence
+    [OAK-8207] - Read-only DocumentNodeStore tries to create root
+    document
+    [OAK-8212] - ImporterImpl.importProperties prone to NPE
+    [OAK-8214] - RDBDocumentStore may not inherit ReadOnly flag from
+    DocumentNodeStore
+    [OAK-8218] - ReadOnlyNodeTypeManager.isNodeType prone to NPE
+    [OAK-8219] - Incorrect parent POM version in oak-doc and
+    oak-doc-railroad-macro
+    [OAK-8220] - CommitRootUpdateTest creates malformed value
+    [OAK-8223] - javadoc-plugin fails with java11
+    [OAK-8229] - LoginModuleImpl.commit will end in NPE if credentials
+    are null
+    [OAK-8231] - Unreachable code in LoginModuleImpl.getLoginId
+    [OAK-8232] - Node#setPrimaryType(String) does not create child
+    nodes defined as autoCreated
+    [OAK-8246] - Test failure:
+    NodeSetPrimaryTypeTest.testSetPrimaryType()
+    [OAK-8258] - Active deletion can delete blobs despite indexing
+    cycle deleting them failed
+    [OAK-8261] - Indexing lane failing but the index is not marked
+    corrupt
+    [OAK-8266] - Redundant check for existing tree in
+    CompiledPermissionImpl.buildVersionDelegatee
+    [OAK-8272] - Orphaned branch commit entries after restart
+    [OAK-8276] - OR-CompositeTreePermission.grantsPermission should
+    loop over aggregates of supported permissions
+    [OAK-8278] - RDBDataSourceFactory.CloseableDataSource doesn't
+    implement java.sql.Wrapper correctly
+    [OAK-8290] - Update org.apache.felix.framework for jdk13
+    [OAK-8293] - PrincipalProviderImpl.findPrincipals my return null
+    values in result iterator
+    [OAK-8300] - Revision GC may remove previous document without
+    removing reference
+    [OAK-8306] - Empty PrincipalProvider cache breaks membership
+    collection
+    [OAK-8309] - SLOW_QUERY_COUNT don't get updated for each slow
+    query.
+    [OAK-8314] - BlobIds created with direct uploads lack length
+    suffix
+    [OAK-8324] - Missing NotNull annotation with
+    AuthenticationConfiguration and LoginModuleStatsCollector
+    [OAK-8369] - Misplace checkNotNull in CacheValidator
+    [OAK-8372] - DeclaredMembershipPredicate contains redundant lookup
+    of groupTree
 
 New Feature
 
-    [OAK-8062] - PrincipalProvider: optional lookup of
-    ItemBasedPrincipal by path
+    [OAK-8146] - oak-run support for inspecting clusterNodeInfo
+    [OAK-8243] - Expose the number of SNFEs as metric
+    [OAK-8294] - Make it possible to mark a (customer) query as bad
+    and skip it
+    [OAK-8358] - oak-run check should have an option for specifying
+    memory mapping
 
 Improvement
 
-    [OAK-7731] - Order by jcr:score descending is not always ignored
-    [OAK-7924] - Reduce Lucene index size footprint with compressing
-    Codec
-    [OAK-7944] - Minor improvements to oak security code base
-    [OAK-7947] - Lazy loading of Lucene index files startup
-    [OAK-7968] - Active deletion of Lucene binaries: configuration
-    option to disable
-    [OAK-7974] - Detailed merge metrics
-    [OAK-7976] - Non-blocking commit rollback
-    [OAK-7977] - Add multi-threaded segment transfer to oak-run
-    segment-copy
-    [OAK-7984] - Batch update documents in commit rollback
-    [OAK-7988] - The node counter jmx bean should show 0 if a node
-    exists
-    [OAK-7991] - Composite node store: tests with queries
-    [OAK-7994] - Principal Management APIs don't allow for search
-    pagination
-    [OAK-8009] - Remove unused code in NodeDocument
-    [OAK-8018] - Move LazyValue from oak-core to oak-commons
-    [OAK-8019] - Replace deprecated NodeUtil in AbstractOakCoreTest
-    [OAK-8020] - Create ImmutableACL from another
-    AbstractAccessControlList
-    [OAK-8021] - PrivilegeBitsProvider.getBits(Privilege[],NameMapper)
-    should use getOakNameOrNull
-    [OAK-8025] - Improve branch state comparison
-    [OAK-8027] - Extract public utility for handling jcr:all privilege
-    bits
-    [OAK-8028] - Avoid unnecessary query in
-    UnsavedModifications.persist()
-    [OAK-8029] - Additional merge metrics
-    [OAK-8036] - Improve test in oak-security-spi
-    [OAK-8041] - IndexDefinitionBuilder should support facets and
-    boost for property definitions
-    [OAK-8042] - IndexDefinitionBuilder should support deprecated
-    properties on index definition
-    [OAK-8046] - Result items are not always correctly counted against
-    the configured read limit if a query uses a lucene index
-    [OAK-8053] - Add intermediate report to ExternalLoginTest
-    [OAK-8055] - Add conflict handler for rep:lastSynced property on
-    external groups
-    [OAK-8066] - Nodes with many direct children can lead to OOME when
-    saving
-    [OAK-8078] - UserPrincipalProvider support for range search
-    [OAK-8084] - LogCustomizer should allow instantiation with Java
-    class (in addition to class name)
-    [OAK-8088] - Add refresh head revision time to background update
-    stats
-    [OAK-8094] - JMX monitoring to detect commits carrying over from
-    previous GC generation can block other threads from committing
-    [OAK-8096] - CompositeAccessControlManager: misleading local field
-    name
-    [OAK-8097] - Load Lucene index files before writing to the index
-    [OAK-8102] - LoginModule error metrics
-    [OAK-8111] - Create read-only DocumentNodeStore for oak-run
-    recovery dry run
-    [OAK-8113] - Add ability to push metrics to prometheus pushgateway
-    from oak-run
-    [OAK-8114] - IndexDefinitionBuilder should be smarter when to
-    reindex while updating a definition
-    [OAK-8121] - RDBExport should handle db2 dump where del files
-    refers to lob files without offset and length params
-    [OAK-8125] - PrincipalProviderImpl support for range search
-    [OAK-8131] - Principal Management APIs full text search support
-    [OAK-8135] - HTTP service may not select correct media type if
-    multiple are specified in Accept header field
-    [OAK-8137] - Oak run tooling to run a RepositoryInitializer on top
-    a list index definitions
-    [OAK-8138] - In cases where search hit count is less than sample
-    size defined for statistical mode for facets, secure mode should
-    be used so that the counts are accurate for non-admin users.
-    [OAK-8140] - UserPrincipalProvider support for full text search
-    [OAK-8142] - CompositePrincipalProvider support for full text
-    search
-    [OAK-8143] - Configurable persistent cache for Oak-Mongo fixture
-    [OAK-8159] - GroupPrincipalWrapper.getName is redundant
-    [OAK-8160] - Missing notnull/nullable annotations with
-    GroupPrincipals
-    [OAK-8164] - CompositePrincipalProvider.findPrincipals lacks
-    NotNull and Overrides annotation
-    [OAK-8168] - Improve readability of AccessControlAction
-    [OAK-8169] - Missing nullability annotations with
-    UserPrincipalProvider and PrincipalProviderImpl
-    [OAK-8171] - Remove DocumentNodeState.getId()
-    [OAK-8175] - ExternalGroupPrincipalProvider support for full text
-    search
-    [OAK-8177] - Add logging around getReferenceCheckpoint method
-    [OAK-8182] - Improvements to PasswordUtil
-    [OAK-8205] - Add benchmark for Node.isNodeType()
+    [OAK-7065] - Remove orphan file from local directory in case
+    indexing fails
+    [OAK-7691] - Remove deprecated ValueFactoryImpl methods
+    [OAK-8141] - Replace String path with custom data type
+    [OAK-8185] - Improve CompositeNodeStore fixture
+    [OAK-8209] - Improve Node.isNodeType(String) performance
+    [OAK-8215] - Use CacheLIRS as default
+    [OAK-8216] - Consistently add nullability annotations with
+    spi.nodetype package and implementation
+    [OAK-8217] - Remove unused field
+    DocumentNodeStoreBuilder#FAST_DIFF
+    [OAK-8228] - Optimize PathUtils.dropIndexFromName(String)
+    [OAK-8234] - Reduce object allocation in PermissionProviderImpl
+    for admin sessions
+    [OAK-8241] - Add benchmark for transient Node.setProperty()
+    [OAK-8247] - Add non-admin mode for Node.isNodeType() benchmark
+    [OAK-8256] - PrincipalManagerImplTest uses Guava beta methods
+    [OAK-8263] - Simplify PermissionEntry.compareTo
+    [OAK-8265] - Add nullable/notnull annotations to
+    org.apache.jackrabbit.oak.security.authorization.permission.*
+    [OAK-8269] - Improve readability of CompositePermissionProvider
+    and CompositeTreePermission
+    [OAK-8270] - Add variant of PermissionUtil.getReadOnlyTree that
+    never returns null
+    [OAK-8284] - Improvements to EntryPredicate
+    [OAK-8301] - Ensure travis-ci uses trusty image
+    [OAK-8304] - VersionablePathHook: Diff.setVersionablePath never
+    results in CommitFailedException
+    [OAK-8305] - Don't log a warning for queries that use
+    "option(traversal fail)"
+    [OAK-8308] - Unused Object methods in
+    PermissionStoreEditor.AcEntry
+    [OAK-8310] - Potentially misleading conflict exception message
+    [OAK-8315] - Missing nullability annotations in package
+    o.a.j.oak.security.authentication.token and
+    o.a.j.oak.spi.security.authentication.token
+    [OAK-8316] - Drop userId field in TokenLoginModule
+    [OAK-8320] - Improve tests for
+    o.a.j.oak.security.authentication.token package
+    [OAK-8323] - Refactor redundant checks for null in TokenValidator
+    [OAK-8354] - Fix/Add nullability annotations with
+    o.a.j.oak.security.user package
+    [OAK-8355] - AuthorizableImpl.isEveryone should not throw
+    RepositoryException
+    [OAK-8360] - UserAuthentication.authenticate: improve readability
+    [OAK-8361] - Improve tests for o.a.j.oak.security.user package
+    [OAK-8362] - UserImporter: redundant check for null principals
+    [OAK-8363] - Remove obsolete comment
+    [OAK-8365] - UserManagerImpl: unreacheable code when retrieving
+    user/group from ID and tree
+    [OAK-8370] - Simplify o.a.j.oak.security.user.Utils.getOrAddTree
+    [OAK-8373] - UserPrincipalProvider: redundant test for null in
+    ResultRowToPrincipal, EveryonePredicate
+    [OAK-8379] - Improve tests for o.a.j.oak.security.authorization
 
 Test
 
-    [OAK-8172] - Basic test for LoggingDocumentStoreWrapper
-
-Wish
-
-    [OAK-8151] - Let ACE.getPrincipal return principals obtained from
-    PrincipalManager
-    [OAK-8173] - Add branch coverage to Jacoco check
+    [OAK-8353] - Additional test for OAK-8012
 
 Task
 
-    [OAK-7904] - Exporting query duration per index metrics with Sling
-    Metrics / DropWizard
-    [OAK-7961] - LSH should truncate to first decimal place
-    [OAK-7962] - FV reranking should be enabled by default
-    [OAK-7969] - Update tika dependency to 1.20
-    [OAK-8011] - Benchmark on QUERY_DURATION metrics implemented in
-    OAK-7904
-    [OAK-8022] - Update Oak trunk to Jackrabbit 2.19.0
-    [OAK-8030] - oak-jcr NodeTypeTest improvements
-    [OAK-8031] - Update Oak trunk to Jackrabbit 2.19.1
-    [OAK-8037] - add test case for making a node type referenceable
-    [OAK-8050] - Make it possible to use CompressingCodec via system
-    property
-    [OAK-8059] - Update Jackson dependency to 2.9.8
-    [OAK-8068] - Update slf4j dependency to 1.7.26
-    [OAK-8072] - Aggregate jcr:content result nodes as their parent
-    [OAK-8085] - Upgrade spotbugs to 3.1.11
-    [OAK-8090] - Update baseline comparisonVersion to 1.10.1
-    [OAK-8098] - oak-examples/webapp: update spring boot dependency to
-    1.5.19
-    [OAK-8103] - TimingHookTest.commitTime failing occasionally
-    [OAK-8112] - Change log pattern to have complete date for oak-run
-    datastore command
-    [OAK-8115] - Allow disabling of BlobTracker when not required
-    [OAK-8116] - Expose text extraction metrics as sling metrics
-    [OAK-8118] - Index selected properties to enhance feature vector
-    similarity search results
-    [OAK-8119] - Let similarity search rerank use distance as exact
-    score
-    [OAK-8120] - Update http components to 4.5.7/4.4.11
-    [OAK-8134] - Index Copier Stats MBean shows stale info
-    [OAK-8148] - [Indexing] Implement sling metric to calculate number
-    of slow queries(relative to all queries)
-    [OAK-8156] - Update baseline comparisonVersion to 1.10.2
-    [OAK-8163] - examples: update Tomcat dependency to 7.0.93
-    [OAK-8179] - Update jacoco to 0.8.3
-    [OAK-8180] - Update mockito to 2.25.1
-    [OAK-8189] - Getting warning message in error logs while trying to
-    search using filters
-    [OAK-8196] - Update httpclient/mime dependencies to 4.5.8
-    [OAK-8206] - Revert Jackrabbit dependency from 2.19.1 to last
-    stable (2.18.0) for stable Oak release
+    [OAK-7902] - Update osgi-mock to 2.3.10
+    [OAK-8197] - Update Oak 1.10 and trunk to Jackrabbit 2.18.1
+    [OAK-8208] - oak-run/rdb: add --rdbtableprefix option
+    [OAK-8235] - Upgrade Solr to version 6.6.6
+    [OAK-8240] - Improve test coverage for
+    org.apache.jackrabbit.oak.security.authorization.permission
+    [OAK-8248] - Update Oak trunk and 1.10 to Jackrabbit 2.18.2
+    [OAK-8255] - update Apache parent pom to version 21
+    [OAK-8277] - Run tests on travis-ci.org on MongoDB 4.0.x
+    [OAK-8286] - Update jetbrains nullability annotations to 17.0.0
+    [OAK-8295] - Update version of jackrabbit dependency
+    [OAK-8296] - DocumentNodeStoreBranchesTest uses
+    javax.annotation.Nonnull
+    [OAK-8312] - MissingLastRevSeeker and NodeDocumentSweeper: improve
+    progress logging
+    [OAK-8317] - Move the version-related migration tools to the
+    oak-core
+    [OAK-8318] - Allow to close the SegmentStoreMigrator
+    [OAK-8329] - update docker-junit-rule dependency
+    [OAK-8331] - Update Tika dependency to 1.21
+    [OAK-8334] - Update Jackson dependency to 2.9.9
+    [OAK-8335] - get rid of junit deprecation warnings
+    [OAK-8341] - Include tomcat-jdbc/juli in oak-run
+    [OAK-8345] - oak-run: cleanup command list and documentation
+    [OAK-8348] - Update surefire/failsafe dependencies to 2.22.2
+    [OAK-8350] - Update animal-sniffer dependency to 1.18
+    [OAK-8356] - Support append mode in the SegmentStoreMigrator
+    [OAK-8357] - Support the truncate operation for the GCJournalFile
+    [OAK-8376] - update commons-codec dependency to 1.12
+    [OAK-8377] - Jacoco plugin: add PACKAGE based rules for security
+    code
 
 Documentation
 
-    [OAK-8178] - Document missing support for multiplexing in Cug
-    Authorization
-    [OAK-8193] - Update docs with new release strategies
+    [OAK-8322] - Create documentation for Oakathons
 
 In addition to the above-mentioned changes, this release contains all
 changes up to the previous release.