Dinesh Joshi last 3 years


 33 Collaborator
Mick Semb Wever , Štefan Miklošovič , Berenguer Blasi , Caleb Rackliffe , David Capwell , Marcus Eriksson , Yifan Cai , Francisco Guerrero , Josh McKenzie , Jon Meredith , Doug Rohrer , Paulo Motta , Chris Lohfink , Andy Tolbert , Yuki Morishita , Abe Ratnofsky , Saranya Krishnakumar , Bernardo Botella , Jyothsna Konisa , James Berragan , Yuriy Semchyshyn , jberragan , Natnael Adere , jkonisa , Shailaja Koppu , Francisco Guerrero Hernandez , Yuqi Gu , Yifan , Saranya , Francisco , Doug , Dinesh , Andrew Tolbert

 10 Patch  45 Review
f078c02cb58bddd735490b07548f7352f0eb09aa, 1ba6ef93d0721741b5f6d6d72cba3da03fe78438, 695ef5ef66eb8f1759f7dccbe199e7da863167b8, 48af78d1d4b5f285d3dd4991afd4df3101e3983a, 07cb6fea534a65152862cabc36e260c6d3776f36, ea4b44e0ed0a4f0bbe9b18fb40ad927b49a73a32, 369355a061a24d8e36a578fd88cc8fa459e0f18c, 38cdacb2e7418e2aefbcffb1754dcd324c46028d, d2be42dbea6fb1d9d908792788d66113960d565b, 1633cd9c6c3d88d5c66825fab76a369266509f7e 98a0b54c4025ef21aa3fb56f1962c4771e095652, d336dda1123af0c272c69e42b6214577e30447e1, bb68141861e77623f0d0b13f72846651a71c1017, a0af41f666c23a840d9df3f06729ed5fd2c06cd1, c09d0d929baeaa02f3438313c7979ccf6b4b3c5a, b9586501a6b6cdfe465302448018785652c9b966, 6ffa43f68b8d10ca84d4a00bf81269527b4e14df, 9c796dfb272daa3ce57a2dc5cbeadd9273e1ac72, 933137fb14d4ebfe38d0d2c8e23b765aa1c89333, f078c02cb58bddd735490b07548f7352f0eb09aa, aafb4d19448f12ce600dc4e84a5b181308825b32, acd815898d1e5669e7d8ee2469808f6e8a14a7df, 4444721b6de555352bf0ac3ef7e36f94dc832f41, 145dbd1f0875ae4c54392125e09ed05153c0dd8f, 4526b3fcbde22d09065820286dd434d93ecc89ba, a250126f0f277b43a18cb665ccd02a105271bc33, e87a1e0c0a19c64ed2edc2d340c0f8af16776e2c, 3a6f6907314670fdb2b316db8f08ffd85da88851, df16b3750dc2c1b6b9bcdece6f81dfd3de7ebdfa, 2043cb9fb6b25ff34afb90467b9476a09acc3933, 0448f15e3db392f2f60db332fabf6309aa3d5089, 1e3bc4c3b34eae563547899645bfb3f0a1948c79, 38cdacb2e7418e2aefbcffb1754dcd324c46028d, e51716ee724cf4950df67eba0393b3f798b7dc00, 555e8494d3ca27a7b35aebabb1f669eede20cc53, d75a6bae5abbf80810012a181644f240141014d5, a242b352c28947427a9bfc30295a487017439fd9, c73c76498b0c2b36705025de6b0b2a7bb38e758b, 87a729feb4660f57bacb2a4be73e1bb2d509578b, 8771581b255e5728a16aea84430506d6f156a589, deebdf97ad01f23550d7d3b42d98c7bf111e2f95, f24951ab6ea2b1e9af4013b030675c70d31adb90, 014db08a79f00ef0d94e6855779e398c9dc689c1, 82b3c0a79c9322142738a4ec2ff7d4d4c0be2370, 6f8f404535d4cff9272091f669f985ce11cee7d2, 69766bca399cc779e0f2f8e859e39f7e29a17b7a, 912fbb47fddc07afcf56f5de97e813593bfb890e, 02d9136cfa72c8990120eca0f4fe5f52587bceb5, ee1c83722bfb1155bef762cdfb2c86034857f2d0, cbae09ca71b9eb9a581b77c23844da21474b095a, bd0b41fb82134844a15fbb43126424d96706d08e, 9523a38b3f1b5bc4313e2949896ddc1fff58afbe, f0fae2deeee20df15ac1105af2163af2a7e7953d, b87b0edd310d1ef93c507bbbb1ae51e1b0b319c6, 1633cd9c6c3d88d5c66825fab76a369266509f7e

e51716ee724cf4950df67eba0393b3f798b7dc00 | Author: jberragan <jberragan@gmail.com>
 | 2024-12-06 16:09:12-08:00

    CASSANDRA-19962: CEP-44 Kafka integration for Cassandra CDC using Sidecar (#87)
    
    This is the initial commit for CEP-44 to introduce a standalone CDC module into the Analytics project. This module provides the foundation for CDC in the Apache Cassandra Sidecar.
    
    This module provides:
    - a standalone Cdc class as the entrypoint for initializing CDC.
    - pluggable interfaces for: listing and reading commit log segments for a token range, persisting and reading CDC state, providing the Cassandra table schema, optionally reading values from Cassandra.
    - read and deserialize commit log mutations.
    - reconcile and de-duplicate mutations across replicas.
    - serialize CDC state into a binary object for persistence.
    - a layer for converting Cassandra mutations into a standard consumable format.
    
    Patch by James Berragan, Jyothsna Konisa, Yifan Cai; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-19962
    
    Co-authored-by: James Berragan <jberragan@apple.com>
    Co-authored-by: Yifan Cai <ycai@apache.org>
    Co-authored-by: Jyothsna Konisa <jkonisa@apple.com>

555e8494d3ca27a7b35aebabb1f669eede20cc53 | Author: Yifan Cai <ycai@apache.org>
 | 2024-08-20 17:33:35-07:00

    CASSANDRA-19836: Fix NPE when writing UDT values (#74)
    
    When UDT field values are set to null, the bulk writer throws NPE
    
    Patch by Yifan Cai; Reviewed by Dinesh Joshi, Doug Rohrer for CASSANDRA-19836

d75a6bae5abbf80810012a181644f240141014d5 | Author: Yifan Cai <ycai@apache.org>
 | 2024-08-14 13:10:15-07:00

    CASSANDRA-19827: Add job_timeout_seconds writer option (#73)
    
    Option to specify the timeout in seconds for bulk write jobs. By default, it is disabled.
    When `JOB_TIMEOUT_SECONDS` is specified, a job exceeding the timeout is:
    - successful when the desired consistency level is met
    - a failure otherwise
    
    Patch by Yifan Cai; Reviewed by Dinesh Joshi, Doug Rohrer for CASSANDRA-19827

a242b352c28947427a9bfc30295a487017439fd9 | Author: jberragan <jberragan@gmail.com>
 | 2024-07-12 14:57:38-07:00

    CASSANDRA-19748: Refactoring to introduce new cassandra-analytics-common module with minimal dependencies (#62)
    
    - Add new module cassandra-analytics-common with no dependencies on Spark or Cassandra and minimal standard dependencies (Guava, Jackson, Commons Lang Kryo etc)
    - Move standalone classes to cassandra-analytics-common module.
    
    Some additional refactoring and clean up:
    - Rename SSTableInputStream -> BufferingInputStream
    - Rename SSTableSource -> CassandraFileSource
    - Introduce CassandraFile interface to be the implementing class for SSTable and CommitLog.
    - Generalize IStats to work across different CassandraFile types
    - Rename methods in StreamScanner to make the API clearer.
    - Move ComplexTypeBuffer, ListBuffer, MapBuffer, SetBuffer, UdtBuffer to standalone classes
    - Delete unused classes RangeTombstone, ReplciaSet and CollectionElement.
    - Remove commons lang as a dependency
    - Rename Rid to RowData
    
    Patch by James Berragan; Reviewed by Bernardo Botella, Dinesh Joshi, Francisco Guerrero, Yifan Cai, Yuriy Semchyshyn for CASSANDRA-19748

98a0b54c4025ef21aa3fb56f1962c4771e095652 | Author: Stefan Miklosovic <smiklosovic@apache.org>
 | 2024-07-10 21:03:10+02:00

    Support dictionary lookup for CassandraPasswordValidator
    
    patch by Stefan Miklosovic; reviewed by Dinesh Joshi, Francisco Guerrero for CASSANDRA-19762

d336dda1123af0c272c69e42b6214577e30447e1 | Author: Stefan Miklosovic <smiklosovic@apache.org>
 | 2024-06-10 17:28:39+02:00

    CEP-24 Password validation / generation
    
    patch by Stefan Miklosovic; reviewed by Dinesh Joshi, Francisco Guerrero for CASSANDRA-17457

bb68141861e77623f0d0b13f72846651a71c1017 | Author: Francisco Guerrero <frank.guerrero@gmail.com>
 | 2024-05-29 13:38:02-07:00

    CASSANDRA-19669: Audit Log entries are missing identity for mTLS connections
    
    Patch by Francisco Guerrero; Reviewed by Bernardo Botella, Andrew Tolbert, Dinesh Joshi for CASSANDRA-19669

a0af41f666c23a840d9df3f06729ed5fd2c06cd1 | Author: Francisco Guerrero <frank.guerrero@gmail.com>
 | 2024-02-15 13:19:28-08:00

    CASSANDRA-18951: Add option for MutualTlsAuthenticator to restrict the certificate validity period
    
    In this commit, we introduce two new optional options for the `server_encryption_options`
    and the `client_encryption_options`. The options are `max_certificate_validity_period` and
    `certificate_validity_warn_threshold`. Both options can be configured as a duration
    configuration parameter as defined by the `DurationSpec` (see CASSANDRA-15234). The resolution
    for these new properties is minutes.
    
    When specified, the certificate validation implementation will take that information
    and reject certificates that are older than the maximum allowed certificate validity period,
    translating into a rejection from the authenticating user.
    
    The `certificate_validity_warn_threshold` option can be configured to emit warnings (log entries)
    when the certificate exceeds the validity threshold.
    
    patch by Francisco Guerrero; reviewed by Andy Tolbert, Abe Ratnofsky, Dinesh Joshi for CASSANDRA-18951

c09d0d929baeaa02f3438313c7979ccf6b4b3c5a | Author: Andy Tolbert <andy_tolbert@apple.com>
 | 2024-01-30 16:41:54-08:00

    Allow CQL client certificate authentication to work without sending an AUTHENTICATE request
    
    patch by Andy Tolbert; reviewed by Abe Ratnofsky, Dinesh Joshi, Francisco Guerrero, Jyothsna Konisa for CASSANDRA-18857

c73c76498b0c2b36705025de6b0b2a7bb38e758b | Author: Doug Rohrer <drohrer@apple.com>
 | 2023-11-20 10:54:46-05:00

    CASSANDRA-19048 - Audit table properties passed through Analytics CqlUtils
    
    The following properties have an effect on the files generated by the
    bulk writer, and therefore need to be retained when cleaning the table
    schema:
    
    bloom_filter_fp_chance
    cdc
    compression
    default_time_to_live
    min_index_interval
    max_index_interval
    
    Additionally, this commit adds tests to make sure all available TTL
    paths, including table default TTLs and constant/per-row options, work
    as designed.
    
    Patch by Doug Rohrer; Reviewed by Francisco Guerrero Hernandez, Yifan Cai,
    Dinesh Joshi for CASSANDRA-19048

87a729feb4660f57bacb2a4be73e1bb2d509578b | Author: Saranya Krishnakumar <saranya_k@apple.com>
 | 2023-11-06 13:32:01-08:00

    CASSANDRA-19903: Get Sidecar port through CassandraContext
    
    Patch by Saranya Krishnakumar; Reviewed by Dinesh Joshi, Francisco Guerrero, Josh McKenzie for CASSANDRA-19903

8771581b255e5728a16aea84430506d6f156a589 | Author: Yuriy Semchyshyn <yuriy@semchyshyn.com>
 | 2023-10-06 17:54:34-05:00

    CASSANDRA-18916: Log start-up validation result to a single report
    
    Patch by Yuriy Semchyshyn; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18916

b9586501a6b6cdfe465302448018785652c9b966 | Author: Jon Meredith <jonmeredith@apache.org>
 | 2023-09-21 16:07:29-06:00

    Internode legacy SSL storage port certificate is not hot reloaded on update
    
    patch by Jon Meredith; reviewed by Dinesh Joshi, Francisco Guerrero for CASSANDRA-18681

6ffa43f68b8d10ca84d4a00bf81269527b4e14df | Author: Francisco Guerrero <frank.guerrero@gmail.com>
 | 2023-08-25 11:10:48-06:00

    Support Dynamic Port Allocation for in-jvm dtest framework
    
    patch by Francisco Guerrero; reviewed by Dinesh Joshi, Jon Meredith, Yifan Cai for CASSANDRA-18722

1ba6ef93d0721741b5f6d6d72cba3da03fe78438 | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-08-16 13:55:40-07:00

    [maven-release-plugin] prepare release 0.0.16

f24951ab6ea2b1e9af4013b030675c70d31adb90 | Author: Yuriy Semchyshyn <yuriy@semchyshyn.com>
 | 2023-08-14 14:09:12-05:00

    CASSANDRA-18810: Cassandra Analytics Start-Up Validation
    
    Patch by Yuriy Semchyshyn; Reviewed by Dinesh Joshi, Francisco Guerrero, Yifan Cai for CASSANDRA-18810

9c796dfb272daa3ce57a2dc5cbeadd9273e1ac72 | Author: Francisco Guerrero <frank.guerrero@gmail.com>
 | 2023-07-28 09:26:20-07:00

    Skip ColumnFamilyStore#topPartitions initialization when client or tool mode
    
    This commit skips the initialization of `topPartitions` in `org.apache.cassandra.db.ColumnFamilyStore`
    when running in client or tool mode. The `TopPartitionTracker` class will attempt to query the system
    keyspace, which when running in client or tool mode will not be part of the KeyspaceMetadata. This
    causes a warning to be printed out with a stacktrace that can be misleading. The warning is similar to
    this:
    
    ```
    WARN org.apache.cassandra.db.SystemKeyspace: Could not load stored top SIZES partitions for ...
    org.apache.cassandra.db.KeyspaceNotDefinedException: keyspace system does not exist
            at org.apache.cassandra.schema.Schema.validateTable(Schema.java:xxx) ~[?:?]
            at org.apache.cassandra.cql3.statements.SelectStatement$RawStatement.prepare(SelectStatement.java:xxx) ~[?:?]
            at org.apache.cassandra.cql3.statements.SelectStatement$RawStatement.prepare(SelectStatement.java:xxx) ~[?:?]
            at org.apache.cassandra.cql3.statements.SelectStatement$RawStatement.prepare(SelectStatement.java:xxx) ~[?:?]
            at org.apache.cassandra.cql3.QueryProcessor.parseAndPrepare(QueryProcessor.java:xxx) ~[?:?]
            ...
    ```
    
    In this commit, we check whether we run in client or tool mode, and skip initialization
    of `topPartitions` in those cases.
    
    Patch by Francisco Guerrero; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18697

82b3c0a79c9322142738a4ec2ff7d4d4c0be2370 | Author: Francisco Guerrero <frankgh@apache.org>
 | 2023-07-25 12:41:10-07:00

    CASSANDRA-18692 Fix bulk writes with Buffered RowBufferMode
    
    When setting Buffered RowBufferMode as part of the `WriterOption`s,
    `org.apache.cassandra.spark.bulkwriter.RecordWriter` ignores that configuration and instead
    uses the batch size to determine when to finalize an SSTable and start writing a new SSTable,
    if more rows are available.
    
    In this commit, we fix `org.apache.cassandra.spark.bulkwriter.RecordWriter#checkBatchSize`
    to take into account the configured `RowBufferMode`. And in specific to the case of the
    `UNBUFFERED` RowBufferMode, we check then the batchSize of the SSTable during writes, and for
    the case of `BUFFERED` that check will take no effect.
    
    Co-authored-by: Doug Rohrer <doug@therohrers.org>
    
    Patch by Francisco Guerrero, Doug Rohrer; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18692

014db08a79f00ef0d94e6855779e398c9dc689c1 | Author: James Berragan <jberragan@apple.com>
 | 2023-07-19 12:23:07-07:00

    CASSANDRA-18683: Add PartitionSizeTableProvider for reading the compressed and uncompressed sizes of all partitions in a table by utilizing the SSTable Index.db files
    
    Patch by James Berragan; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18683

6f8f404535d4cff9272091f669f985ce11cee7d2 | Author: Yuriy Semchyshyn <yuriy@semchyshyn.com>
 | 2023-07-18 18:58:00-05:00

    CASSANDRA-18684: Minor Refactoring to Improve Code Reusability
    
    patch by Yuriy Semchyshyn; reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18684

02d9136cfa72c8990120eca0f4fe5f52587bceb5 | Author: Francisco Guerrero <frankgh@apache.org>
 | 2023-06-27 10:28:04-07:00

    CASSANDRA-18631: Add Release Audit Tool (RAT) plugin to Analytics
    
    This commit adds the Release Audit Tool (RAT) plugin to `build.gradle` which adds a new task
    `rat`. This new task makes sure that the license headers are valid and present in the source
    files during the `check` task.
    
    To run the RAT plugin, you can run:
    
    ```
    ./gradlew rat
    ```
    
    patch by Francisco Guerrero; reviewed by Dinesh Joshi, Michael Semb Wever for CASSANDRA-18631

69766bca399cc779e0f2f8e859e39f7e29a17b7a | Author: Francisco Guerrero <frankgh@apache.org>
 | 2023-06-27 10:03:56-07:00

    CASSANDRA-18662: Fix cassandra-analytics-core-example
    
    This commit fixes the `SampleCassandraJob` available under the `cassandra-analytics-core-example`
    subproject.
    
    Fix checkstyle issues
    
    Fix serialization issue in SidecarDataTransferApi
    
    The `sidecarClient` field in `SidecarDataTransferApi` is declared as transient,
    this is causing NPEs coming from executors while trying to perform an SSTable
    upload.
    
    This commit completely avoids serializing the `dataTransferApi` field in the
    `CassandraBulkWriterContext`, and lazily initializing it during the `transfer()`
    method invocation. We guard the initialization to a single thread by making the
    `tranfer()` method synchronized. The `SidecarDataTransferApi` can be recreated
    when needed using the already serialized `clusterInfo`, `jobInfo`, and `conf`
    fields.
    
    Fix setting ROW_BUFFER_MODE to BUFFERED
    
    patch by Francisco Guerrero; reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18662

912fbb47fddc07afcf56f5de97e813593bfb890e | Author: Yuriy Semchyshyn <yuriy@semchyshyn.com>
 | 2023-06-26 14:40:10-05:00

    CASSANDRA-18633: Added caching of Node Settings to improve efficiency
    
    patch by Yuriy Semchyshyn; reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18633

9523a38b3f1b5bc4313e2949896ddc1fff58afbe | Author: jkonisa <jkonisa@apple.com>
 | 2023-06-15 13:31:01-07:00

    CASSANDRA-18605 Adding support for TTL & Timestamps for bulk writes
    
    This commit introduces a new feature in Spark Bulk Writer to support writes with
    constant/per_row based TTL & Timestamps.
    
    Patch by Jyothsna Konisa; Reviewed by Dinesh Joshi, Francisco Guerrero, Yifan Cai for CASSANDRA-18605

cbae09ca71b9eb9a581b77c23844da21474b095a | Author: Francisco Guerrero <frankgh@apache.org>
 | 2023-06-14 11:52:55-07:00

    CASSANDRA-18600 Add NOTICE.txt file
    
    The NOTICE.txt file is currently missing in the repository. This commit adds the file to
    comply with ASF's guidance.
    
    patch by Francisco Guerrero; reviewed by Dinesh Joshi, Michael Semb Wever, Berenguer Blasi for CASSANDRA-18600

deebdf97ad01f23550d7d3b42d98c7bf111e2f95 | Author: Doug Rohrer <drohrer@apple.com>
 | 2023-06-14 13:33:29-04:00

    CASSANDRA-18759: Use in-jvm dtest framework from Sidecar for testing
    
    This commit introduces the use of the in-jvm dtest framework for testing
    Analytics workloads. It can spin up a Cassandra cluster, including the
    necessary Sidecar process, to test writing to and reading from Cassandra
    using the analytics library.
    
    Additional changes made in this commit include
    
    * Use concurrent collections in MockBulkWriterContext (Fixes flaky test StreamSessionConsistencyTest)
    
        The StreamSessionConsistency test uses the MockBulkWriter context, but it wasn't originally used
        (before this test was added) in a multi-threaded environment. Because of this, it would occasionally
        throw ConcurrentModificationExceptions, which would cause the stream test to fail in a
        non-deterministic way. This commit adds the use of concurrent/synchronous collections to the
        MockBulkWriterContext to make sure it doesn't throw these spurious errors.
    
    * Make the StartupValidation system thread-safe by using TreadLocals
      instead of static collections, and clearing them once validation is
      complete.
    
    Patch by Doug Rohrer; Reviewed by Dinesh Joshi, Francisco Guerrero, Yifan Cai for CASSANDRA-18759

bd0b41fb82134844a15fbb43126424d96706d08e | Author: Doug Rohrer <drohrer@apple.com>
 | 2023-06-14 13:33:29-04:00

    CASSANDRA-18599 Upgrade to JUnit 5
    
    patch by Doug Rohrer, Francisco Guerrero; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18599

933137fb14d4ebfe38d0d2c8e23b765aa1c89333 | Author: Shailaja Koppu <s_koppu@apple.com>
 | 2023-06-13 17:18:29+01:00

    CIDR filtering authorizer
    
    Patch by Shailaja Koppu, Yifan Cai; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18592
    
    Co-Authored-By: Yifan Cai <ycai@apache.org>

f0fae2deeee20df15ac1105af2163af2a7e7953d | Author: Francisco Guerrero <frankgh@apache.org>
 | 2023-06-08 12:40:22-07:00

    CASSANDRA-18578 Add circleci configuration yaml for Cassandra Analytics
    
    This commit adds the CircleCI configuration yaml to test against all the existing
    profiles
    
          - cassandra-analytics-core-spark2-2.11-jdk8
          - cassandra-analytics-core-spark2-2.12-jdk8
          - cassandra-analytics-core-spark3-2.12-jdk11
          - cassandra-analytics-core-spark3-2.13-jdk11
    
    Patch by Francisco Guerrero; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18578

ee1c83722bfb1155bef762cdfb2c86034857f2d0 | Author: Francisco Guerrero <frankgh@apache.org>
 | 2023-06-07 12:40:50-07:00

    CASSANDRA-18574: Fix sample job documentation after Sidecar changes
    
    This commit fixes the README file with documentation to setup and run the Sample job provided in the repository.
    During Sidecar review, there was a suggestion to change the yaml property `uploads_staging_dir` to `staging_dir`.
    That change however was not reflected as part of the sample job README.md.
    
    patch by Francisco Guerrero; reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18574

d2be42dbea6fb1d9d908792788d66113960d565b | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-24 16:30:54-07:00

    Ninja fix .asf.yaml

695ef5ef66eb8f1759f7dccbe199e7da863167b8 | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-24 08:24:21-07:00

    [maven-release-plugin] prepare for next development iteration

48af78d1d4b5f285d3dd4991afd4df3101e3983a | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-24 08:23:35-07:00

    [maven-release-plugin] prepare release 0.0.15

b87b0edd310d1ef93c507bbbb1ae51e1b0b319c6 | Author: Francisco Guerrero <francisco.guerrero@apple.com>
 | 2023-05-23 13:56:48-07:00

    CASSANDRA-18545: Provide a SecretsProvider interface to abstract the secret provisioning
    
    This commit introduces the SecretsProvider interface that abstracts the secrets provisioning.
    This way different implementations of the SecretsProvider can be used to provide SSL secrets
    for the Analytics job. We provide an implementation, SslConficSecretsProvider, which provides
    secrets based on the configuration for the job.
    
    Patch by Francisco Guerrero; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18545

f078c02cb58bddd735490b07548f7352f0eb09aa | Author: jkonisa <jkonisa@apple.com>
 | 2023-05-22 22:15:22-07:00

    Adding Mutual TLS authenticators for client & internode connections
    
    Patch by Jyothsna Konisa & Dinesh Joshi; reviewed by Yifan Cai, Jon Meredith,
    Yuki Morishita & Dinesh Joshi for CASSANDRA-18554
    
    Co-Authored-By: Dinesh Joshi <djoshi@apache.org>

38cdacb2e7418e2aefbcffb1754dcd324c46028d | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-19 15:34:05-07:00

    CEP-28: Implement Bulk API endpoints and introduce the Sidecar Client to Support Cassandra Analytics
    
    This commit implements the remaining endpoints needed to perform Bulk Analytics operations that allow
    reading and writing data from Cassandra in Bulk. The new endpoints include:
    
    - Endpoint to create snapshots
    - Endpoint to clear a snapshot
    - Endpoint to upload SSTable components
    - Endpoint to clean up uploads for SSTable components
    - Endpoint to import SSTable components
    - Endpoint to retrieve gossip info
    - Endpoint to retrieve the time skew for the server
    - Endpoint to retrieve the ring information
    
    Sidecar Client
    
    Introduces the fully featured sidecar client to access Cassandra Sidecar endpoints.
    It offers support for retries and Sidecar instance selection policies. The client
    project itself is technology-agnostic, but we provide a vertx implementation for
    the `HttpClient`. The Sidecar vertx-client can be published as a shaded-jar to be
    consumed by clients where the dependencies can cause issues, especially in environments
    where the dependencies are not always controlled by the consumers (for example Spark).
    
    Patch by Doug, Francisco, Saranya, Yifan, Dinesh; reviewed by Dinesh Joshi and Yifan Cai for CASSANDRA-16222
    
    Co-authored-by: Saranya Krishnakumar <saranya_k@apple.com>
    Co-authored-by: Yifan Cai <ycai@apache.org>
    Co-authored-by: Francisco Guerrero <francisco.guerrero@apple.com>
    Co-authored-by: Doug Rohrer <drohrer@apple.com>
    Co-authored-by: Dinesh Joshi <djoshi@apache.org>

1633cd9c6c3d88d5c66825fab76a369266509f7e | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-19 14:57:47-07:00

    CEP-28: Apache Cassandra Analytics
    
    This is the initial commit for the Apache Cassandra Analytics project
    where we support reading and writing bulk data from Apache Cassandra from
    Spark.
    
    Patch by James Berragan, Doug Rohrer; Reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-16222
    
    Co-authored-by: James Berragan <jberragan@apple.com>
    Co-authored-by: Doug Rohrer <drohrer@apple.com>
    Co-authored-by: Saranya Krishnakumar <saranya_k@apple.com>
    Co-authored-by: Francisco Guerrero <francisco.guerrero@apple.com>
    Co-authored-by: Yifan Cai <ycai@apache.org>
    Co-authored-by: Jyothsna Konisa <jkonisa@apple.com>
    Co-authored-by: Yuriy Semchyshyn <ysemchyshyn@apple.com>
    Co-authored-by: Dinesh Joshi <djoshi@apache.org>

1e3bc4c3b34eae563547899645bfb3f0a1948c79 | Author: Doug Rohrer <doug@therohrers.org>
 | 2023-05-18 20:44:43-04:00

    Add JMX utility class to in-jvm dtest to ease development of new tests using JMX
    
    While reviewing CASSANDRA-18511, some repetitive code was identified across the 4 branches,
    and 2 different tests, that would also be repeated for any new usages of the JMX support
    in the in-jvm dtest framework. Therefore, a utility class should be added to the dtest-api's
    `shared` package that will simplify some of this repetitive and error-prone code.
    
    patch by Doug Rohrer; reviewed by Jon Meredith, Dinesh Joshi for CASSANDRA-18537

07cb6fea534a65152862cabc36e260c6d3776f36 | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-15 14:58:13-07:00

    [maven-release-plugin] prepare for next development iteration

ea4b44e0ed0a4f0bbe9b18fb40ad927b49a73a32 | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-15 14:56:37-07:00

    [maven-release-plugin] prepare release 0.0.14

369355a061a24d8e36a578fd88cc8fa459e0f18c | Author: Dinesh Joshi <djoshi@apache.org>
 | 2023-05-15 14:54:01-07:00

    Update CHANGES.txt

aafb4d19448f12ce600dc4e84a5b181308825b32 | Author: Marcus Eriksson <marcuse@apache.org>
 | 2023-04-12 09:17:50+02:00

    Improve nodetool enable{audit,fullquery}log
    
    Patch by marcuse; reviewed by Dinesh Joshi and Mick Semb Wever for CASSANDRA-18550

acd815898d1e5669e7d8ee2469808f6e8a14a7df | Author: Yuriy Semchyshyn <ysemchyshyn@apple.com>
 | 2023-04-07 09:52:44-07:00

    Node Draining Should Abort All Current SSTables Imports
    
    patch by Yuriy Semchyshyn; reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-18373

4444721b6de555352bf0ac3ef7e36f94dc832f41 | Author: Natnael Adere <natnael_adere@apple.com>
 | 2023-03-24 09:28:37-07:00

    Provide summary of failed SessionInfo's in StreamResultFuture
    
    patch by Natnael Adere; reviewed by David Capwell, Dinesh Joshi, Jon Meredith for CASSANDRA-17199

145dbd1f0875ae4c54392125e09ed05153c0dd8f | Author: Saranya Krishnakumar <saranya_k@apple.com>
 | 2022-10-19 16:58:41-07:00

    Add flag to exclude nodes from local DC when running nodetool rebuild
    
    Patch by Saranya Krishnakumar; reviewed by Dinesh Joshi, Marcus Eriksson, Yifan Cai for CASSANDRA-17870

4526b3fcbde22d09065820286dd434d93ecc89ba | Author: Josh McKenzie <jmckenzie@apache.org>
 | 2022-08-16 14:19:46-04:00

    Add ability to log load profiles at fixed intervals
    
    Patch by Yifan Cai; reviewed by Josh McKenzie, Dinesh Joshi, and Chris Lohfink for CASSANDRA-17821
    
    Co-authored-by: Yifan Cai <ycai@apache.org>
    Co-authored-by: Josh McKenzie <jmckenzie@apache.org>

a250126f0f277b43a18cb665ccd02a105271bc33 | Author: Francisco Guerrero <frank.guerrero@gmail.com>
 | 2022-07-06 17:34:25-07:00

    Remove commons-lang dependency during build runtime
    
    patch by Francisco Guerrero; reviewed by Dinesh Joshi, Yifan Cai for CASSANDRA-17724

e87a1e0c0a19c64ed2edc2d340c0f8af16776e2c | Author: David Capwell <dcapwell@apache.org>
 | 2022-03-01 13:15:18-08:00

    Expose streaming as a vtable
    
    patch by David Capwell; reviewed by Dinesh Joshi, Paulo Motta for CASSANDRA-17390

df16b3750dc2c1b6b9bcdece6f81dfd3de7ebdfa | Author: David Capwell <dcapwell@apache.org>
 | 2022-02-04 10:15:58-08:00

    When streaming sees a ClosedChannelException this triggers the disk failure policy
    
    patch by David Capwell, Francisco Guerrero; reviewed by Caleb Rackliffe, Dinesh Joshi for CASSANDRA-17116

0448f15e3db392f2f60db332fabf6309aa3d5089 | Author: David Capwell <David Capwell>
 | 2022-02-04 10:15:46-08:00

    When streaming sees a ClosedChannelException this triggers the disk failure policy
    
    patch by David Capwell, Francisco Guerrero; reviewed by Caleb Rackliffe, Dinesh Joshi for CASSANDRA-17116

3a6f6907314670fdb2b316db8f08ffd85da88851 | Author: Yifan Cai <ycai@apache.org>
 | 2021-12-07 18:54:58-08:00

    Limit the maximum hints size per host
    
    patch by Yifan Cai; reviewed by Dinesh Joshi, Francisco Guerrero for CASSANDRA-17142

2043cb9fb6b25ff34afb90467b9476a09acc3933 | Author: Yuqi Gu <guyuqi@apache.org>
 | 2021-10-14 02:47:10+00:00

    Upgrade Snappy and JNA version to support Apple M1
    
    Patch-By Yuqi Gu; Reviewed by Dinesh Joshi and Yifan Cai for CASSANDRA-17040