You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@asterixdb.apache.org by mb...@apache.org on 2023/06/14 01:18:37 UTC

[asterixdb] branch master updated (9f38f8df67 -> 7952d12785)

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

mblow pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git


    from 9f38f8df67 [ASTERIXDB-3196][CONF] Add cloud properties
     new aedda3544b [NO ISSUE][*DB]: Update smart-json to avoid encountered CVE
     new e2a5b688c7 [NO ISSUE] Exclude licenses that are exclusively shadowed
     new 35c42acd3c [NO ISSUE][*DB]: Update Azure blob library
     new c2d6db8d30 Merge branch 'gerrit/cheshire-cat'
     new 46ca03f935 [NO ISSUE][*DB]: Update Azure dependencies
     new 1951421eba Merge branch gerrit/stabilization-667a908755 into neo
     new 31c9ae5af2 [NO ISSUE][HYR][CFG] Support custom ranged long byte units
     new 1b053f3abe Merge branch 'gerrit/stabilization-667a908755'
     new 5b13c7979d [ASTERIXDB-3156][API] Allow specifying lossless-adm as format
     new 025ed62f64 Merge branch 'gerrit/stabilization-667a908755'
     new 64d5d66b1c [NO ISSUE][EXT]: Explicitly set no credentials auth when anonymous auth is used
     new bbe9d0344c [ASTERIXDB-3205][COMP] Avoid inlining non-pure functions in aggregate functions
     new fc90675063 Merge branch 'stabilization-667a908755' into neo
     new 7952d12785 Merge branch 'gerrit/neo' into 'master'

The 14 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../non-pure-function.00.ddl.sqlpp}                |   0
 .../non-pure-function.01.update.sqlpp              |  24 +++
 .../non-pure-function.02.query.sqlpp               |  26 +++
 .../non-pure-function.03.query.sqlpp               |  27 ++++
 .../non-pure-function.04.query.sqlpp               |  28 ++++
 .../non-pure-function.05.query.sqlpp               |  27 ++++
 .../non-pure-function.06.query.sqlpp               |  28 ++++
 .../non-pure-function/non-pure-function.02.adm     |   1 +
 .../non-pure-function/non-pure-function.03.adm     |   1 +
 .../non-pure-function/non-pure-function.04.adm     |   1 +
 .../non-pure-function/non-pure-function.05.adm     |   1 +
 .../non-pure-function/non-pure-function.06.adm     |   1 +
 .../test/resources/runtimets/testsuite_sqlpp.xml   |   5 +
 asterixdb/asterix-external-data/pom.xml            |  10 ++
 .../asterix/external/util/google/gcs/GCSUtils.java |   8 +-
 asterixdb/asterix-server/pom.xml                   |  87 ++++------
 asterixdb/pom.xml                                  |  22 ++-
 .../appended-resources/supplemental-models.xml     | 180 ++++++++++++---------
 ...bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt} |   0
 ...bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt} |   4 +-
 ...7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt} |   4 +-
 ...5b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt} |   4 +-
 ...-sdk-for-java_azure-identity_1.9.0_LICENSE.txt} |   0
 ...e-sdk-for-java_azure-identity_1.9.0_NOTICE.txt} | 141 +++++++++++++---
 ...or-java_azure-storage-blob_12.22.0_LICENSE.txt} |   0
 ...for-java_azure-storage-blob_12.22.0_NOTICE.txt} |  45 ++++--
 .../rules/InlineAssignIntoAggregateRule.java       |  31 ++--
 .../hyracks/control/common/config/OptionTypes.java |   4 +
 hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml     |   8 +-
 hyracks-fullstack/pom.xml                          |  15 ++
 30 files changed, 541 insertions(+), 192 deletions(-)
 copy asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/{objects/load-record-fields/load-record-fields.1.ddl.sqlpp => aggregate/non-pure-function/non-pure-function.00.ddl.sqlpp} (100%)
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.01.update.sqlpp
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.02.query.sqlpp
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.03.query.sqlpp
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.04.query.sqlpp
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.05.query.sqlpp
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.06.query.sqlpp
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.02.adm
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.03.adm
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.04.adm
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.05.adm
 create mode 100644 asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.06.adm
 rename asterixdb/src/main/licenses/content/{bitbucket.org_connect2id_nimbus-content-type_raw_c6d2701ed5cd57e0f88728c6f3e6303db97c5bcf_COPYRIGHT.txt => bitbucket.org_connect2id_nimbus-content-type_raw_18f43920bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt} (100%)
 rename asterixdb/src/main/licenses/content/{bitbucket.org_connect2id_nimbus-jose-jwt_raw_50ae2a39a4a6d0dcbf05572af8a581377174ac96_COPYRIGHT.txt => bitbucket.org_connect2id_nimbus-jose-jwt_raw_e9eaef24bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt} (91%)
 rename asterixdb/src/main/licenses/content/{bitbucket.org_connect2id_nimbus-language-tags_raw_ead5120f62b5849309069808509b4cc6e57a0841_COPYRIGHT.txt => bitbucket.org_connect2id_nimbus-language-tags_raw_372b274e7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt} (91%)
 rename asterixdb/src/main/licenses/content/{bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_5d13925b57ace092ea5e1131c338f464d85545f4_COPYRIGHT.txt => bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_c8f09b035b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt} (89%)
 copy asterixdb/src/main/licenses/content/{raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_LICENSE.txt => raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_LICENSE.txt} (100%)
 copy asterixdb/src/main/licenses/content/{raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_NOTICE.txt => raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_NOTICE.txt} (80%)
 rename asterixdb/src/main/licenses/content/{raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_LICENSE.txt => raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_LICENSE.txt} (100%)
 rename asterixdb/src/main/licenses/content/{raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_NOTICE.txt => raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt} (95%)


[asterixdb] 14/14: Merge branch 'gerrit/neo' into 'master'

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 7952d127854a2ef4750df897f39a957257f88a9f
Merge: 9f38f8df67 fc90675063
Author: Michael Blow <mi...@couchbase.com>
AuthorDate: Tue Jun 13 19:11:15 2023 -0400

    Merge branch 'gerrit/neo' into 'master'
    
    Change-Id: I76febe15393ba442f007d36655cd68e2a6a75238

 .../non-pure-function.00.ddl.sqlpp                 |  30 ++++
 .../non-pure-function.01.update.sqlpp              |  24 +++
 .../non-pure-function.02.query.sqlpp               |  26 +++
 .../non-pure-function.03.query.sqlpp               |  27 ++++
 .../non-pure-function.04.query.sqlpp               |  28 ++++
 .../non-pure-function.05.query.sqlpp               |  27 ++++
 .../non-pure-function.06.query.sqlpp               |  28 ++++
 .../non-pure-function/non-pure-function.02.adm     |   1 +
 .../non-pure-function/non-pure-function.03.adm     |   1 +
 .../non-pure-function/non-pure-function.04.adm     |   1 +
 .../non-pure-function/non-pure-function.05.adm     |   1 +
 .../non-pure-function/non-pure-function.06.adm     |   1 +
 .../test/resources/runtimets/testsuite_sqlpp.xml   |   5 +
 asterixdb/asterix-external-data/pom.xml            |  10 ++
 .../asterix/external/util/google/gcs/GCSUtils.java |   8 +-
 asterixdb/asterix-server/pom.xml                   |  87 ++++------
 asterixdb/pom.xml                                  |  22 ++-
 .../appended-resources/supplemental-models.xml     | 180 ++++++++++++---------
 ...bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt} |   0
 ...bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt} |   4 +-
 ...7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt} |   4 +-
 ...5b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt} |   4 +-
 ...-sdk-for-java_azure-identity_1.9.0_LICENSE.txt} |   0
 ...e-sdk-for-java_azure-identity_1.9.0_NOTICE.txt} | 141 +++++++++++++---
 ...or-java_azure-storage-blob_12.22.0_LICENSE.txt} |   0
 ...for-java_azure-storage-blob_12.22.0_NOTICE.txt} |  45 ++++--
 .../rules/InlineAssignIntoAggregateRule.java       |  31 ++--
 .../hyracks/control/common/config/OptionTypes.java |   4 +
 hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml     |   8 +-
 hyracks-fullstack/pom.xml                          |  15 ++
 30 files changed, 571 insertions(+), 192 deletions(-)

diff --cc asterixdb/asterix-external-data/pom.xml
index 466bbb11f5,0698b8a20f..253754efb0
--- a/asterixdb/asterix-external-data/pom.xml
+++ b/asterixdb/asterix-external-data/pom.xml
@@@ -550,16 -551,11 +555,21 @@@
        <groupId>org.eclipse.jetty</groupId>
        <artifactId>jetty-util-ajax</artifactId>
      </dependency>
+     <!-- Manually included to avoid CVE-2023-1370 -->
+     <dependency>
+       <groupId>net.minidev</groupId>
+       <artifactId>json-smart</artifactId>
+     </dependency>
 +    <dependency>
 +      <groupId>org.apache.iceberg</groupId>
 +      <artifactId>iceberg-core</artifactId>
 +      <version>1.1.0</version>
 +    </dependency>
 +    <dependency>
 +      <groupId>org.apache.avro</groupId>
 +      <artifactId>avro</artifactId>
 +      <version>1.11.1</version>
 +    </dependency>
    </dependencies>
    <!-- apply patch for HADOOP-17225 to workaround CVE-2019-10172 -->
    <repositories>
diff --cc asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/google/gcs/GCSUtils.java
index 3efb041dae,0000000000..6183a88143
mode 100644,000000..100644
--- a/asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/google/gcs/GCSUtils.java
+++ b/asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/google/gcs/GCSUtils.java
@@@ -1,242 -1,0 +1,242 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one
 + * or more contributor license agreements.  See the NOTICE file
 + * distributed with this work for additional information
 + * regarding copyright ownership.  The ASF licenses this file
 + * to you under the Apache License, Version 2.0 (the
 + * "License"); you may not use this file except in compliance
 + * with the License.  You may obtain a copy of the License at
 + *
 + *   http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing,
 + * software distributed under the License is distributed on an
 + * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
 + * KIND, either express or implied.  See the License for the
 + * specific language governing permissions and limitations
 + * under the License.
 + */
 +package org.apache.asterix.external.util.google.gcs;
 +
 +import static org.apache.asterix.common.exceptions.ErrorCode.EXTERNAL_SOURCE_ERROR;
 +import static org.apache.asterix.common.exceptions.ErrorCode.INVALID_PARAM_VALUE_ALLOWED_VALUE;
 +import static org.apache.asterix.common.exceptions.ErrorCode.PARAM_NOT_ALLOWED_IF_PARAM_IS_PRESENT;
 +import static org.apache.asterix.external.util.ExternalDataUtils.getPrefix;
 +import static org.apache.asterix.external.util.ExternalDataUtils.validateIncludeExclude;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.APPLICATION_DEFAULT_CREDENTIALS_FIELD_NAME;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.ENDPOINT_FIELD_NAME;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.HADOOP_AUTH_SERVICE_ACCOUNT_JSON_KEY_FILE;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.HADOOP_AUTH_SERVICE_ACCOUNT_JSON_KEY_FILE_PATH;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.HADOOP_AUTH_TYPE;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.HADOOP_AUTH_UNAUTHENTICATED;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.HADOOP_ENDPOINT;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.HADOOP_GCS_PROTOCOL;
 +import static org.apache.asterix.external.util.google.gcs.GCSConstants.JSON_CREDENTIALS_FIELD_NAME;
 +import static org.apache.hyracks.api.util.ExceptionUtils.getMessageOrToString;
 +
 +import java.io.ByteArrayInputStream;
 +import java.io.IOException;
 +import java.io.InputStream;
 +import java.nio.file.Path;
 +import java.util.ArrayList;
 +import java.util.List;
 +import java.util.Map;
 +import java.util.function.BiPredicate;
 +import java.util.regex.Matcher;
 +
 +import org.apache.asterix.common.exceptions.CompilationException;
 +import org.apache.asterix.common.exceptions.ErrorCode;
 +import org.apache.asterix.external.input.record.reader.abstracts.AbstractExternalInputStreamFactory.IncludeExcludeMatcher;
 +import org.apache.asterix.external.util.ExternalDataConstants;
 +import org.apache.asterix.external.util.ExternalDataUtils;
 +import org.apache.asterix.external.util.HDFSUtils;
 +import org.apache.hadoop.mapred.JobConf;
 +import org.apache.hyracks.api.exceptions.IWarningCollector;
 +import org.apache.hyracks.api.exceptions.SourceLocation;
 +import org.apache.hyracks.api.exceptions.Warning;
 +
 +import com.google.api.gax.paging.Page;
 +import com.google.auth.oauth2.GoogleCredentials;
 +import com.google.cloud.BaseServiceException;
++import com.google.cloud.NoCredentials;
 +import com.google.cloud.storage.Blob;
 +import com.google.cloud.storage.Storage;
 +import com.google.cloud.storage.StorageOptions;
 +
 +public class GCSUtils {
 +    private GCSUtils() {
 +        throw new AssertionError("do not instantiate");
 +
 +    }
 +
 +    /**
 +     * Builds the client using the provided configuration
 +     *
 +     * @param configuration properties
 +     * @return clientasterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/ExternalDataUtils.java
 +     * @throws CompilationException CompilationException
 +     */
 +    public static Storage buildClient(Map<String, String> configuration) throws CompilationException {
 +        String applicationDefaultCredentials = configuration.get(APPLICATION_DEFAULT_CREDENTIALS_FIELD_NAME);
 +        String jsonCredentials = configuration.get(JSON_CREDENTIALS_FIELD_NAME);
 +        String endpoint = configuration.get(ENDPOINT_FIELD_NAME);
 +
 +        StorageOptions.Builder builder = StorageOptions.newBuilder();
 +
 +        // default credentials provider
 +        if (applicationDefaultCredentials != null) {
 +            // only "true" value is allowed
 +            if (!applicationDefaultCredentials.equalsIgnoreCase("true")) {
 +                throw new CompilationException(INVALID_PARAM_VALUE_ALLOWED_VALUE,
 +                        APPLICATION_DEFAULT_CREDENTIALS_FIELD_NAME, "true");
 +            }
 +
 +            // no other authentication parameters are allowed
 +            if (jsonCredentials != null) {
 +                throw new CompilationException(PARAM_NOT_ALLOWED_IF_PARAM_IS_PRESENT, JSON_CREDENTIALS_FIELD_NAME,
 +                        APPLICATION_DEFAULT_CREDENTIALS_FIELD_NAME);
 +            }
 +
 +            try {
 +                builder.setCredentials(GoogleCredentials.getApplicationDefault());
 +            } catch (IOException ex) {
 +                throw CompilationException.create(EXTERNAL_SOURCE_ERROR, getMessageOrToString(ex));
 +            }
-         }
- 
-         // json credentials
-         if (jsonCredentials != null) {
++        } else if (jsonCredentials != null) {
 +            try (InputStream credentialsStream = new ByteArrayInputStream(jsonCredentials.getBytes())) {
 +                builder.setCredentials(GoogleCredentials.fromStream(credentialsStream));
 +            } catch (IOException ex) {
 +                throw new CompilationException(EXTERNAL_SOURCE_ERROR, getMessageOrToString(ex));
 +            }
++        } else {
++            builder.setCredentials(NoCredentials.getInstance());
 +        }
 +
 +        if (endpoint != null) {
 +            builder.setHost(endpoint);
 +        }
 +
 +        return builder.build().getService();
 +    }
 +
 +    /**
 +     * Validate external dataset properties
 +     *
 +     * @param configuration properties
 +     * @throws CompilationException Compilation exception
 +     */
 +    public static void validateProperties(Map<String, String> configuration, SourceLocation srcLoc,
 +            IWarningCollector collector) throws CompilationException {
 +
 +        // check if the format property is present
 +        if (configuration.get(ExternalDataConstants.KEY_FORMAT) == null) {
 +            throw new CompilationException(ErrorCode.PARAMETERS_REQUIRED, srcLoc, ExternalDataConstants.KEY_FORMAT);
 +        }
 +
 +        validateIncludeExclude(configuration);
 +        String container = configuration.get(ExternalDataConstants.CONTAINER_NAME_FIELD_NAME);
 +
 +        try {
 +            Storage.BlobListOption limitOption = Storage.BlobListOption.pageSize(1);
 +            Storage.BlobListOption prefixOption = Storage.BlobListOption.prefix(getPrefix(configuration));
 +            Storage storage = buildClient(configuration);
 +            Page<Blob> items = storage.list(container, limitOption, prefixOption);
 +
 +            if (!items.iterateAll().iterator().hasNext() && collector.shouldWarn()) {
 +                Warning warning = Warning.of(srcLoc, ErrorCode.EXTERNAL_SOURCE_CONFIGURATION_RETURNED_NO_FILES);
 +                collector.warn(warning);
 +            }
 +        } catch (CompilationException ex) {
 +            throw ex;
 +        } catch (Exception ex) {
 +            throw new CompilationException(ErrorCode.EXTERNAL_SOURCE_ERROR, getMessageOrToString(ex));
 +        }
 +    }
 +
 +    public static List<Blob> listItems(Map<String, String> configuration, IncludeExcludeMatcher includeExcludeMatcher,
 +            IWarningCollector warningCollector) throws CompilationException {
 +        // Prepare to retrieve the objects
 +        List<Blob> filesOnly = new ArrayList<>();
 +        String container = configuration.get(ExternalDataConstants.CONTAINER_NAME_FIELD_NAME);
 +        Storage gcs = buildClient(configuration);
 +        Storage.BlobListOption options = Storage.BlobListOption.prefix(ExternalDataUtils.getPrefix(configuration));
 +        Page<Blob> items;
 +
 +        try {
 +            items = gcs.list(container, options);
 +        } catch (BaseServiceException ex) {
 +            throw new CompilationException(ErrorCode.EXTERNAL_SOURCE_ERROR, getMessageOrToString(ex));
 +        }
 +
 +        // Collect the paths to files only
 +        collectAndFilterFiles(items, includeExcludeMatcher.getPredicate(), includeExcludeMatcher.getMatchersList(),
 +                filesOnly);
 +
 +        // Warn if no files are returned
 +        if (filesOnly.isEmpty() && warningCollector.shouldWarn()) {
 +            Warning warning = Warning.of(null, ErrorCode.EXTERNAL_SOURCE_CONFIGURATION_RETURNED_NO_FILES);
 +            warningCollector.warn(warning);
 +        }
 +
 +        return filesOnly;
 +    }
 +
 +    /**
 +     * Excludes paths ending with "/" as that's a directory indicator, we need to return the files only
 +     *
 +     * @param items List of returned objects
 +     */
 +    private static void collectAndFilterFiles(Page<Blob> items, BiPredicate<List<Matcher>, String> predicate,
 +            List<Matcher> matchers, List<Blob> filesOnly) {
 +        for (Blob item : items.iterateAll()) {
 +            // skip folders
 +            if (item.getName().endsWith("/")) {
 +                continue;
 +            }
 +
 +            // No filter, add file
 +            if (predicate.test(matchers, item.getName())) {
 +                filesOnly.add(item);
 +            }
 +        }
 +    }
 +
 +    /**
 +     * Builds the client using the provided configuration
 +     *
 +     * @param configuration      properties
 +     * @param numberOfPartitions number of partitions in the cluster
 +     */
 +    public static void configureHdfsJobConf(JobConf conf, Map<String, String> configuration, int numberOfPartitions) {
 +        String jsonCredentials = configuration.get(JSON_CREDENTIALS_FIELD_NAME);
 +        String endpoint = configuration.get(ENDPOINT_FIELD_NAME);
 +
 +        // disable caching FileSystem
 +        HDFSUtils.disableHadoopFileSystemCache(conf, HADOOP_GCS_PROTOCOL);
 +
 +        // TODO(htowaileb): needs further testing, recommended to disable by gcs-hadoop team
 +        conf.set(GCSConstants.HADOOP_SUPPORT_COMPRESSED, ExternalDataConstants.FALSE);
 +
 +        // TODO(htowaileb): needs further testing
 +        // set number of threads
 +        //        conf.set(GCSConstants.HADOOP_MAX_REQUESTS_PER_BATCH, String.valueOf(numberOfPartitions));
 +        //        conf.set(GCSConstants.HADOOP_BATCH_THREADS, String.valueOf(numberOfPartitions));
 +
 +        // authentication method
 +        // TODO(htowaileb): find a way to pass the content instead of the path to keyfile, this line is temporary
 +        Path credentials = Path.of("credentials.json");
 +        if (jsonCredentials == null) {
 +            // anonymous access
 +            conf.set(HADOOP_AUTH_TYPE, HADOOP_AUTH_UNAUTHENTICATED);
 +        } else {
 +            // TODO(htowaileb) need to pass the file content
 +            conf.set(HADOOP_AUTH_TYPE, HADOOP_AUTH_SERVICE_ACCOUNT_JSON_KEY_FILE);
 +            conf.set(HADOOP_AUTH_SERVICE_ACCOUNT_JSON_KEY_FILE_PATH, credentials.toAbsolutePath().toString());
 +        }
 +
 +        // set endpoint if provided, default is https://storage.googleapis.com/
 +        if (endpoint != null) {
 +            conf.set(HADOOP_ENDPOINT, endpoint);
 +        }
 +    }
 +}
diff --cc asterixdb/asterix-server/pom.xml
index e068a2aa2d,0dcfbdec5e..6e279b836d
--- a/asterixdb/asterix-server/pom.xml
+++ b/asterixdb/asterix-server/pom.xml
@@@ -676,14 -518,7 +658,15 @@@
                  <aliasUrl>https://raw.githubusercontent.com/googleapis/gapic-generator-java/v2.13.0/java-common-protos/LICENSE</aliasUrl>
                  <aliasUrl>https://raw.githubusercontent.com/googleapis/google-api-java-client/v2.1.2/LICENSE</aliasUrl>
                  <aliasUrl>https://raw.githubusercontent.com/grpc/grpc-java/v1.52.1/LICENSE</aliasUrl>
+                 <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.28/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/java-core/v2.8.0/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/google/gson/gson-parent-2.9.0/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/allegro/json-avro-converter/json-avro-converter-0.2.15/LICENSE.md</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/airlift/aircompressor/0.21/license.txt</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/apache/orc/v1.8.0/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/RoaringBitmap/RoaringBitmap/0.9.39/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/JetBrains/java-annotations/master/LICENSE.txt</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/awslabs/aws-crt-java/v0.21.10/LICENSE</aliasUrl>
                </aliasUrls>
                <metric>1</metric>
              </license>
diff --cc asterixdb/pom.xml
index 47544bbc8b,33ca4a80d9..681e9a8236
--- a/asterixdb/pom.xml
+++ b/asterixdb/pom.xml
@@@ -87,10 -87,12 +87,12 @@@
      <hadoop.version>3.3.4</hadoop.version>
      <jacoco.version>0.7.6.201602180812</jacoco.version>
      <log4j.version>2.19.0</log4j.version>
 -    <awsjavasdk.version>2.17.218</awsjavasdk.version>
 +    <awsjavasdk.version>2.20.37</awsjavasdk.version>
      <parquet.version>1.12.3</parquet.version>
      <hadoop-awsjavasdk.version>1.12.402</hadoop-awsjavasdk.version>
-     <azureblobjavasdk.version>12.14.2</azureblobjavasdk.version>
+     <azureblobjavasdk.version>12.22.0</azureblobjavasdk.version>
+     <azurecommonjavasdk.version>12.21.0</azurecommonjavasdk.version>
+     <azureidentity.version>1.9.0</azureidentity.version>
      <azuredatalakejavasdk.version>12.7.2</azuredatalakejavasdk.version>
      <gcsjavasdk.version>2.17.2</gcsjavasdk.version>
      <hadoop-azuresdk.version>8.6.6</hadoop-azuresdk.version>


[asterixdb] 09/14: [ASTERIXDB-3156][API] Allow specifying lossless-adm as format

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 5b13c7979d9b38793fe9e08a7e59a65f57fe147b
Author: Murtadha Hubail <mu...@couchbase.com>
AuthorDate: Tue Mar 28 00:35:42 2023 +0300

    [ASTERIXDB-3156][API] Allow specifying lossless-adm as format
    
    - user model changes: yes
    - storage format changes: no
    - interface changes: no
    
    Details:
    
    - Allow specifying `lossless-adm` as format in the
      REST API.
    - Add test case.
    
    Change-Id: I24057c56bafbe021b5d4da93a82cdaa0213bccd5
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17451
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Reviewed-by: Ali Alsuliman <al...@gmail.com>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
    (cherry picked from commit ffdcf57835a49b049fd65a840469468bc7274fa1)
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17564
---
 .../http/server/QueryServiceRequestParameters.java |  2 ++
 .../request-param/request-param.003.query.sqlpp    | 24 ++++++++++++++++++++++
 .../api/request-param/request-param.003.adm        |  2 ++
 3 files changed, 28 insertions(+)

diff --git a/asterixdb/asterix-app/src/main/java/org/apache/asterix/api/http/server/QueryServiceRequestParameters.java b/asterixdb/asterix-app/src/main/java/org/apache/asterix/api/http/server/QueryServiceRequestParameters.java
index df068c0824..b6913e448b 100644
--- a/asterixdb/asterix-app/src/main/java/org/apache/asterix/api/http/server/QueryServiceRequestParameters.java
+++ b/asterixdb/asterix-app/src/main/java/org/apache/asterix/api/http/server/QueryServiceRequestParameters.java
@@ -626,6 +626,8 @@ public class QueryServiceRequestParameters {
             return Pair.of(OutputFormat.CLEAN_JSON, Boolean.FALSE);
         } else if (value.equals(HttpUtil.ContentType.ADM)) {
             return Pair.of(OutputFormat.ADM, Boolean.FALSE);
+        } else if (value.equals(Attribute.LOSSLESS_ADM.str())) {
+            return Pair.of(OutputFormat.LOSSLESS_ADM_JSON, Boolean.FALSE);
         } else {
             throw new RuntimeDataException(ErrorCode.INVALID_REQ_PARAM_VAL, parameterName, value);
         }
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/api/request-param/request-param.003.query.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/api/request-param/request-param.003.query.sqlpp
new file mode 100644
index 0000000000..52800c8708
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/api/request-param/request-param.003.query.sqlpp
@@ -0,0 +1,24 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+// requesttype=application/json
+// param format:string=lossless-adm
+
+from [1, 2] as v
+select v;
\ No newline at end of file
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/results/api/request-param/request-param.003.adm b/asterixdb/asterix-app/src/test/resources/runtimets/results/api/request-param/request-param.003.adm
new file mode 100644
index 0000000000..cb88308596
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/results/api/request-param/request-param.003.adm
@@ -0,0 +1,2 @@
+{ "v": 1 }
+{ "v": 2 }
\ No newline at end of file


[asterixdb] 08/14: Merge branch 'gerrit/stabilization-667a908755'

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 1b053f3abe1aba98890a1f37fa42dfab70d17aca
Merge: 1951421eba 31c9ae5af2
Author: Michael Blow <mb...@apache.org>
AuthorDate: Sun Jun 4 07:47:40 2023 -0400

    Merge branch 'gerrit/stabilization-667a908755'
    
    Change-Id: Id920cc0b131dd626b62be7e1bd618de59562ee6b

 .../java/org/apache/hyracks/control/common/config/OptionTypes.java    | 4 ++++
 1 file changed, 4 insertions(+)


[asterixdb] 02/14: [NO ISSUE] Exclude licenses that are exclusively shadowed

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit e2a5b688c71b824aabd6e9e7616b343b39dcf41b
Author: Michael Blow <mb...@apache.org>
AuthorDate: Fri Dec 9 15:56:28 2022 -0500

    [NO ISSUE] Exclude licenses that are exclusively shadowed
    
    (cherry picked from commit 667a908755)
    
    Change-Id: I19eb0000e2977e85293fd7c2e67768a218062fe9
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17563
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Reviewed-by: Hussain Towaileb <hu...@gmail.com>
---
 asterixdb/src/main/licenses/templates/asterix-license.ftl         | 8 ++++----
 .../apache/hyracks/maven/license/project/LicensedProjects.java    | 6 ++++++
 2 files changed, 10 insertions(+), 4 deletions(-)

diff --git a/asterixdb/src/main/licenses/templates/asterix-license.ftl b/asterixdb/src/main/licenses/templates/asterix-license.ftl
index 434ce447f6..f9c969e27c 100644
--- a/asterixdb/src/main/licenses/templates/asterix-license.ftl
+++ b/asterixdb/src/main/licenses/templates/asterix-license.ftl
@@ -34,8 +34,11 @@ ${license.content}
 <#list licenseMap as e>
    <#assign licenseUrl = e.getKey()/>
    <#assign entry = e.getValue()/>
-   <#assign projects = entry.projects/>
+   <#assign projects = entry.nonShadowedProjects/>
    <#assign license = entry.getLicense()/>
+   <#if projects?size == 0>
+     <#continue/>
+   </#if>
    <#if projects?size == 1>
    Component:
      <#assign isare = "is"/>
@@ -44,9 +47,6 @@ ${license.content}
      <#assign isare = "are"/>
    </#if>
    <#list projects as p>
-     <#if p.shadowed>
-       <#continue/>
-     </#if>
        * ${p.name} (${p.groupId}:${p.artifactId}:${p.version})
      <#list p.locations as loc>
          - ${loc}${p.jarName}
diff --git a/hyracks-fullstack/hyracks/hyracks-maven-plugins/license-automation-plugin/src/main/java/org/apache/hyracks/maven/license/project/LicensedProjects.java b/hyracks-fullstack/hyracks/hyracks-maven-plugins/license-automation-plugin/src/main/java/org/apache/hyracks/maven/license/project/LicensedProjects.java
index f6f9f32444..31b4a86061 100644
--- a/hyracks-fullstack/hyracks/hyracks-maven-plugins/license-automation-plugin/src/main/java/org/apache/hyracks/maven/license/project/LicensedProjects.java
+++ b/hyracks-fullstack/hyracks/hyracks-maven-plugins/license-automation-plugin/src/main/java/org/apache/hyracks/maven/license/project/LicensedProjects.java
@@ -21,6 +21,7 @@ package org.apache.hyracks.maven.license.project;
 import java.util.Set;
 import java.util.SortedSet;
 import java.util.TreeSet;
+import java.util.function.Predicate;
 
 import org.apache.hyracks.maven.license.LicenseSpec;
 
@@ -51,6 +52,11 @@ public class LicensedProjects {
         return projects;
     }
 
+    public SortedSet<Project> getNonShadowedProjects() {
+        return projects.stream().filter(Predicate.not(Project::isShadowed))
+                .collect(() -> new TreeSet<>(Project.PROJECT_COMPARATOR), TreeSet::add, TreeSet::addAll);
+    }
+
     public void addProject(Project project) {
         projects.add(project);
     }


[asterixdb] 06/14: Merge branch gerrit/stabilization-667a908755 into neo

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 1951421ebaf8e92d9cc2424fa7410d07d8c067d3
Merge: 47aa7a5cc3 46ca03f935
Author: Hussain Towaileb <Hu...@couchbase.com>
AuthorDate: Sat May 27 20:43:59 2023 +0300

    Merge branch gerrit/stabilization-667a908755 into neo
    
    Change-Id: I30741e372bd765908b6ba9e976651c7113242f5c

 asterixdb/asterix-external-data/pom.xml            |  10 ++
 asterixdb/asterix-server/pom.xml                   |  87 ++++------
 asterixdb/pom.xml                                  |  22 ++-
 .../appended-resources/supplemental-models.xml     | 180 ++++++++++++---------
 ...bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt} |   0
 ...bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt} |   4 +-
 ...7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt} |   4 +-
 ...5b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt} |   4 +-
 ...-sdk-for-java_azure-identity_1.9.0_LICENSE.txt} |   0
 ...e-sdk-for-java_azure-identity_1.9.0_NOTICE.txt} | 141 +++++++++++++---
 ...or-java_azure-storage-blob_12.22.0_LICENSE.txt} |   0
 ...for-java_azure-storage-blob_12.22.0_NOTICE.txt} |  45 ++++--
 hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml     |   8 +-
 hyracks-fullstack/pom.xml                          |  15 ++
 14 files changed, 348 insertions(+), 172 deletions(-)

diff --cc hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml
index 106bb08618,816746cfca..33526f1d12
--- a/hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml
+++ b/hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml
@@@ -179,12 -183,20 +179,16 @@@
        <scope>test</scope>
        <exclusions>
          <exclusion>
-           <groupId>org.slf4j</groupId>
-           <artifactId>slf4j-reload4j</artifactId>
+           <groupId>net.minidev</groupId>
+           <artifactId>json-smart</artifactId>
+         </exclusion>
+         <exclusion>
+           <groupId>log4j</groupId>
+           <artifactId>log4j</artifactId>
          </exclusion>
          <exclusion>
 -          <groupId>org.slf4j</groupId>
 -          <artifactId>slf4j-api</artifactId>
 -        </exclusion>
 -        <exclusion>
 -          <groupId>org.slf4j</groupId>
 -          <artifactId>slf4j-log4j12</artifactId>
 +          <groupId>ch.qos.reload4j</groupId>
 +          <artifactId>reload4j</artifactId>
          </exclusion>
          <!-- TODO(htowaileb): Remove after updating to hadoop 3.3.4 -->
          <exclusion>


[asterixdb] 05/14: [NO ISSUE][*DB]: Update Azure dependencies

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 46ca03f9356e7da6b0b1cba3be68c152fecd8e13
Author: Hussain Towaileb <Hu...@couchbase.com>
AuthorDate: Tue May 16 22:34:20 2023 +0300

    [NO ISSUE][*DB]: Update Azure dependencies
    
    Change-Id: I57b62efbc1720e20d5cad4a1ea2c8f0075f70a71
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17537
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Reviewed-by: Hussain Towaileb <hu...@gmail.com>
    Reviewed-by: Michael Blow <mb...@apache.org>
---
 asterixdb/asterix-external-data/pom.xml            |   8 +-
 asterixdb/asterix-server/pom.xml                   |  61 +++--------
 asterixdb/pom.xml                                  |   3 +-
 .../appended-resources/supplemental-models.xml     |  62 +++--------
 ...bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt} |   0
 ...bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt} |   4 +-
 ...7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt} |   4 +-
 ...5b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt} |   4 +-
 ...e-sdk-for-java_azure-identity_1.9.0_LICENSE.txt |  21 ++++
 ...e-sdk-for-java_azure-identity_1.9.0_NOTICE.txt} | 122 +++++++++++++++++----
 ...-for-java_azure-storage-blob_12.22.0_NOTICE.txt |  24 ++--
 11 files changed, 180 insertions(+), 133 deletions(-)

diff --git a/asterixdb/asterix-external-data/pom.xml b/asterixdb/asterix-external-data/pom.xml
index c2d78199f4..b3ab6dae38 100644
--- a/asterixdb/asterix-external-data/pom.xml
+++ b/asterixdb/asterix-external-data/pom.xml
@@ -537,6 +537,10 @@
       <groupId>io.netty</groupId>
       <artifactId>netty-transport-native-unix-common</artifactId>
     </dependency>
+    <dependency>
+      <groupId>io.netty</groupId>
+      <artifactId>netty-handler-proxy</artifactId>
+    </dependency>
     <!-- TODO(htowaileb): removed from hadoop transitively and added separately to avoid CVEs, can
      be removed once upgraded to hadoop 3.3.4 as it addresses the CVEs -->
     <dependency>
@@ -552,10 +556,6 @@
       <groupId>net.minidev</groupId>
       <artifactId>json-smart</artifactId>
     </dependency>
-    <dependency>
-      <groupId>io.netty</groupId>
-      <artifactId>netty-handler-proxy</artifactId>
-    </dependency>
   </dependencies>
   <!-- apply patch for HADOOP-17225 to workaround CVE-2019-10172 -->
   <repositories>
diff --git a/asterixdb/asterix-server/pom.xml b/asterixdb/asterix-server/pom.xml
index 495b92f628..7832dec560 100644
--- a/asterixdb/asterix-server/pom.xml
+++ b/asterixdb/asterix-server/pom.xml
@@ -256,58 +256,36 @@
               <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.28/LICENSE</url>
             </override>
             <override>
-              <gav>com.microsoft.azure:msal4j:1.11.0</gav>
-              <url>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-library-for-java/v1.11.0/LICENSE</url>
+              <gav>com.microsoft.azure:msal4j:1.13.8</gav>
+              <url>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-library-for-java/v1.13.8/LICENSE</url>
             </override>
             <override>
-              <gav>com.microsoft.azure:msal4j-persistence-extension:1.1.0</gav>
-              <url>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-extensions-for-java/1.1.0/LICENSE</url>
+              <gav>com.microsoft.azure:msal4j-persistence-extension:1.2.0</gav>
+              <url>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-extensions-for-java/master/LICENSE</url>
             </override>
             <override>
               <gav>com.microsoft.azure:azure-keyvault-core:1.2.4</gav>
               <url>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/main/sdk/keyvault/LICENSE</url>
             </override>
             <override>
-              <gav>com.nimbusds:nimbus-jose-jwt:9.9.3</gav>
-              <noticeUrl>https://bitbucket.org/connect2id/nimbus-jose-jwt/raw/50ae2a39a4a6d0dcbf05572af8a581377174ac96/COPYRIGHT.txt</noticeUrl>
+              <gav>com.nimbusds:nimbus-jose-jwt:9.30.2</gav>
+              <noticeUrl>https://bitbucket.org/connect2id/nimbus-jose-jwt/raw/e9eaef24bc7348d6be23d2a9daaacd6b8424b8c1/COPYRIGHT.txt</noticeUrl>
             </override>
-            <!-- com.nimbusds:oauth2-oidc-sdk:9.7 points to https://www.apache.org/licenses/LICENSE-2.0.html in the pom.xml but has bad characters in the URI, overriding to fix -->
             <override>
-              <gav>com.nimbusds:oauth2-oidc-sdk:9.7</gav>
-              <url>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/5d13925b57ace092ea5e1131c338f464d85545f4/LICENSE.txt</url>
-              <noticeUrl>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/5d13925b57ace092ea5e1131c338f464d85545f4/COPYRIGHT.txt</noticeUrl>
+              <gav>com.nimbusds:oauth2-oidc-sdk:10.7.1</gav>
+              <noticeUrl>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/c8f09b035b7e93858a39ad4a46ba4d0e17a0aefe/COPYRIGHT.txt</noticeUrl>
             </override>
             <override>
-              <gav>com.nimbusds:lang-tag:1.5</gav>
-              <noticeUrl>https://bitbucket.org/connect2id/nimbus-language-tags/raw/ead5120f62b5849309069808509b4cc6e57a0841/COPYRIGHT.txt</noticeUrl>
+              <gav>com.nimbusds:lang-tag:1.7</gav>
+              <noticeUrl>https://bitbucket.org/connect2id/nimbus-language-tags/raw/372b274e7db1c3a9d42f1ae39fb35cfbb54a8742/COPYRIGHT.txt</noticeUrl>
             </override>
             <override>
-              <gav>com.nimbusds:content-type:2.1</gav>
-              <noticeUrl>https://bitbucket.org/connect2id/nimbus-content-type/raw/c6d2701ed5cd57e0f88728c6f3e6303db97c5bcf/COPYRIGHT.txt</noticeUrl>
+              <gav>com.nimbusds:content-type:2.2</gav>
+              <noticeUrl>https://bitbucket.org/connect2id/nimbus-content-type/raw/18f43920bc8e88873f0c1e42723640536866d3df/COPYRIGHT.txt</noticeUrl>
             </override>
             <override>
-              <gavs>
-                <gav>io.projectreactor.netty:reactor-netty:1.0.7</gav>
-                <gav>io.projectreactor.netty:reactor-netty-core:1.0.7</gav>
-                <gav>io.projectreactor.netty:reactor-netty-http:1.0.7</gav>
-                <gav>io.projectreactor.netty:reactor-netty-http-brave:1.0.7</gav>
-              </gavs>
-              <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.7/LICENSE</url>
-            </override>
-            <override>
-              <gavs>
-                <gav>io.projectreactor.netty:reactor-netty-core:1.0.11</gav>
-                <gav>io.projectreactor.netty:reactor-netty-http:1.0.11</gav>
-              </gavs>
-              <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.11/LICENSE</url>
-            </override>
-            <override>
-              <gav>io.projectreactor:reactor-core:3.4.6</gav>
-              <url>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.6/LICENSE</url>
-            </override>
-            <override>
-              <gav>io.projectreactor:reactor-core:3.4.10</gav>
-              <url>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.10/LICENSE</url>
+              <gav>io.projectreactor:reactor-core:3.4.27</gav>
+              <url>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.27/LICENSE</url>
             </override>
             <override>
               <gavs>
@@ -520,12 +498,9 @@
                 <aliasUrl>https://www.apache.org/licenses/LICENSE-2.0.html</aliasUrl>
                 <aliasUrl>https://aws.amazon.com/apache2.0</aliasUrl>
                 <aliasUrl>https://raw.githubusercontent.com/jorabin/KeePassJava2/KeePassJava2-2.1.4/LICENSE</aliasUrl>
-                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.7/LICENSE</aliasUrl>
-                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.11/LICENSE</aliasUrl>
-                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.6/LICENSE</aliasUrl>
-                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.10/LICENSE</aliasUrl>
+                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.27/LICENSE</aliasUrl>
                 <aliasUrl>https://raw.githubusercontent.com/codehaus/stax/master/dev/ASF2.0.txt</aliasUrl>
-                <aliasUrl>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/5d13925b57ace092ea5e1131c338f464d85545f4/LICENSE.txt</aliasUrl>
+                <aliasUrl>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/c8f09b035b7e93858a39ad4a46ba4d0e17a0aefe/LICENSE.txt</aliasUrl>
                 <aliasUrl>https://raw.githubusercontent.com/google/auto/auto-value-1.10.1/LICENSE</aliasUrl>
                 <aliasUrl>https://raw.githubusercontent.com/google/j2objc/1.3/LICENSE</aliasUrl>
                 <aliasUrl>https://raw.githubusercontent.com/googleapis/java-storage/v2.17.2/LICENSE</aliasUrl>
@@ -592,8 +567,8 @@
               <aliasUrls>
                 <aliasUrl>http://www.opensource.org/licenses/mit-license.php</aliasUrl>
                 <aliasUrl>http://opensource.org/licenses/MIT</aliasUrl>
-                <aliasUrl>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-library-for-java/v1.11.0/LICENSE</aliasUrl>
-                <aliasUrl>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-extensions-for-java/1.1.0/LICENSE</aliasUrl>
+                <aliasUrl>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-library-for-java/v1.13.8/LICENSE</aliasUrl>
+                <aliasUrl>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-extensions-for-java/master/LICENSE</aliasUrl>
               </aliasUrls>
             </license>
             <license>
diff --git a/asterixdb/pom.xml b/asterixdb/pom.xml
index 868c7eeb9b..952f838abc 100644
--- a/asterixdb/pom.xml
+++ b/asterixdb/pom.xml
@@ -92,6 +92,7 @@
     <hadoop-awsjavasdk.version>1.12.402</hadoop-awsjavasdk.version>
     <azureblobjavasdk.version>12.22.0</azureblobjavasdk.version>
     <azurecommonjavasdk.version>12.21.0</azurecommonjavasdk.version>
+    <azureidentity.version>1.9.0</azureidentity.version>
     <azuredatalakejavasdk.version>12.7.2</azuredatalakejavasdk.version>
     <gcsjavasdk.version>2.17.2</gcsjavasdk.version>
     <hadoop-azuresdk.version>8.6.6</hadoop-azuresdk.version>
@@ -1651,7 +1652,7 @@
       <dependency>
         <groupId>com.azure</groupId>
         <artifactId>azure-identity</artifactId>
-        <version>1.4.1</version>
+        <version>${azureidentity.version}</version>
         <exclusions>
           <exclusion>
             <groupId>net.minidev</groupId>
diff --git a/asterixdb/src/main/appended-resources/supplemental-models.xml b/asterixdb/src/main/appended-resources/supplemental-models.xml
index ac3e63c50f..d33451f77e 100644
--- a/asterixdb/src/main/appended-resources/supplemental-models.xml
+++ b/asterixdb/src/main/appended-resources/supplemental-models.xml
@@ -847,9 +847,9 @@
       <groupId>com.azure</groupId>
       <artifactId>azure-identity</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.4.1</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.4.1</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>1.4.1</license.ignoreLicenseOverride>
+        <license.ignoreMissingEmbeddedLicense>1.9.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.9.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>1.9.0</license.ignoreLicenseOverride>
       </properties>
     </project>
   </supplement>
@@ -860,9 +860,9 @@
       <groupId>com.microsoft.azure</groupId>
       <artifactId>msal4j</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.11.0</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.11.0</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>1.11.0</license.ignoreLicenseOverride>
+        <license.ignoreMissingEmbeddedLicense>1.13.8</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.13.8</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>1.13.8</license.ignoreLicenseOverride>
       </properties>
     </project>
   </supplement>
@@ -873,9 +873,9 @@
       <groupId>com.microsoft.azure</groupId>
       <artifactId>msal4j-persistence-extension</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.1.0</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.1.0</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>1.1.0</license.ignoreLicenseOverride>
+        <license.ignoreMissingEmbeddedLicense>1.2.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.2.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>1.2.0</license.ignoreLicenseOverride>
       </properties>
     </project>
   </supplement>
@@ -957,18 +957,6 @@
     </project>
   </supplement>
 
-  <!-- io.projectreactor.netty:reactor-netty uses ALv2 license and has no notice -->
-  <supplement>
-    <project>
-      <groupId>io.projectreactor.netty</groupId>
-      <artifactId>reactor-netty</artifactId>
-      <properties>
-        <license.ignoreMissingEmbeddedLicense>1.0.28</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.0.28</license.ignoreMissingEmbeddedNotice>
-      </properties>
-    </project>
-  </supplement>
-
   <!-- io.projectreactor.netty:reactor-netty-core uses ALv2 license and has no notice -->
   <supplement>
     <project>
@@ -993,28 +981,14 @@
     </project>
   </supplement>
 
-  <!-- io.projectreactor.netty:reactor-netty-http-brave uses ALv2 license and has no notice -->
-  <supplement>
-    <project>
-      <groupId>io.projectreactor.netty</groupId>
-      <artifactId>reactor-netty-http-brave</artifactId>
-      <properties>
-        <license.ignoreMissingEmbeddedLicense>1.0.7</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.0.7</license.ignoreMissingEmbeddedNotice>
-      </properties>
-    </project>
-  </supplement>
-
   <!-- com.nimbusds:oauth2-oidc-sdk has ALv2 embedded in pom.xml -->
   <supplement>
     <project>
       <groupId>com.nimbusds</groupId>
       <artifactId>oauth2-oidc-sdk</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>9.7</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>9.7</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>9.7</license.ignoreLicenseOverride>
-        <license.ignoreNoticeOverride>9.7</license.ignoreNoticeOverride>
+        <license.ignoreMissingEmbeddedLicense>10.7.1</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>10.7.1</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -1025,8 +999,8 @@
       <groupId>com.nimbusds</groupId>
       <artifactId>nimbus-jose-jwt</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>9.9.3</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>9.9.3</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>9.30.2</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>9.30.2</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -1037,8 +1011,8 @@
       <groupId>com.nimbusds</groupId>
       <artifactId>lang-tag</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.5</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.5</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>1.7</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.7</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -1049,8 +1023,8 @@
       <groupId>com.nimbusds</groupId>
       <artifactId>content-type</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>2.1</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>2.1</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>2.2</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>2.2</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -1960,7 +1934,7 @@
       <groupId>net.java.dev.jna</groupId>
       <artifactId>jna</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedNotice>5.5.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedNotice>5.13.0</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
diff --git a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-content-type_raw_c6d2701ed5cd57e0f88728c6f3e6303db97c5bcf_COPYRIGHT.txt b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-content-type_raw_18f43920bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt
similarity index 100%
rename from asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-content-type_raw_c6d2701ed5cd57e0f88728c6f3e6303db97c5bcf_COPYRIGHT.txt
rename to asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-content-type_raw_18f43920bc8e88873f0c1e42723640536866d3df_COPYRIGHT.txt
diff --git a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-jose-jwt_raw_50ae2a39a4a6d0dcbf05572af8a581377174ac96_COPYRIGHT.txt b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-jose-jwt_raw_e9eaef24bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt
similarity index 91%
rename from asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-jose-jwt_raw_50ae2a39a4a6d0dcbf05572af8a581377174ac96_COPYRIGHT.txt
rename to asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-jose-jwt_raw_e9eaef24bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt
index 29cdeb1fe1..f4fec45061 100644
--- a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-jose-jwt_raw_50ae2a39a4a6d0dcbf05572af8a581377174ac96_COPYRIGHT.txt
+++ b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-jose-jwt_raw_e9eaef24bc7348d6be23d2a9daaacd6b8424b8c1_COPYRIGHT.txt
@@ -1,6 +1,6 @@
 Nimbus JOSE + JWT
 
-Copyright 2012 - 2020, Connect2id Ltd.
+Copyright 2012 - 2022, Connect2id Ltd.
 
 Licensed under the Apache License, Version 2.0 (the "License"); you may not use
 this file except in compliance with the License. You may obtain a copy of the
@@ -11,4 +11,4 @@ License at
 Unless required by applicable law or agreed to in writing, software distributed
 under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR
 CONDITIONS OF ANY KIND, either express or implied. See the License for the
-specific language governing permissions and limitations under the License.
+specific language governing permissions and limitations under the License.
\ No newline at end of file
diff --git a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-language-tags_raw_ead5120f62b5849309069808509b4cc6e57a0841_COPYRIGHT.txt b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-language-tags_raw_372b274e7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt
similarity index 91%
rename from asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-language-tags_raw_ead5120f62b5849309069808509b4cc6e57a0841_COPYRIGHT.txt
rename to asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-language-tags_raw_372b274e7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt
index 37a85f6850..e9956372d6 100644
--- a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-language-tags_raw_ead5120f62b5849309069808509b4cc6e57a0841_COPYRIGHT.txt
+++ b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_nimbus-language-tags_raw_372b274e7db1c3a9d42f1ae39fb35cfbb54a8742_COPYRIGHT.txt
@@ -1,6 +1,6 @@
 Nimbus Language Tags
 
-Copyright 2012-2016, Connect2id Ltd.
+Copyright 2012-2022, Connect2id Ltd.
 
 Licensed under the Apache License, Version 2.0 (the "License"); you may not use
 this file except in compliance with the License. You may obtain a copy of the
@@ -11,4 +11,4 @@ License at
 Unless required by applicable law or agreed to in writing, software distributed
 under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR
 CONDITIONS OF ANY KIND, either express or implied. See the License for the
-specific language governing permissions and limitations under the License.
+specific language governing permissions and limitations under the License.
\ No newline at end of file
diff --git a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_5d13925b57ace092ea5e1131c338f464d85545f4_COPYRIGHT.txt b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_c8f09b035b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt
similarity index 89%
rename from asterixdb/src/main/licenses/content/bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_5d13925b57ace092ea5e1131c338f464d85545f4_COPYRIGHT.txt
rename to asterixdb/src/main/licenses/content/bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_c8f09b035b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt
index 42e4fd73dc..a03dc6355c 100644
--- a/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_5d13925b57ace092ea5e1131c338f464d85545f4_COPYRIGHT.txt
+++ b/asterixdb/src/main/licenses/content/bitbucket.org_connect2id_oauth-2.0-sdk-with-openid-connect-extensions_raw_c8f09b035b7e93858a39ad4a46ba4d0e17a0aefe_COPYRIGHT.txt
@@ -1,6 +1,6 @@
 Nimbus OAuth 2.0 SDK with OpenID Connect extensions
 
-Copyright 2012-2021, Connect2id Ltd and contributors.
+Copyright 2012-2023, Connect2id Ltd and contributors.
 
 Licensed under the Apache License, Version 2.0 (the "License"); you may not use
 this file except in compliance with the License. You may obtain a copy of the
@@ -11,4 +11,4 @@ License at
 Unless required by applicable law or agreed to in writing, software distributed
 under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR
 CONDITIONS OF ANY KIND, either express or implied. See the License for the
-specific language governing permissions and limitations under the License.
+specific language governing permissions and limitations under the License.
\ No newline at end of file
diff --git a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_LICENSE.txt b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_LICENSE.txt
new file mode 100644
index 0000000000..49d21669ae
--- /dev/null
+++ b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_LICENSE.txt
@@ -0,0 +1,21 @@
+The MIT License (MIT)
+
+Copyright (c) 2015 Microsoft
+
+Permission is hereby granted, free of charge, to any person obtaining a copy
+of this software and associated documentation files (the "Software"), to deal
+in the Software without restriction, including without limitation the rights
+to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+copies of the Software, and to permit persons to whom the Software is
+furnished to do so, subject to the following conditions:
+
+The above copyright notice and this permission notice shall be included in all
+copies or substantial portions of the Software.
+
+THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
+SOFTWARE.
\ No newline at end of file
diff --git a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_NOTICE.txt
similarity index 83%
copy from asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
copy to asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_NOTICE.txt
index f9973895e3..ff05c5325d 100644
--- a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
+++ b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-identity_1.9.0_NOTICE.txt
@@ -252,20 +252,20 @@ All rights reserved.
 Redistribution and use in source and binary forms, with or without modification,
 are permitted provided that the following conditions are met:
 
-Redistributions of source code must retain the above copyright notice, 
+Redistributions of source code must retain the above copyright notice,
 this list of conditions and the following disclaimer.
-Redistributions in binary form must reproduce the above copyright notice, 
-this list of conditions and the following disclaimer in the documentation and/or other materials 
+Redistributions in binary form must reproduce the above copyright notice,
+this list of conditions and the following disclaimer in the documentation and/or other materials
 provided with the distribution.
-Neither the name of the Eclipse Foundation, Inc. nor the names of its contributors may be used to 
+Neither the name of the Eclipse Foundation, Inc. nor the names of its contributors may be used to
 endorse or promote products derived from this software without specific prior written permission.
-THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR 
-IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND 
-FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS 
-BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES 
-(INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; 
-LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING 
+THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR
+IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
+FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS
+BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
+(INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES;
+LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
+WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING
 IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 
 
@@ -282,20 +282,20 @@ All rights reserved.
 Redistribution and use in source and binary forms, with or without modification,
 are permitted provided that the following conditions are met:
 
-Redistributions of source code must retain the above copyright notice, 
+Redistributions of source code must retain the above copyright notice,
 this list of conditions and the following disclaimer.
-Redistributions in binary form must reproduce the above copyright notice, 
-this list of conditions and the following disclaimer in the documentation and/or other materials 
+Redistributions in binary form must reproduce the above copyright notice,
+this list of conditions and the following disclaimer in the documentation and/or other materials
 provided with the distribution.
-Neither the name of the Eclipse Foundation, Inc. nor the names of its contributors may be used to 
+Neither the name of the Eclipse Foundation, Inc. nor the names of its contributors may be used to
 endorse or promote products derived from this software without specific prior written permission.
-THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR 
-IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND 
-FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS 
-BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES 
-(INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; 
-LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING 
+THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR
+IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
+FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS
+BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
+(INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES;
+LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
+WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING
 IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 
 
@@ -530,4 +530,80 @@ http://www.apache.org/licenses/LICENSE-2.0
 
 Unless required by applicable law or agreed to in writing, software distributed under the License
 is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and limitations under the License.
\ No newline at end of file
+See the License for the specific language governing permissions and limitations under the License.
+
+-------------------------------------------------------------------------------------------------
+
+License notice for GraalVM
+------------------------------------------------------------------------------
+org.graalvm.sdk:graal-sdk - https://github.com/graalvm/native-build-tools/blob/master/common/junit-platform-native/LICENSE
+The Universal Permissive License (UPL), Version 1.0
+
+Subject to the condition set forth below, permission is hereby granted to any person obtaining a copy of this software,
+associated documentation and/or data (collectively the "Software"), free of charge and under any and all copyright rights
+in the Software, and any and all patent rights owned or freely licensable by each licensor hereunder covering either
+(i) the unmodified Software as contributed to or provided by such licensor, or (ii) the Larger Works (as defined below),
+to deal in both
+
+(a) the Software, and
+
+(b) any piece of software and/or hardware listed in the lrgrwrks.txt file if one is included with the Software each a
+"Larger Work" to which the Software is contributed by such licensors), without restriction, including without limitation
+the rights to copy, create derivative works of, display, perform, and distribute the Software and make, use, sell, offer
+for sale, import, export, have made, and have sold the Software and the Larger Work(s), and to sublicense the foregoing
+rights on either these or other terms.
+
+This license is subject to the following condition:
+
+The above copyright notice and either this complete permission notice or at a minimum a reference to the UPL must be
+included in all copies or substantial portions of the Software.
+
+THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE
+WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
+COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE,
+ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
+
+-------------------------------------------------------------------------------------------------
+
+License notice for JUnit platform native plugin
+------------------------------------------------------------------------------
+org.graalvm.buildtools:junit-platform-native - https://github.com/graalvm/native-build-tools/blob/master/common/junit-platform-native/LICENSE
+
+Copyright (c) 2020, 2021, Oracle and/or its affiliates. All rights reserved.
+DO NOT ALTER OR REMOVE COPYRIGHT NOTICES OR THIS FILE HEADER.
+
+The Universal Permissive License (UPL), Version 1.0
+
+Subject to the condition set forth below, permission is hereby granted to any
+person obtaining a copy of this software, associated documentation and/or
+data (collectively the "Software"), free of charge and under any and all
+copyright rights in the Software, and any and all patent rights owned or
+freely licensable by each licensor hereunder covering either (i) the
+unmodified Software as contributed to or provided by such licensor, or (ii)
+the Larger Works (as defined below), to deal in both
+
+(a) the Software, and
+
+(b) any piece of software and/or hardware listed in the lrgrwrks.txt file if
+one is included with the Software each a "Larger Work" to which the Software
+is contributed by such licensors),
+
+without restriction, including without limitation the rights to copy, create
+derivative works of, display, perform, and distribute the Software and make,
+use, sell, offer for sale, import, export, have made, and have sold the
+Software and the Larger Work(s), and to sublicense the foregoing rights on
+either these or other terms.
+
+This license is subject to the following condition:
+
+The above copyright notice and either this complete permission notice or at a
+minimum a reference to the UPL must be included in all copies or substantial
+portions of the Software.
+
+THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
+SOFTWARE.
\ No newline at end of file
diff --git a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
index f9973895e3..986d0e6039 100644
--- a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
+++ b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
@@ -265,7 +265,7 @@ FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT
 BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES 
 (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; 
 LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING 
+WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING
 IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 
 
@@ -282,20 +282,20 @@ All rights reserved.
 Redistribution and use in source and binary forms, with or without modification,
 are permitted provided that the following conditions are met:
 
-Redistributions of source code must retain the above copyright notice, 
+Redistributions of source code must retain the above copyright notice,
 this list of conditions and the following disclaimer.
-Redistributions in binary form must reproduce the above copyright notice, 
-this list of conditions and the following disclaimer in the documentation and/or other materials 
+Redistributions in binary form must reproduce the above copyright notice,
+this list of conditions and the following disclaimer in the documentation and/or other materials
 provided with the distribution.
-Neither the name of the Eclipse Foundation, Inc. nor the names of its contributors may be used to 
+Neither the name of the Eclipse Foundation, Inc. nor the names of its contributors may be used to
 endorse or promote products derived from this software without specific prior written permission.
-THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR 
-IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND 
-FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS 
-BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES 
-(INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; 
-LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING 
+THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR
+IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
+FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS
+BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
+(INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES;
+LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
+WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING
 IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 
 


[asterixdb] 03/14: [NO ISSUE][*DB]: Update Azure blob library

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 35c42acd3c5de6a142714ff0bb83c64ce40db302
Author: Hussain Towaileb <Hu...@couchbase.com>
AuthorDate: Tue May 23 10:44:10 2023 +0300

    [NO ISSUE][*DB]: Update Azure blob library
    
    Change-Id: I0b46060587dd787dfd7cbd0cb454491fe3c4d373
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17551
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Reviewed-by: Michael Blow <mb...@apache.org>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
---
 asterixdb/asterix-external-data/pom.xml            |  5 ++
 asterixdb/asterix-server/pom.xml                   | 24 ++++--
 asterixdb/pom.xml                                  |  7 +-
 .../appended-resources/supplemental-models.xml     | 97 +++++++++++++++-------
 ...or-java_azure-storage-blob_12.22.0_LICENSE.txt} |  0
 ...for-java_azure-storage-blob_12.22.0_NOTICE.txt} | 21 ++++-
 hyracks-fullstack/pom.xml                          |  5 ++
 7 files changed, 117 insertions(+), 42 deletions(-)

diff --git a/asterixdb/asterix-external-data/pom.xml b/asterixdb/asterix-external-data/pom.xml
index 6cc875a7b7..21bbfb941d 100644
--- a/asterixdb/asterix-external-data/pom.xml
+++ b/asterixdb/asterix-external-data/pom.xml
@@ -210,6 +210,7 @@
               <usedDependency>io.netty:netty-resolver-dns</usedDependency>
               <usedDependency>io.netty:netty-codec-http2</usedDependency>
               <usedDependency>io.netty:netty-transport-native-unix-common</usedDependency>
+              <usedDependency>io.netty:netty-handler-proxy</usedDependency>
             </usedDependencies>
           </configuration>
         </plugin>
@@ -502,5 +503,9 @@
       <groupId>io.netty</groupId>
       <artifactId>netty-transport-native-unix-common</artifactId>
     </dependency>
+    <dependency>
+      <groupId>io.netty</groupId>
+      <artifactId>netty-handler-proxy</artifactId>
+    </dependency>
   </dependencies>
 </project>
diff --git a/asterixdb/asterix-server/pom.xml b/asterixdb/asterix-server/pom.xml
index 2e6afb2135..33ab5882c0 100644
--- a/asterixdb/asterix-server/pom.xml
+++ b/asterixdb/asterix-server/pom.xml
@@ -218,15 +218,22 @@
             </override>
             <override>
               <gavs>
-                <gav>com.azure:azure-core:1.24.1</gav>
-                <gav>com.azure:azure-core-http-netty:1.11.6</gav>
-                <gav>com.azure:azure-storage-blob:12.14.3</gav>
-                <gav>com.azure:azure-storage-common:12.14.2</gav>
-                <gav>com.azure:azure-storage-internal-avro:12.1.3</gav>
+                <gav>com.azure:azure-core:1.38.0</gav>
+                <gav>com.azure:azure-core-http-netty:1.13.2</gav>
+                <gav>com.azure:azure-json:1.0.0</gav>
+                <gav>com.azure:azure-storage-blob:12.22.0</gav>
+                <gav>com.azure:azure-storage-common:12.21.0</gav>
+                <gav>com.azure:azure-storage-internal-avro:12.7.0</gav>
               </gavs>
-              <!-- azure-storage-blob-batch_12.11.3 release is at 89a32290750a18d1b99c27c16b1b11d42f16c622 -->
-              <noticeUrl>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/89a32290750a18d1b99c27c16b1b11d42f16c622/NOTICE.txt</noticeUrl>
-              <url>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/89a32290750a18d1b99c27c16b1b11d42f16c622/LICENSE.txt</url>
+              <noticeUrl>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/azure-storage-blob_12.22.0/NOTICE.txt</noticeUrl>
+              <url>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/azure-storage-blob_12.22.0/LICENSE.txt</url>
+            </override>
+            <override>
+              <gavs>
+                <gav>io.projectreactor.netty:reactor-netty-core:1.0.28</gav>
+                <gav>io.projectreactor.netty:reactor-netty-http:1.0.28</gav>
+              </gavs>
+              <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.28/LICENSE</url>
             </override>
             <override>
               <gav>org.mindrot:jbcrypt:0.4</gav>
@@ -271,6 +278,7 @@
                 <aliasUrl>http://www.apache.org/licenses/LICENSE-2.0.html</aliasUrl>
                 <aliasUrl>https://www.apache.org/licenses/LICENSE-2.0.html</aliasUrl>
                 <aliasUrl>https://aws.amazon.com/apache2.0</aliasUrl>
+                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.28/LICENSE</aliasUrl>
               </aliasUrls>
               <metric>1</metric>
             </license>
diff --git a/asterixdb/pom.xml b/asterixdb/pom.xml
index 5d6a5fe962..92f0473225 100644
--- a/asterixdb/pom.xml
+++ b/asterixdb/pom.xml
@@ -88,7 +88,8 @@
     <jacoco.version>0.7.6.201602180812</jacoco.version>
     <log4j.version>2.19.0</log4j.version>
     <awsjavasdk.version>2.17.218</awsjavasdk.version>
-    <azurejavasdk.version>12.12.0</azurejavasdk.version>
+    <azureblobjavasdk.version>12.22.0</azureblobjavasdk.version>
+    <azurecommonjavasdk.version>12.21.0</azurecommonjavasdk.version>
     <parquet.version>1.8.2</parquet.version>
 
     <implementation.title>Apache AsterixDB - ${project.name}</implementation.title>
@@ -1523,7 +1524,7 @@
       <dependency>
         <groupId>com.azure</groupId>
         <artifactId>azure-storage-blob</artifactId>
-        <version>12.14.3</version>
+        <version>${azureblobjavasdk.version}</version>
         <exclusions>
           <exclusion>
             <groupId>io.netty</groupId>
@@ -1594,7 +1595,7 @@
       <dependency>
         <groupId>com.azure</groupId>
         <artifactId>azure-storage-common</artifactId>
-        <version>12.14.2</version>
+        <version>${azurecommonjavasdk.version}</version>
         <exclusions>
           <exclusion>
             <groupId>io.netty</groupId>
diff --git a/asterixdb/src/main/appended-resources/supplemental-models.xml b/asterixdb/src/main/appended-resources/supplemental-models.xml
index 24eca6a3fc..2300c925d0 100644
--- a/asterixdb/src/main/appended-resources/supplemental-models.xml
+++ b/asterixdb/src/main/appended-resources/supplemental-models.xml
@@ -226,6 +226,18 @@
       </properties>
     </project>
   </supplement>
+  <supplement>
+    <project>
+      <groupId>io.netty</groupId>
+      <artifactId>netty-codec-socks</artifactId>
+      <properties>
+        <!-- netty is ALv2, and does not contain any embedded LICENSE or NOTICE file -->
+        <license.ignoreMissingEmbeddedLicense>4.1.87.Final</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>4.1.87.Final</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreNoticeOverride>4.1.87.Final</license.ignoreNoticeOverride>
+      </properties>
+    </project>
+  </supplement>
   <supplement>
     <project>
       <groupId>io.netty</groupId>
@@ -238,6 +250,18 @@
       </properties>
     </project>
   </supplement>
+  <supplement>
+    <project>
+      <groupId>io.netty</groupId>
+      <artifactId>netty-handler-proxy</artifactId>
+      <properties>
+        <!-- netty is ALv2, and does not contain any embedded LICENSE or NOTICE file -->
+        <license.ignoreMissingEmbeddedLicense>4.1.87.Final</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>4.1.87.Final</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreNoticeOverride>4.1.87.Final</license.ignoreNoticeOverride>
+      </properties>
+    </project>
+  </supplement>
   <supplement>
     <project>
       <groupId>io.netty</groupId>
@@ -653,10 +677,10 @@
       <groupId>com.azure</groupId>
       <artifactId>azure-storage-blob</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>12.14.3</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>12.14.3</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>12.14.3</license.ignoreLicenseOverride>
-        <license.ignoreNoticeOverride>12.14.3</license.ignoreNoticeOverride>
+        <license.ignoreMissingEmbeddedLicense>12.22.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>12.22.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>12.22.0</license.ignoreLicenseOverride>
+        <license.ignoreNoticeOverride>12.22.0</license.ignoreNoticeOverride>
       </properties>
     </project>
   </supplement>
@@ -666,10 +690,10 @@
       <groupId>com.azure</groupId>
       <artifactId>azure-storage-common</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>12.14.2</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>12.14.2</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>12.14.2</license.ignoreLicenseOverride>
-        <license.ignoreNoticeOverride>12.14.2</license.ignoreNoticeOverride>
+        <license.ignoreMissingEmbeddedLicense>12.21.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>12.21.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>12.21.0</license.ignoreLicenseOverride>
+        <license.ignoreNoticeOverride>12.21.0</license.ignoreNoticeOverride>
       </properties>
     </project>
   </supplement>
@@ -679,10 +703,10 @@
       <groupId>com.azure</groupId>
       <artifactId>azure-storage-internal-avro</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>12.1.3</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>12.1.3</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>12.1.3</license.ignoreLicenseOverride>
-        <license.ignoreNoticeOverride>12.1.3</license.ignoreNoticeOverride>
+        <license.ignoreMissingEmbeddedLicense>12.7.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>12.7.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>12.7.0</license.ignoreLicenseOverride>
+        <license.ignoreNoticeOverride>12.7.0</license.ignoreNoticeOverride>
       </properties>
     </project>
   </supplement>
@@ -692,10 +716,10 @@
       <groupId>com.azure</groupId>
       <artifactId>azure-core</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.24.1</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.24.1</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>1.24.1</license.ignoreLicenseOverride>
-        <license.ignoreNoticeOverride>1.24.1</license.ignoreNoticeOverride>
+        <license.ignoreMissingEmbeddedLicense>1.38.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.38.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>1.38.0</license.ignoreLicenseOverride>
+        <license.ignoreNoticeOverride>1.38.0</license.ignoreNoticeOverride>
       </properties>
     </project>
   </supplement>
@@ -705,10 +729,23 @@
       <groupId>com.azure</groupId>
       <artifactId>azure-core-http-netty</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.11.6</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.11.6</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>1.11.6</license.ignoreLicenseOverride>
-        <license.ignoreNoticeOverride>1.11.6</license.ignoreNoticeOverride>
+        <license.ignoreMissingEmbeddedLicense>1.13.2</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.13.2</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>1.13.2</license.ignoreLicenseOverride>
+        <license.ignoreNoticeOverride>1.13.2</license.ignoreNoticeOverride>
+      </properties>
+    </project>
+  </supplement>
+
+  <supplement>
+    <project>
+      <groupId>com.azure</groupId>
+      <artifactId>azure-json</artifactId>
+      <properties>
+        <license.ignoreMissingEmbeddedLicense>1.0.0</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.0.0</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>1.0.0</license.ignoreLicenseOverride>
+        <license.ignoreNoticeOverride>1.0.0</license.ignoreNoticeOverride>
       </properties>
     </project>
   </supplement>
@@ -721,7 +758,7 @@
       <groupId>com.fasterxml.jackson.datatype</groupId>
       <artifactId>jackson-datatype-jsr310</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedNotice>2.13.1</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedNotice>2.13.5</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -733,7 +770,7 @@
       <groupId>com.fasterxml.woodstox</groupId>
       <artifactId>woodstox-core</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedNotice>6.2.7</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedNotice>6.4.0</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -756,8 +793,8 @@
       <groupId>io.projectreactor</groupId>
       <artifactId>reactor-core</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>3.4.13</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>3.4.13</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>3.4.27</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>3.4.27</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -768,8 +805,8 @@
       <groupId>io.projectreactor.netty</groupId>
       <artifactId>reactor-netty</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.0.14</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.0.14</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>1.0.28</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.0.28</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -780,8 +817,8 @@
       <groupId>io.projectreactor.netty</groupId>
       <artifactId>reactor-netty-core</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.0.14</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.0.14</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>1.0.28</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.0.28</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -792,8 +829,8 @@
       <groupId>io.projectreactor.netty</groupId>
       <artifactId>reactor-netty-http</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>1.0.14</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>1.0.14</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>1.0.28</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>1.0.28</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
diff --git a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_LICENSE.txt b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_LICENSE.txt
similarity index 100%
rename from asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_LICENSE.txt
rename to asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_LICENSE.txt
diff --git a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_NOTICE.txt b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
similarity index 96%
rename from asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_NOTICE.txt
rename to asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
index 9cee8257b5..f9973895e3 100644
--- a/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_89a32290750a18d1b99c27c16b1b11d42f16c622_NOTICE.txt
+++ b/asterixdb/src/main/licenses/content/raw.githubusercontent.com_Azure_azure-sdk-for-java_azure-storage-blob_12.22.0_NOTICE.txt
@@ -511,4 +511,23 @@ or implied. See the License for the specific language governing permissions and
 the License.
 
 Openkeepass License Link: https://github.com/cternes/openkeepass/blob/master/LICENSE.txt
--------------------------------------------------------------------------------------------------
\ No newline at end of file
+-------------------------------------------------------------------------------------------------
+
+License notice for Apache Commons
+------------------------------------------------------------------------------
+
+Copyright 2002-2019 The Apache Software Foundation
+
+commons-codec (https://github.com/apache/commons-codec)
+commons-text (https://github.com/apache/commons-text)
+commons-lang (https://github.com/apache/commons-lang)
+commons-collections (https://github.com/apache/commons-collections)
+
+Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except
+in compliance with the License. You may obtain a copy of the License at
+
+http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing, software distributed under the License
+is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and limitations under the License.
\ No newline at end of file
diff --git a/hyracks-fullstack/pom.xml b/hyracks-fullstack/pom.xml
index b91cbd1afb..9380fb181d 100644
--- a/hyracks-fullstack/pom.xml
+++ b/hyracks-fullstack/pom.xml
@@ -115,6 +115,11 @@
         <artifactId>netty-handler</artifactId>
         <version>${netty.version}</version>
       </dependency>
+      <dependency>
+        <groupId>io.netty</groupId>
+        <artifactId>netty-handler-proxy</artifactId>
+        <version>${netty.version}</version>
+      </dependency>
       <dependency>
         <groupId>io.netty</groupId>
         <artifactId>netty-transport-classes-epoll</artifactId>


[asterixdb] 11/14: [ASTERIXDB-3205][COMP] Avoid inlining non-pure functions in aggregate functions

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit bbe9d0344cff8723d162c313ba42c19e72fd159d
Author: Wail Alkowaileet <wa...@gmail.com>
AuthorDate: Tue Jun 6 16:54:21 2023 -0700

    [ASTERIXDB-3205][COMP] Avoid inlining non-pure functions in aggregate functions
    
    - user model changes: no
    - storage format changes: no
    - interface changes: no
    
    Details:
    Currently, the compiler blindly inlines all functions
    from assign operators into aggregate functions. However,
    non-pure functions should not be inlined.
    
    Change-Id: Ib3fbd684f1732a276d6033bf38507df41d33b843
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17589
    Reviewed-by: Wail Alkowaileet <wa...@gmail.com>
    Reviewed-by: Ali Alsuliman <al...@gmail.com>
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
---
 .../non-pure-function.00.ddl.sqlpp                 | 30 +++++++++++++++++++++
 .../non-pure-function.01.update.sqlpp              | 24 +++++++++++++++++
 .../non-pure-function.02.query.sqlpp               | 26 ++++++++++++++++++
 .../non-pure-function.03.query.sqlpp               | 27 +++++++++++++++++++
 .../non-pure-function.04.query.sqlpp               | 28 +++++++++++++++++++
 .../non-pure-function.05.query.sqlpp               | 27 +++++++++++++++++++
 .../non-pure-function.06.query.sqlpp               | 28 +++++++++++++++++++
 .../non-pure-function/non-pure-function.02.adm     |  1 +
 .../non-pure-function/non-pure-function.03.adm     |  1 +
 .../non-pure-function/non-pure-function.04.adm     |  1 +
 .../non-pure-function/non-pure-function.05.adm     |  1 +
 .../non-pure-function/non-pure-function.06.adm     |  1 +
 .../test/resources/runtimets/testsuite_sqlpp.xml   |  5 ++++
 .../rules/InlineAssignIntoAggregateRule.java       | 31 +++++++++++-----------
 14 files changed, 215 insertions(+), 16 deletions(-)

diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.00.ddl.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.00.ddl.sqlpp
new file mode 100644
index 0000000000..99898f9b28
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.00.ddl.sqlpp
@@ -0,0 +1,30 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+DROP DATAVERSE test IF EXISTS;
+CREATE DATAVERSE test;
+
+USE test;
+
+CREATE TYPE OpenType AS {
+    id: int
+};
+
+CREATE DATASET MyDataset(OpenType)
+PRIMARY KEY id;
\ No newline at end of file
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.01.update.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.01.update.sqlpp
new file mode 100644
index 0000000000..751aaba761
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.01.update.sqlpp
@@ -0,0 +1,24 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+USE test;
+
+INSERT INTO MyDataset(
+    SELECT x id, x num
+    FROM range(1, 10) x
+);
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.02.query.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.02.query.sqlpp
new file mode 100644
index 0000000000..116c61ae47
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.02.query.sqlpp
@@ -0,0 +1,26 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/*
+* Description  : Do not inline random(1) in COUNT()
+* Date         : Jun 2nd 2023
+*/
+USE test;
+SELECT COUNT(random(1)) randCount
+FROM MyDataset md
+GROUP BY 1
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.03.query.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.03.query.sqlpp
new file mode 100644
index 0000000000..1e02ae2426
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.03.query.sqlpp
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/*
+* Description  : Do not inline random(1) in COUNT()
+* Date         : Jun 2nd 2023
+*/
+USE test;
+
+SELECT COUNT(random(1)) randCount, COUNT(md.num + 1) numCount
+FROM MyDataset md
+GROUP BY 1
\ No newline at end of file
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.04.query.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.04.query.sqlpp
new file mode 100644
index 0000000000..c5837237f4
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.04.query.sqlpp
@@ -0,0 +1,28 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/*
+* Description  : Do not inline random(1) in COUNT()
+* Date         : Jun 2nd 2023
+* Notes        : We can inline COUNT(md.num + 1) if ASTERIXDB-3206 is fixed
+*/
+USE test;
+
+SELECT COUNT(md.num + 1) numCount, COUNT(random(1)) randCount
+FROM MyDataset md
+GROUP BY 1
\ No newline at end of file
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.05.query.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.05.query.sqlpp
new file mode 100644
index 0000000000..715b73f92d
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.05.query.sqlpp
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/*
+* Description  : Do not inline random(1) in COUNT()
+* Date         : Jun 2nd 2023
+*/
+USE test;
+
+SELECT COUNT(random(1) + round(md.num / 3)) randCount, COUNT(md.num + 1) numCount
+FROM MyDataset md
+GROUP BY 1
\ No newline at end of file
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.06.query.sqlpp b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.06.query.sqlpp
new file mode 100644
index 0000000000..20e2c785a7
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate/non-pure-function/non-pure-function.06.query.sqlpp
@@ -0,0 +1,28 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/*
+* Description  : Do not inline random(1) in COUNT()
+* Date         : Jun 2nd 2023
+* Notes        : We can inline COUNT(md.num + 1) if ASTERIXDB-3206 is fixed
+*/
+USE test;
+
+SELECT COUNT(md.num + 1) numCount, COUNT(random(1) + round(md.num / 3)) randCount
+FROM MyDataset md
+GROUP BY 1
\ No newline at end of file
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.02.adm b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.02.adm
new file mode 100644
index 0000000000..6390f8a0f6
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.02.adm
@@ -0,0 +1 @@
+{ "randCount": 10 }
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.03.adm b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.03.adm
new file mode 100644
index 0000000000..160683ea33
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.03.adm
@@ -0,0 +1 @@
+{ "randCount": 10, "numCount": 10 }
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.04.adm b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.04.adm
new file mode 100644
index 0000000000..a3724b3662
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.04.adm
@@ -0,0 +1 @@
+{ "numCount": 10, "randCount": 10 }
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.05.adm b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.05.adm
new file mode 100644
index 0000000000..160683ea33
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.05.adm
@@ -0,0 +1 @@
+{ "randCount": 10, "numCount": 10 }
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.06.adm b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.06.adm
new file mode 100644
index 0000000000..a3724b3662
--- /dev/null
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/results/aggregate/non-pure-function/non-pure-function.06.adm
@@ -0,0 +1 @@
+{ "numCount": 10, "randCount": 10 }
diff --git a/asterixdb/asterix-app/src/test/resources/runtimets/testsuite_sqlpp.xml b/asterixdb/asterix-app/src/test/resources/runtimets/testsuite_sqlpp.xml
index c0784c1dce..41c0424389 100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/testsuite_sqlpp.xml
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/testsuite_sqlpp.xml
@@ -1612,6 +1612,11 @@
         <output-dir compare="Text">min_max_arrays</output-dir>
       </compilation-unit>
     </test-case>
+    <test-case FilePath="aggregate">
+      <compilation-unit name="non-pure-function">
+        <output-dir compare="Text">non-pure-function</output-dir>
+      </compilation-unit>
+    </test-case>
   </test-group>
   <test-group name="aggregate-sql">
     <test-case FilePath="aggregate-sql">
diff --git a/hyracks-fullstack/algebricks/algebricks-rewriter/src/main/java/org/apache/hyracks/algebricks/rewriter/rules/InlineAssignIntoAggregateRule.java b/hyracks-fullstack/algebricks/algebricks-rewriter/src/main/java/org/apache/hyracks/algebricks/rewriter/rules/InlineAssignIntoAggregateRule.java
index d966ed100d..ad7703db8a 100644
--- a/hyracks-fullstack/algebricks/algebricks-rewriter/src/main/java/org/apache/hyracks/algebricks/rewriter/rules/InlineAssignIntoAggregateRule.java
+++ b/hyracks-fullstack/algebricks/algebricks-rewriter/src/main/java/org/apache/hyracks/algebricks/rewriter/rules/InlineAssignIntoAggregateRule.java
@@ -84,11 +84,7 @@ public class InlineAssignIntoAggregateRule implements IAlgebraicRewriteRule {
         }
         AssignOperator assignOp = (AssignOperator) op2;
         VarExprSubstitution ves = new VarExprSubstitution(assignOp.getVariables(), assignOp.getExpressions());
-        inlineVariables(aggOp, ves);
-        List<Mutable<ILogicalOperator>> op1InpList = aggOp.getInputs();
-        op1InpList.clear();
-        op1InpList.add(op2.getInputs().get(0));
-        return true;
+        return inlineVariables(aggOp, ves);
     }
 
     private boolean inlineOuterInputAssignIntoAgg(AggregateOperator aggOp,
@@ -107,18 +103,20 @@ public class InlineAssignIntoAggregateRule implements IAlgebraicRewriteRule {
         for (Mutable<ILogicalExpression> exprRef : aggOp.getExpressions()) {
             ILogicalExpression expr = exprRef.getValue();
             Pair<Boolean, ILogicalExpression> p = expr.accept(ves, null);
-            if (p.first) {
-                exprRef.setValue(p.second);
+            ILogicalExpression originalExpr = p.second;
+            if (p.first & originalExpr.isFunctional()) {
+                exprRef.setValue(originalExpr);
                 inlined = true;
             }
         }
         return inlined;
     }
 
-    private class VarExprSubstitution extends AbstractConstVarFunVisitor<Pair<Boolean, ILogicalExpression>, Void> {
+    private static class VarExprSubstitution
+            extends AbstractConstVarFunVisitor<Pair<Boolean, ILogicalExpression>, Void> {
 
-        private List<LogicalVariable> variables;
-        private List<Mutable<ILogicalExpression>> expressions;
+        private final List<LogicalVariable> variables;
+        private final List<Mutable<ILogicalExpression>> expressions;
 
         public VarExprSubstitution(List<LogicalVariable> variables, List<Mutable<ILogicalExpression>> expressions) {
             this.variables = variables;
@@ -127,7 +125,7 @@ public class InlineAssignIntoAggregateRule implements IAlgebraicRewriteRule {
 
         @Override
         public Pair<Boolean, ILogicalExpression> visitConstantExpression(ConstantExpression expr, Void arg) {
-            return new Pair<Boolean, ILogicalExpression>(false, expr);
+            return new Pair<>(false, expr);
         }
 
         @Override
@@ -137,12 +135,13 @@ public class InlineAssignIntoAggregateRule implements IAlgebraicRewriteRule {
             for (Mutable<ILogicalExpression> eRef : expr.getArguments()) {
                 ILogicalExpression e = eRef.getValue();
                 Pair<Boolean, ILogicalExpression> p = e.accept(this, arg);
-                if (p.first) {
-                    eRef.setValue(p.second.cloneExpression());
+                ILogicalExpression originalExpr = p.second;
+                if (p.first & originalExpr.isFunctional()) {
+                    eRef.setValue(originalExpr.cloneExpression());
                     changed = true;
                 }
             }
-            return new Pair<Boolean, ILogicalExpression>(changed, expr);
+            return new Pair<>(changed, expr);
         }
 
         @Override
@@ -151,9 +150,9 @@ public class InlineAssignIntoAggregateRule implements IAlgebraicRewriteRule {
             LogicalVariable v = expr.getVariableReference();
             int idx = variables.indexOf(v);
             if (idx < 0) {
-                return new Pair<Boolean, ILogicalExpression>(false, expr);
+                return new Pair<>(false, expr);
             } else {
-                return new Pair<Boolean, ILogicalExpression>(true, expressions.get(idx).getValue());
+                return new Pair<>(true, expressions.get(idx).getValue());
             }
 
         }


[asterixdb] 12/14: [NO ISSUE][EXT]: Explicitly set no credentials auth when anonymous auth is used

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 64d5d66b1c7fa5acb521433cfe9d8ba4eeca754f
Author: Hussain Towaileb <Hu...@couchbase.com>
AuthorDate: Thu Jun 8 20:11:39 2023 +0300

    [NO ISSUE][EXT]: Explicitly set no credentials auth when anonymous auth is used
    
    Change-Id: Id6fc37fb53a8bc944816a782a4119feaf59db725
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17593
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Reviewed-by: Ian Maxon <im...@uci.edu>
---
 .../java/org/apache/asterix/external/util/ExternalDataUtils.java  | 8 ++++----
 1 file changed, 4 insertions(+), 4 deletions(-)

diff --git a/asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/ExternalDataUtils.java b/asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/ExternalDataUtils.java
index 29e04e9904..31444899ad 100644
--- a/asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/ExternalDataUtils.java
+++ b/asterixdb/asterix-external-data/src/main/java/org/apache/asterix/external/util/ExternalDataUtils.java
@@ -150,6 +150,7 @@ import com.azure.storage.file.datalake.models.ListPathsOptions;
 import com.azure.storage.file.datalake.models.PathItem;
 import com.google.api.gax.paging.Page;
 import com.google.auth.oauth2.GoogleCredentials;
+import com.google.cloud.NoCredentials;
 import com.google.cloud.storage.Blob;
 import com.google.cloud.storage.Storage;
 import com.google.cloud.storage.StorageOptions;
@@ -1883,15 +1884,14 @@ public class ExternalDataUtils {
                 } catch (IOException ex) {
                     throw CompilationException.create(EXTERNAL_SOURCE_ERROR, getMessageOrToString(ex));
                 }
-            }
-
-            // json credentials
-            if (jsonCredentials != null) {
+            } else if (jsonCredentials != null) {
                 try (InputStream credentialsStream = new ByteArrayInputStream(jsonCredentials.getBytes())) {
                     builder.setCredentials(GoogleCredentials.fromStream(credentialsStream));
                 } catch (IOException ex) {
                     throw new CompilationException(EXTERNAL_SOURCE_ERROR, getMessageOrToString(ex));
                 }
+            } else {
+                builder.setCredentials(NoCredentials.getInstance());
             }
 
             if (endpoint != null) {


[asterixdb] 13/14: Merge branch 'stabilization-667a908755' into neo

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit fc906750632cacc0fdf93ff63ec9e6950d5d3708
Merge: 64d5d66b1c bbe9d0344c
Author: Wail Alkowaileet <wa...@gmail.com>
AuthorDate: Fri Jun 9 11:30:01 2023 -0700

    Merge branch 'stabilization-667a908755' into neo
    
    Change-Id: Ib3fbd684f1732a276d6033bf38507df41d33b846

 .../non-pure-function.00.ddl.sqlpp                 | 30 +++++++++++++++++++++
 .../non-pure-function.01.update.sqlpp              | 24 +++++++++++++++++
 .../non-pure-function.02.query.sqlpp               | 26 ++++++++++++++++++
 .../non-pure-function.03.query.sqlpp               | 27 +++++++++++++++++++
 .../non-pure-function.04.query.sqlpp               | 28 +++++++++++++++++++
 .../non-pure-function.05.query.sqlpp               | 27 +++++++++++++++++++
 .../non-pure-function.06.query.sqlpp               | 28 +++++++++++++++++++
 .../non-pure-function/non-pure-function.02.adm     |  1 +
 .../non-pure-function/non-pure-function.03.adm     |  1 +
 .../non-pure-function/non-pure-function.04.adm     |  1 +
 .../non-pure-function/non-pure-function.05.adm     |  1 +
 .../non-pure-function/non-pure-function.06.adm     |  1 +
 .../test/resources/runtimets/testsuite_sqlpp.xml   |  5 ++++
 .../rules/InlineAssignIntoAggregateRule.java       | 31 +++++++++++-----------
 14 files changed, 215 insertions(+), 16 deletions(-)



[asterixdb] 01/14: [NO ISSUE][*DB]: Update smart-json to avoid encountered CVE

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit aedda3544b52a3b3baebbab24e63d6273c0bbc59
Author: Hussain Towaileb <Hu...@couchbase.com>
AuthorDate: Mon May 22 04:45:42 2023 +0300

    [NO ISSUE][*DB]: Update smart-json to avoid encountered CVE
    
    Details:
    - This change updates smart-json to avoid CVE-2023-1370:
      json-smart 2.4.7 -> 2.4.11
    
    Change-Id: I6cceff58ae80042c1421de4acb97dbfa3549168a
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17548
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Reviewed-by: Hussain Towaileb <hu...@gmail.com>
    Reviewed-by: Michael Blow <mb...@apache.org>
---
 asterixdb/asterix-external-data/pom.xml                    |  5 +++++
 asterixdb/asterix-server/pom.xml                           |  2 +-
 asterixdb/pom.xml                                          | 12 ++++++++++++
 .../src/main/appended-resources/supplemental-models.xml    | 14 +++++++-------
 hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml             |  4 ++++
 hyracks-fullstack/pom.xml                                  | 10 ++++++++++
 6 files changed, 39 insertions(+), 8 deletions(-)

diff --git a/asterixdb/asterix-external-data/pom.xml b/asterixdb/asterix-external-data/pom.xml
index 068e294fec..f8a4401186 100644
--- a/asterixdb/asterix-external-data/pom.xml
+++ b/asterixdb/asterix-external-data/pom.xml
@@ -546,6 +546,11 @@
       <groupId>org.eclipse.jetty</groupId>
       <artifactId>jetty-util-ajax</artifactId>
     </dependency>
+    <!-- Manually included to avoid CVE-2023-1370 -->
+    <dependency>
+      <groupId>net.minidev</groupId>
+      <artifactId>json-smart</artifactId>
+    </dependency>
   </dependencies>
   <!-- apply patch for HADOOP-17225 to workaround CVE-2019-10172 -->
   <repositories>
diff --git a/asterixdb/asterix-server/pom.xml b/asterixdb/asterix-server/pom.xml
index fb1c2f16cc..2ab0e5f2a2 100644
--- a/asterixdb/asterix-server/pom.xml
+++ b/asterixdb/asterix-server/pom.xml
@@ -309,7 +309,7 @@
               <url>https://raw.githubusercontent.com/codehaus/stax/master/dev/ASF2.0.txt</url>
             </override>
             <override>
-              <gav>org.ow2.asm:asm:9.1</gav>
+              <gav>org.ow2.asm:asm:9.3</gav>
               <url>https://raw.githubusercontent.com/llbit/ow2-asm/master/LICENSE.txt</url>
             </override>
             <override>
diff --git a/asterixdb/pom.xml b/asterixdb/pom.xml
index 45f1986569..3610b19ee9 100644
--- a/asterixdb/pom.xml
+++ b/asterixdb/pom.xml
@@ -1019,6 +1019,10 @@
         <artifactId>hadoop-common</artifactId>
         <version>${hadoop.version}</version>
         <exclusions>
+          <exclusion>
+            <groupId>net.minidev</groupId>
+            <artifactId>json-smart</artifactId>
+          </exclusion>
           <exclusion>
             <groupId>com.nimbusds</groupId>
             <artifactId>nimbus-jose-jwt</artifactId>
@@ -1111,6 +1115,10 @@
         <version>${hadoop.version}</version>
         <classifier>tests</classifier>
         <exclusions>
+          <exclusion>
+            <groupId>net.minidev</groupId>
+            <artifactId>json-smart</artifactId>
+          </exclusion>
           <exclusion>
             <groupId>com.nimbusds</groupId>
             <artifactId>nimbus-jose-jwt</artifactId>
@@ -1644,6 +1652,10 @@
         <artifactId>azure-identity</artifactId>
         <version>1.4.1</version>
         <exclusions>
+          <exclusion>
+            <groupId>net.minidev</groupId>
+            <artifactId>json-smart</artifactId>
+          </exclusion>
           <exclusion>
             <groupId>io.netty</groupId>
             <artifactId>netty-handler</artifactId>
diff --git a/asterixdb/src/main/appended-resources/supplemental-models.xml b/asterixdb/src/main/appended-resources/supplemental-models.xml
index 18508ef66a..1a97cbfef9 100644
--- a/asterixdb/src/main/appended-resources/supplemental-models.xml
+++ b/asterixdb/src/main/appended-resources/supplemental-models.xml
@@ -1090,8 +1090,8 @@
       <groupId>net.minidev</groupId>
       <artifactId>json-smart</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>2.4.7</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>2.4.7</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>2.4.11</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>2.4.11</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -1102,8 +1102,8 @@
       <groupId>net.minidev</groupId>
       <artifactId>accessors-smart</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>2.4.7</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>2.4.7</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreMissingEmbeddedLicense>2.4.11</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>2.4.11</license.ignoreMissingEmbeddedNotice>
       </properties>
     </project>
   </supplement>
@@ -1113,9 +1113,9 @@
       <groupId>org.ow2.asm</groupId>
       <artifactId>asm</artifactId>
       <properties>
-        <license.ignoreMissingEmbeddedLicense>9.1</license.ignoreMissingEmbeddedLicense>
-        <license.ignoreMissingEmbeddedNotice>9.1</license.ignoreMissingEmbeddedNotice>
-        <license.ignoreLicenseOverride>9.1</license.ignoreLicenseOverride>
+        <license.ignoreMissingEmbeddedLicense>9.3</license.ignoreMissingEmbeddedLicense>
+        <license.ignoreMissingEmbeddedNotice>9.3</license.ignoreMissingEmbeddedNotice>
+        <license.ignoreLicenseOverride>9.3</license.ignoreLicenseOverride>
       </properties>
     </project>
   </supplement>
diff --git a/hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml b/hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml
index b16904df1c..816746cfca 100644
--- a/hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml
+++ b/hyracks-fullstack/hyracks/hyracks-hdfs/pom.xml
@@ -182,6 +182,10 @@
       <classifier>tests</classifier>
       <scope>test</scope>
       <exclusions>
+        <exclusion>
+          <groupId>net.minidev</groupId>
+          <artifactId>json-smart</artifactId>
+        </exclusion>
         <exclusion>
           <groupId>log4j</groupId>
           <artifactId>log4j</artifactId>
diff --git a/hyracks-fullstack/pom.xml b/hyracks-fullstack/pom.xml
index 69a82799b5..9ef0212060 100644
--- a/hyracks-fullstack/pom.xml
+++ b/hyracks-fullstack/pom.xml
@@ -155,6 +155,10 @@
         <artifactId>hadoop-common</artifactId>
         <version>${hadoop.version}</version>
         <exclusions>
+          <exclusion>
+            <groupId>net.minidev</groupId>
+            <artifactId>json-smart</artifactId>
+          </exclusion>
           <exclusion>
             <groupId>com.nimbusds</groupId>
             <artifactId>nimbus-jose-jwt</artifactId>
@@ -472,6 +476,12 @@
         <artifactId>jetty-util-ajax</artifactId>
         <version>9.4.48.v20220622</version>
       </dependency>
+      <!-- Manually included to avoid CVE-2023-1370 -->
+      <dependency>
+        <groupId>net.minidev</groupId>
+        <artifactId>json-smart</artifactId>
+        <version>2.4.11</version>
+      </dependency>
     </dependencies>
   </dependencyManagement>
   <build>


[asterixdb] 04/14: Merge branch 'gerrit/cheshire-cat'

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit c2d6db8d30ebe13da29ca8c2a7e76791e902ae8e
Merge: aedda3544b 35c42acd3c
Author: Michael Blow <mb...@apache.org>
AuthorDate: Wed May 24 21:53:15 2023 -0400

    Merge branch 'gerrit/cheshire-cat'
    
    Change-Id: I0c0bbeae92635eb016af3e42e0b1f9c5d5743645

 asterixdb/asterix-external-data/pom.xml            |   5 +
 asterixdb/asterix-server/pom.xml                   |  24 ++--
 asterixdb/pom.xml                                  |   7 +-
 .../appended-resources/supplemental-models.xml     | 122 ++++++++++++++++-----
 ...or-java_azure-storage-blob_12.22.0_LICENSE.txt} |   0
 ...for-java_azure-storage-blob_12.22.0_NOTICE.txt} |  21 +++-
 hyracks-fullstack/pom.xml                          |   5 +
 7 files changed, 142 insertions(+), 42 deletions(-)

diff --cc asterixdb/asterix-external-data/pom.xml
index f8a4401186,21bbfb941d..c2d78199f4
--- a/asterixdb/asterix-external-data/pom.xml
+++ b/asterixdb/asterix-external-data/pom.xml
@@@ -536,27 -503,9 +537,31 @@@
        <groupId>io.netty</groupId>
        <artifactId>netty-transport-native-unix-common</artifactId>
      </dependency>
 +    <!-- TODO(htowaileb): removed from hadoop transitively and added separately to avoid CVEs, can
 +     be removed once upgraded to hadoop 3.3.4 as it addresses the CVEs -->
 +    <dependency>
 +      <groupId>org.eclipse.jetty</groupId>
 +      <artifactId>jetty-util</artifactId>
 +    </dependency>
 +    <dependency>
 +      <groupId>org.eclipse.jetty</groupId>
 +      <artifactId>jetty-util-ajax</artifactId>
 +    </dependency>
 +    <!-- Manually included to avoid CVE-2023-1370 -->
 +    <dependency>
 +      <groupId>net.minidev</groupId>
 +      <artifactId>json-smart</artifactId>
 +    </dependency>
+     <dependency>
+       <groupId>io.netty</groupId>
+       <artifactId>netty-handler-proxy</artifactId>
+     </dependency>
    </dependencies>
 +  <!-- apply patch for HADOOP-17225 to workaround CVE-2019-10172 -->
 +  <repositories>
 +    <repository>
 +      <id>atlassian-3rdparty</id>
 +      <url>https://packages.atlassian.com/maven-3rdparty/</url>
 +    </repository>
 +  </repositories>
  </project>
diff --cc asterixdb/asterix-server/pom.xml
index 2ab0e5f2a2,33ab5882c0..495b92f628
--- a/asterixdb/asterix-server/pom.xml
+++ b/asterixdb/asterix-server/pom.xml
@@@ -232,225 -216,25 +232,232 @@@
                <gav>software.amazon.eventstream:eventstream:1.0.1</gav>
                <noticeUrl>https://raw.githubusercontent.com/awslabs/aws-eventstream-java/7be2dd80e12f8835674c8ffb0f4a2efb64c7b585/NOTICE</noticeUrl>
              </override>
 +            <override>
 +              <gav>software.amazon.ion:ion-java:1.0.2</gav>
 +              <noticeUrl>https://raw.githubusercontent.com/amzn/ion-java/v1.0.2/NOTICE</noticeUrl>
 +            </override>
              <override>
                <gavs>
-                 <gav>com.azure:azure-core:1.24.1</gav>
-                 <gav>com.azure:azure-core-http-netty:1.11.6</gav>
-                 <gav>com.azure:azure-storage-blob:12.14.3</gav>
-                 <gav>com.azure:azure-storage-common:12.14.2</gav>
-                 <gav>com.azure:azure-storage-internal-avro:12.1.3</gav>
+                 <gav>com.azure:azure-core:1.38.0</gav>
+                 <gav>com.azure:azure-core-http-netty:1.13.2</gav>
+                 <gav>com.azure:azure-json:1.0.0</gav>
+                 <gav>com.azure:azure-storage-blob:12.22.0</gav>
+                 <gav>com.azure:azure-storage-common:12.21.0</gav>
+                 <gav>com.azure:azure-storage-internal-avro:12.7.0</gav>
                </gavs>
-               <!-- azure-storage-blob-batch_12.11.3 release is at 89a32290750a18d1b99c27c16b1b11d42f16c622 -->
-               <noticeUrl>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/89a32290750a18d1b99c27c16b1b11d42f16c622/NOTICE.txt</noticeUrl>
-               <url>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/89a32290750a18d1b99c27c16b1b11d42f16c622/LICENSE.txt</url>
+               <noticeUrl>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/azure-storage-blob_12.22.0/NOTICE.txt</noticeUrl>
+               <url>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/azure-storage-blob_12.22.0/LICENSE.txt</url>
+             </override>
+             <override>
+               <gavs>
+                 <gav>io.projectreactor.netty:reactor-netty-core:1.0.28</gav>
+                 <gav>io.projectreactor.netty:reactor-netty-http:1.0.28</gav>
+               </gavs>
+               <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.28/LICENSE</url>
              </override>
 +            <override>
 +              <gav>com.microsoft.azure:msal4j:1.11.0</gav>
 +              <url>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-library-for-java/v1.11.0/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.microsoft.azure:msal4j-persistence-extension:1.1.0</gav>
 +              <url>https://raw.githubusercontent.com/AzureAD/microsoft-authentication-extensions-for-java/1.1.0/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.microsoft.azure:azure-keyvault-core:1.2.4</gav>
 +              <url>https://raw.githubusercontent.com/Azure/azure-sdk-for-java/main/sdk/keyvault/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.nimbusds:nimbus-jose-jwt:9.9.3</gav>
 +              <noticeUrl>https://bitbucket.org/connect2id/nimbus-jose-jwt/raw/50ae2a39a4a6d0dcbf05572af8a581377174ac96/COPYRIGHT.txt</noticeUrl>
 +            </override>
 +            <!-- com.nimbusds:oauth2-oidc-sdk:9.7 points to https://www.apache.org/licenses/LICENSE-2.0.html in the pom.xml but has bad characters in the URI, overriding to fix -->
 +            <override>
 +              <gav>com.nimbusds:oauth2-oidc-sdk:9.7</gav>
 +              <url>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/5d13925b57ace092ea5e1131c338f464d85545f4/LICENSE.txt</url>
 +              <noticeUrl>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/5d13925b57ace092ea5e1131c338f464d85545f4/COPYRIGHT.txt</noticeUrl>
 +            </override>
 +            <override>
 +              <gav>com.nimbusds:lang-tag:1.5</gav>
 +              <noticeUrl>https://bitbucket.org/connect2id/nimbus-language-tags/raw/ead5120f62b5849309069808509b4cc6e57a0841/COPYRIGHT.txt</noticeUrl>
 +            </override>
 +            <override>
 +              <gav>com.nimbusds:content-type:2.1</gav>
 +              <noticeUrl>https://bitbucket.org/connect2id/nimbus-content-type/raw/c6d2701ed5cd57e0f88728c6f3e6303db97c5bcf/COPYRIGHT.txt</noticeUrl>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>io.projectreactor.netty:reactor-netty:1.0.7</gav>
 +                <gav>io.projectreactor.netty:reactor-netty-core:1.0.7</gav>
 +                <gav>io.projectreactor.netty:reactor-netty-http:1.0.7</gav>
 +                <gav>io.projectreactor.netty:reactor-netty-http-brave:1.0.7</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.7/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>io.projectreactor.netty:reactor-netty-core:1.0.11</gav>
 +                <gav>io.projectreactor.netty:reactor-netty-http:1.0.11</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.11/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>io.projectreactor:reactor-core:3.4.6</gav>
 +              <url>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.6/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>io.projectreactor:reactor-core:3.4.10</gav>
 +              <url>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.10/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>stax:stax-api:1.0.1</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/codehaus/stax/master/dev/ASF2.0.txt</url>
 +            </override>
 +            <override>
 +              <gav>org.ow2.asm:asm:9.3</gav>
 +              <url>https://raw.githubusercontent.com/llbit/ow2-asm/master/LICENSE.txt</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>com.google.http-client:google-http-client:1.42.3</gav>
 +                <gav>com.google.http-client:google-http-client-jackson2:1.42.3</gav>
 +                <gav>com.google.http-client:google-http-client-appengine:1.42.3</gav>
 +                <gav>com.google.http-client:google-http-client-gson:1.42.3</gav>
 +                <gav>com.google.http-client:google-http-client-apache-v2:1.42.3</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/googleapis/google-http-java-client/v1.42.3/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.oauth-client:google-oauth-client:1.34.1</gav>
 +              <url>https://raw.githubusercontent.com/googleapis/google-oauth-java-client/v1.34.1/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>com.google.protobuf:protobuf-java:3.21.12</gav>
 +                <gav>com.google.protobuf:protobuf-java-util:3.21.12</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/protocolbuffers/protobuf/v3.21.12/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>com.google.auth:google-auth-library-oauth2-http:1.14.0</gav>
 +                <gav>com.google.auth:google-auth-library-credentials:1.14.0</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/googleapis/google-auth-library-java/v1.14.0/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>com.google.cloud:google-cloud-core:2.9.4</gav>
 +                <gav>com.google.cloud:google-cloud-core-http:2.9.4</gav>
 +                <gav>com.google.cloud:google-cloud-core-grpc:2.9.4</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/googleapis/java-core/v2.9.4/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.cloud:google-cloud-storage:2.17.2</gav>
 +              <gav>com.google.api.grpc:gapic-google-cloud-storage-v2:2.17.2-alpha</gav>
 +              <gav>com.google.api.grpc:proto-google-cloud-storage-v2:2.17.2-alpha</gav>
 +              <gav>com.google.api.grpc:grpc-google-cloud-storage-v2:2.17.2-alpha</gav>
 +              <url>https://raw.githubusercontent.com/googleapis/java-storage/v2.17.2/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.api.grpc:proto-google-cloud-monitoring-v3:1.64.0</gav>
 +              <url>https://raw.githubusercontent.com/googleapis/googleapis/master/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>io.opencensus:opencensus-proto:0.2.0</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/census-instrumentation/opencensus-proto/v0.2.0/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>io.opencensus:opencensus-api:0.31.1</gav>
 +                <gav>io.opencensus:opencensus-contrib-http-util:0.31.1</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/census-instrumentation/opencensus-java/v0.31.1/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>io.opencensus:opencensus-contrib-exemplar-util:0.31.0</gav>
 +                <gav>io.opencensus:opencensus-contrib-grpc-metrics:0.31.0</gav>
 +                <gav>io.opencensus:opencensus-contrib-resource-util:0.31.0</gav>
 +                <gav>io.opencensus:opencensus-exporter-metrics-util:0.31.0</gav>
 +                <gav>io.opencensus:opencensus-exporter-stats-stackdriver:0.31.0</gav>
 +                <gav>io.opencensus:opencensus-impl-core:0.31.0</gav>
 +                <gav>io.opencensus:opencensus-impl:0.31.0</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/census-instrumentation/opencensus-java/v0.31.0/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.api-client:google-api-client:2.1.2</gav>
 +              <url>https://raw.githubusercontent.com/googleapis/google-api-java-client/v2.1.2/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.api.grpc:proto-google-iam-v1:1.8.0</gav>
 +              <gav>com.google.api.grpc:proto-google-common-protos:2.13.0</gav>
 +              <url>https://raw.githubusercontent.com/googleapis/gapic-generator-java/v2.13.0/java-common-protos/LICENSE</url>
 +            </override>
 +            <!-- api-common-java has been moved to a new repo, using the same license, for more info, see:
 +            https://github.com/googleapis/gapic-generator-java/tree/v2.13.0/api-common-java
 +            -->
 +            <override>
 +              <gav>com.google.api:api-common:2.5.0</gav>
 +              <url>https://raw.githubusercontent.com/googleapis/gapic-generator-java/v2.13.0/api-common-java/LICENSE</url>
 +            </override>
 +            <!-- gax has been moved to a new repo, using the same license, for more info, see:
 +            https://github.com/googleapis/gax-java
 +            https://github.com/googleapis/gapic-generator-java/tree/v2.13.0/gax-java
 +            -->
 +            <override>
 +              <gavs>
 +                <gav>com.google.api:gax-httpjson:0.107.0</gav>
 +                <gav>com.google.api:gax:2.22.0</gav>
 +                <gav>com.google.api:gax-grpc:2.22.0</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/googleapis/gapic-generator-java/v2.13.0/gax-java/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.auto.value:auto-value:1.10.1</gav>
 +              <gav>com.google.auto.value:auto-value-annotations:1.10.1</gav>
 +              <url>https://raw.githubusercontent.com/google/auto/auto-value-1.10.1/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.code.findbugs:jsr305:3.0.2</gav>
 +              <url>https://raw.githubusercontent.com/findbugsproject/findbugs/3.0.2_preview2/findbugs/licenses/LICENSE-jsr305.txt</url>
 +            </override>
 +            <override>
 +              <gav>com.google.code.gson:gson:2.10.1</gav>
 +              <url>https://raw.githubusercontent.com/google/gson/gson-parent-2.10.1/LICENSE</url>
 +            </override>
 +            <override>
 +              <gav>com.google.guava:listenablefuture:9999.0-empty-to-avoid-conflict-with-guava</gav>
 +              <url>https://raw.githubusercontent.com/google/guava/master/COPYING</url>
 +            </override>
 +            <override>
 +              <gav>com.google.j2objc:j2objc-annotations:1.3</gav>
 +              <url>https://raw.githubusercontent.com/google/j2objc/1.3/LICENSE</url>
 +            </override>
 +            <override>
 +              <gavs>
 +                <gav>io.grpc:grpc-alts:1.52.1</gav>
 +                <gav>io.grpc:grpc-api:1.52.1</gav>
 +                <gav>io.grpc:grpc-auth:1.52.1</gav>
 +                <gav>io.grpc:grpc-context:1.52.1</gav>
 +                <gav>io.grpc:grpc-core:1.52.1</gav>
 +                <gav>io.grpc:grpc-grpclb:1.52.1</gav>
 +                <gav>io.grpc:grpc-googleapis:1.52.1</gav>
 +                <gav>io.grpc:grpc-protobuf-lite:1.52.1</gav>
 +                <gav>io.grpc:grpc-protobuf:1.52.1</gav>
 +                <gav>io.grpc:grpc-services:1.52.1</gav>
 +                <gav>io.grpc:grpc-stub:1.52.1</gav>
 +                <gav>io.grpc:grpc-xds:1.52.1</gav>
 +              </gavs>
 +              <url>https://raw.githubusercontent.com/grpc/grpc-java/v1.52.1/LICENSE</url>
 +              <noticeUrl>https://raw.githubusercontent.com/grpc/grpc-java/v1.52.1/NOTICE.txt</noticeUrl>
 +            </override>
              <override>
                <gav>org.mindrot:jbcrypt:0.4</gav>
                <url>http://www.mindrot.org/files/jBCrypt/LICENSE</url>
@@@ -512,30 -278,7 +519,31 @@@
                  <aliasUrl>http://www.apache.org/licenses/LICENSE-2.0.html</aliasUrl>
                  <aliasUrl>https://www.apache.org/licenses/LICENSE-2.0.html</aliasUrl>
                  <aliasUrl>https://aws.amazon.com/apache2.0</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/jorabin/KeePassJava2/KeePassJava2-2.1.4/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.7/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.11/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.6/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-core/v3.4.10/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/codehaus/stax/master/dev/ASF2.0.txt</aliasUrl>
 +                <aliasUrl>https://bitbucket.org/connect2id/oauth-2.0-sdk-with-openid-connect-extensions/raw/5d13925b57ace092ea5e1131c338f464d85545f4/LICENSE.txt</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/google/auto/auto-value-1.10.1/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/google/j2objc/1.3/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/java-storage/v2.17.2/LICENSE</aliasUrl>
 +                <aliasUrl>http://repository.jboss.org/licenses/apache-2.0.txt</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/census-instrumentation/opencensus-java/v0.31.0/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/census-instrumentation/opencensus-java/v0.31.1/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/census-instrumentation/opencensus-proto/v0.2.0/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/google/conscrypt/2.5.2/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/googleapis/master/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/perfmark/perfmark/v0.26.0/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/google-http-java-client/v1.42.3/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/google-oauth-java-client/v1.34.1/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/java-core/v2.9.4/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/google/gson/gson-parent-2.10.1/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/gapic-generator-java/v2.13.0/java-common-protos/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/googleapis/google-api-java-client/v2.1.2/LICENSE</aliasUrl>
 +                <aliasUrl>https://raw.githubusercontent.com/grpc/grpc-java/v1.52.1/LICENSE</aliasUrl>
+                 <aliasUrl>https://raw.githubusercontent.com/reactor/reactor-netty/v1.0.28/LICENSE</aliasUrl>
                </aliasUrls>
                <metric>1</metric>
              </license>
diff --cc asterixdb/pom.xml
index 3610b19ee9,92f0473225..868c7eeb9b
--- a/asterixdb/pom.xml
+++ b/asterixdb/pom.xml
@@@ -88,12 -88,9 +88,13 @@@
      <jacoco.version>0.7.6.201602180812</jacoco.version>
      <log4j.version>2.19.0</log4j.version>
      <awsjavasdk.version>2.17.218</awsjavasdk.version>
 +    <parquet.version>1.12.3</parquet.version>
 +    <hadoop-awsjavasdk.version>1.12.402</hadoop-awsjavasdk.version>
-     <azureblobjavasdk.version>12.14.2</azureblobjavasdk.version>
+     <azureblobjavasdk.version>12.22.0</azureblobjavasdk.version>
+     <azurecommonjavasdk.version>12.21.0</azurecommonjavasdk.version>
 -    <parquet.version>1.8.2</parquet.version>
 +    <azuredatalakejavasdk.version>12.7.2</azuredatalakejavasdk.version>
 +    <gcsjavasdk.version>2.17.2</gcsjavasdk.version>
 +    <hadoop-azuresdk.version>8.6.6</hadoop-azuresdk.version>
  
      <implementation.title>Apache AsterixDB - ${project.name}</implementation.title>
      <implementation.url>https://asterixdb.apache.org/</implementation.url>
diff --cc asterixdb/src/main/appended-resources/supplemental-models.xml
index 1a97cbfef9,2300c925d0..ac3e63c50f
--- a/asterixdb/src/main/appended-resources/supplemental-models.xml
+++ b/asterixdb/src/main/appended-resources/supplemental-models.xml
@@@ -874,11 -755,34 +911,36 @@@
    <!-- See https://github.com/FasterXML/jackson-modules-java8 -->
    <supplement>
      <project>
 -      <groupId>com.fasterxml.jackson.datatype</groupId>
 -      <artifactId>jackson-datatype-jsr310</artifactId>
 +      <groupId>com.fasterxml.jackson.dataformat</groupId>
 +      <artifactId>jackson-dataformat-cbor</artifactId>
        <properties>
 -        <license.ignoreMissingEmbeddedNotice>2.13.5</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreMissingEmbeddedLicense>2.12.6</license.ignoreMissingEmbeddedLicense>
-         <license.ignoreMissingEmbeddedNotice>2.12.6</license.ignoreMissingEmbeddedNotice>
++        <license.ignoreMissingEmbeddedNotice>2.12.6,2.13.5</license.ignoreMissingEmbeddedNotice>
++        <license.ignoreLicenseOverride>2.12.6</license.ignoreLicenseOverride>
+       </properties>
+     </project>
+   </supplement>
+ 
+   <!-- com.fasterxml.woodstox contains embedded license but has no NOTICE -->
+   <!-- See https://github.com/FasterXML/woodstox -->
+   <supplement>
+     <project>
+       <groupId>com.fasterxml.woodstox</groupId>
+       <artifactId>woodstox-core</artifactId>
+       <properties>
+         <license.ignoreMissingEmbeddedNotice>6.4.0</license.ignoreMissingEmbeddedNotice>
+       </properties>
+     </project>
+   </supplement>
+ 
+   <!-- org.codehaus.woodstox contains embedded license but has no NOTICE -->
+   <!-- See https://github.com/FasterXML/stax2-api -->
+   <supplement>
+     <project>
+       <groupId>org.codehaus.woodstox</groupId>
+       <artifactId>stax2-api</artifactId>
+       <properties>
+         <license.ignoreMissingEmbeddedNotice>4.2.1</license.ignoreMissingEmbeddedNotice>
        </properties>
      </project>
    </supplement>
@@@ -969,1106 -869,13 +1031,1106 @@@
      </project>
    </supplement>
  
 -  <!-- io.zipkin.reporter2:zipkin-reporter-brave has embedded license but no notice -->
 +  <!-- com.nimbusds:lang-tag has ALv2 embedded in pom.xml -->
    <supplement>
      <project>
 -      <groupId>io.zipkin.reporter2</groupId>
 -      <artifactId>zipkin-reporter-brave</artifactId>
 +      <groupId>com.nimbusds</groupId>
 +      <artifactId>lang-tag</artifactId>
        <properties>
 -        <license.ignoreMissingEmbeddedNotice>2.16.3</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreMissingEmbeddedLicense>1.5</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.5</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.nimbusds:content-type has ALv2 embedded in pom.xml -->
 +  <supplement>
 +    <project>
 +      <groupId>com.nimbusds</groupId>
 +      <artifactId>content-type</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:KeePassJava2 uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>KeePassJava2</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:KeePassJava2-dom uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>KeePassJava2-dom</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:KeePassJava2-jaxb uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>KeePassJava2-jaxb</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:KeePassJava2-kdb uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>KeePassJava2-kdb</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:KeePassJava2-kdbx uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>KeePassJava2-kdbx</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:KeePassJava2-simple uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>KeePassJava2-simple</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.linguafranca.pwdb:database uses ALv2 and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.linguafranca.pwdb</groupId>
 +      <artifactId>database</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- net.minidev:json-smart has ALv2 embedded in pom.xml -->
 +  <supplement>
 +    <project>
 +      <groupId>net.minidev</groupId>
 +      <artifactId>json-smart</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.4.11</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.4.11</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- net.minidev:accessors-smart has ALv2 embedded in pom.xml -->
 +  <supplement>
 +    <project>
 +      <groupId>net.minidev</groupId>
 +      <artifactId>accessors-smart</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.4.11</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.4.11</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <supplement>
 +    <project>
 +      <groupId>org.ow2.asm</groupId>
 +      <artifactId>asm</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>9.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>9.3</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>9.3</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- GCS SDK for Java start -->
 +  <!-- com.google.api has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api</groupId>
 +      <artifactId>api-common</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.5.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.5.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.5.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api:gax-httpjson has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api</groupId>
 +      <artifactId>gax-httpjson</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.107.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.107.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.107.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api:gax has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api</groupId>
 +      <artifactId>gax</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.22.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.22.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.22.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api-client uses non-fixed ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api-client</groupId>
 +      <artifactId>google-api-client</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.1.2</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.1.2</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.1.2</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.opencensus uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>io.opencensus</groupId>
 +      <artifactId>opencensus-proto</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.2.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.2.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.2.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.android:annotations has ASLv2 <license> in pom -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.android</groupId>
 +      <artifactId>annotations</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>4.1.1.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>4.1.1.4</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.opencensus uses non-fixed ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>io.opencensus</groupId>
 +      <artifactId>opencensus-api</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.31.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.31.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.31.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.opencensus uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>io.opencensus</groupId>
 +      <artifactId>opencensus-contrib-exemplar-util</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.31.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.31.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.31.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.opencensus uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>io.opencensus</groupId>
 +      <artifactId>opencensus-contrib-grpc-metrics</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.31.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.31.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.31.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.opencensus uses non-fixed ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>io.opencensus</groupId>
 +      <artifactId>opencensus-contrib-http-util</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.31.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.31.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.31.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api.grpc uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api.grpc</groupId>
 +      <artifactId>gapic-google-cloud-storage-v2</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.17.2-alpha</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.17.2-alpha</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.17.2-alpha</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api.grpc uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api.grpc</groupId>
 +      <artifactId>grpc-google-cloud-storage-v2</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.17.2-alpha</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.17.2-alpha</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.17.2-alpha</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api.grpc uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api.grpc</groupId>
 +      <artifactId>proto-google-cloud-storage-v2</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.17.2-alpha</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.17.2-alpha</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.17.2-alpha</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.conscrypt uses ALv2 LICENSE and has a NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>org.conscrypt</groupId>
 +      <artifactId>conscrypt-openjdk-uber</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.5.2</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.5.2</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.5.2</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.perfmark uses ALv2 license -->
 +  <supplement>
 +    <project>
 +      <groupId>io.perfmark</groupId>
 +      <artifactId>perfmark-api</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>0.26.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>0.26.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>0.26.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.codehaus.mojo:animal-sniffer-annotations uses MIT license -->
 +  <supplement>
 +    <project>
 +      <groupId>org.codehaus.mojo</groupId>
 +      <artifactId>animal-sniffer-annotations</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.22</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.22</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.apis:google-api-services-iamcredentials has embedded ASLv2 in pom.xml -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.apis</groupId>
 +      <artifactId>google-api-services-iamcredentials</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>v1-rev20210326-1.32.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>v1-rev20210326-1.32.1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.apis:google-api-services-iamcredentials has embedded ASLv2 in pom.xml -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api</groupId>
 +      <artifactId>gax-grpc</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.22.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.22.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.22.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.cloud uses ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.cloud</groupId>
 +      <artifactId>google-cloud-core-grpc</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.9.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.9.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.9.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.cloud:google-cloud-core is non-fixed ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.cloud</groupId>
 +      <artifactId>google-cloud-core</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.9.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.9.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.9.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.cloud:google-cloud-core-http is non-fixed ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.cloud</groupId>
 +      <artifactId>google-cloud-core-http</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.9.4</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.9.4</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.9.4</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.auth has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.auth</groupId>
 +      <artifactId>google-auth-library-credentials</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.14.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.14.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.14.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.auth has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.auth</groupId>
 +      <artifactId>google-auth-library-oauth2-http</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.14.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.14.0</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.14.0</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-alts</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-api</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-auth</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-census</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.43.2</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.43.2</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.43.2</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-context</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-core</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-googleapis</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +        <license.ignoreNoticeOverride>1.52.1</license.ignoreNoticeOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-grpclb</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-protobuf-lite</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-protobuf</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-services</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-stub</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.grpc uses ALv2 -->
 +  <supplement>
 +    <project>
 +      <groupId>io.grpc</groupId>
 +      <artifactId>grpc-xds</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.52.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.52.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.52.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.protobuf has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.protobuf</groupId>
 +      <artifactId>protobuf-java-util</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>3.21.12</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>3.21.12</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>3.21.12</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.protobuf has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.protobuf</groupId>
 +      <artifactId>protobuf-java</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>3.21.12</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>3.21.12</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>3.21.12</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.threeten has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>org.threeten</groupId>
 +      <artifactId>threetenbp</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>1.6.5</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.http-client is ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.http-client</groupId>
 +      <artifactId>google-http-client-jackson2</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.42.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.42.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.http-client is ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.http-client</groupId>
 +      <artifactId>google-http-client</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.42.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.42.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.http-client is ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.http-client</groupId>
 +      <artifactId>google-http-client-appengine</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.42.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.42.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.http-client is ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.http-client</groupId>
 +      <artifactId>google-http-client-apache-v2</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.42.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.42.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.http-client is ALv2 with no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.http-client</groupId>
 +      <artifactId>google-http-client-gson</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.42.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.42.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.code.findbugs:jsr305 has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.code.findbugs</groupId>
 +      <artifactId>jsr305</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>3.0.2</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>3.0.2</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>3.0.2</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.code.gson:gson uses non-fixed ALv2 and has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.code.gson</groupId>
 +      <artifactId>gson</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.10.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.10.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>2.10.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.guava:listenablefuture uses non-fixed ALv2 and has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.guava</groupId>
 +      <artifactId>listenablefuture</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>9999.0-empty-to-avoid-conflict-with-guava</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>9999.0-empty-to-avoid-conflict-with-guava</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>9999.0-empty-to-avoid-conflict-with-guava</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.checkerframework:checker-qual has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>org.checkerframework</groupId>
 +      <artifactId>checker-qual</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>3.29.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.auto.value:auto-value-annotations has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.auto.value</groupId>
 +      <artifactId>auto-value</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.10.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.10.1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.auto.value:auto-value-annotations has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.auto.value</groupId>
 +      <artifactId>auto-value-annotations</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.10.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.10.1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- javax.annotation:javax.annotation-api has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>javax.annotation</groupId>
 +      <artifactId>javax.annotation-api</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.3.2</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.3.2</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.apis:google-api-services-storage has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.apis</groupId>
 +      <artifactId>google-api-services-storage</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>v1-rev20220705-2.0.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>v1-rev20220705-2.0.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.oauth-client:google-oauth-client uses non-fixed ALv2 and has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.oauth-client</groupId>
 +      <artifactId>google-oauth-client</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.34.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.34.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.34.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api.grpc:proto-google-iam-v1 has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api.grpc</groupId>
 +      <artifactId>proto-google-iam-v1</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.8.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.8.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.api.grpc:proto-google-common-protos has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.api.grpc</groupId>
 +      <artifactId>proto-google-common-protos</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.13.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.13.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.cloud:google-cloud-storage has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.cloud</groupId>
 +      <artifactId>google-cloud-storage</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.17.2</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.17.2</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.google.j2objc:j2objc-annotations has no NOTICE file -->
 +  <supplement>
 +    <project>
 +      <groupId>com.google.j2objc</groupId>
 +      <artifactId>j2objc-annotations</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +  <!-- GCS SDK for Java end -->
 +
 +  <!-- jackson-datatype-jsr contains embedded license but has no NOTICE -->
 +  <!-- See https://github.com/FasterXML/jackson-modules-java8 -->
 +  <supplement>
 +    <project>
 +      <groupId>com.fasterxml.jackson.datatype</groupId>
 +      <artifactId>jackson-datatype-jsr310</artifactId>
 +      <properties>
-         <license.ignoreMissingEmbeddedNotice>2.13.1</license.ignoreMissingEmbeddedNotice>
++        <license.ignoreMissingEmbeddedNotice>2.13.1,2.13.5</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.fasterxml.woodstox contains embedded license but has no NOTICE -->
 +  <!-- See https://github.com/FasterXML/woodstox -->
 +  <supplement>
 +    <project>
 +      <groupId>com.fasterxml.woodstox</groupId>
 +      <artifactId>woodstox-core</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>6.2.7,6.4.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.codehaus.woodstox contains embedded license but has no NOTICE -->
 +  <!-- See https://github.com/FasterXML/stax2-api -->
 +  <supplement>
 +    <project>
 +      <groupId>org.codehaus.woodstox</groupId>
 +      <artifactId>stax2-api</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>4.2.1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <supplement>
 +    <project>
 +      <groupId>stax</groupId>
 +      <artifactId>stax-api</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.0.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.0.1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.0.1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- net.java.dev.jna:jna has embedded license but no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>net.java.dev.jna</groupId>
 +      <artifactId>jna</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>5.5.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- net.java.dev.jna:jna-platform has embedded license but no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>net.java.dev.jna</groupId>
 +      <artifactId>jna-platform</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>5.6.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.zipkin2:zipkin has embedded license but no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>io.zipkin.zipkin2</groupId>
 +      <artifactId>zipkin</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>2.23.2</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.zipkin.reporter2:zipkin-reporter has embedded license but no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>io.zipkin.reporter2</groupId>
 +      <artifactId>zipkin-reporter</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>2.16.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- io.zipkin.reporter2:zipkin-reporter-brave has embedded license but no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>io.zipkin.reporter2</groupId>
 +      <artifactId>zipkin-reporter-brave</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>2.16.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.fasterxml:aalto-xml has embedded license but no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>com.fasterxml</groupId>
 +      <artifactId>aalto-xml</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>1.0.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- com.github.stephenc.jcip:jcip-annotations is ALv2 embedded in pom.xml and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>com.github.stephenc.jcip</groupId>
 +      <artifactId>jcip-annotations</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.0-1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.0-1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.jetbrains:annotations is ALv2 embedded in pom.xml and has no notice -->
 +  <supplement>
 +    <project>
 +      <groupId>org.jetbrains</groupId>
 +      <artifactId>annotations</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>15.0</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>15.0</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- org.simpleframework:simple-xml is ALv2 embedded in pom.xml -->
 +  <supplement>
 +    <project>
 +      <groupId>org.simpleframework</groupId>
 +      <artifactId>simple-xml</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>2.7.1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>2.7.1</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <supplement>
 +    <project>
 +      <groupId>com.github.luben</groupId>
 +      <artifactId>zstd-jni</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.5.0-1</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.5.0-1</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.5.0-1</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <supplement>
 +    <project>
 +      <groupId>org.slf4j</groupId>
 +      <artifactId>slf4j-reload4j</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.7.36</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.7.36</license.ignoreMissingEmbeddedNotice>
 +        <license.ignoreLicenseOverride>1.7.36</license.ignoreLicenseOverride>
 +      </properties>
 +    </project>
 +  </supplement>
 +  <!-- Apache Parquet -->
 +  <supplement>
 +    <project>
 +      <groupId>org.apache.parquet</groupId>
 +      <artifactId>parquet-format-structures</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.12.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.12.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <supplement>
 +    <project>
 +      <groupId>org.apache.parquet</groupId>
 +      <artifactId>parquet-common</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedLicense>1.12.3</license.ignoreMissingEmbeddedLicense>
 +        <license.ignoreMissingEmbeddedNotice>1.12.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- Contains embedded LICENSE but missing NOTICE -->
 +  <supplement>
 +    <project>
 +      <groupId>org.apache.parquet</groupId>
 +      <artifactId>parquet-column</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>1.12.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- Contains embedded LICENSE but missing NOTICE -->
 +  <supplement>
 +    <project>
 +      <groupId>org.apache.parquet</groupId>
 +      <artifactId>parquet-encoding</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>1.12.3</license.ignoreMissingEmbeddedNotice>
 +      </properties>
 +    </project>
 +  </supplement>
 +
 +  <!-- Contains embedded LICENSE but missing NOTICE -->
 +  <supplement>
 +    <project>
 +      <groupId>org.apache.parquet</groupId>
 +      <artifactId>parquet-hadoop</artifactId>
 +      <properties>
 +        <license.ignoreMissingEmbeddedNotice>1.12.3</license.ignoreMissingEmbeddedNotice>
        </properties>
      </project>
    </supplement>


[asterixdb] 07/14: [NO ISSUE][HYR][CFG] Support custom ranged long byte units

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 31c9ae5af22363f0a7f37f12022b4bd2aed4a812
Author: Michael Blow <mb...@apache.org>
AuthorDate: Thu Jun 1 20:04:10 2023 -0400

    [NO ISSUE][HYR][CFG] Support custom ranged long byte units
    
    Change-Id: Ib456a75dd8de5989fff87b34a7c5b7b1d4a6d9de
    Reviewed-on: https://asterix-gerrit.ics.uci.edu/c/asterixdb/+/17587
    Reviewed-by: Michael Blow <mb...@apache.org>
    Reviewed-by: Murtadha Hubail <mh...@apache.org>
    Integration-Tests: Jenkins <je...@fulliautomatix.ics.uci.edu>
    Tested-by: Jenkins <je...@fulliautomatix.ics.uci.edu>
---
 .../java/org/apache/hyracks/control/common/config/OptionTypes.java    | 4 ++++
 1 file changed, 4 insertions(+)

diff --git a/hyracks-fullstack/hyracks/hyracks-control/hyracks-control-common/src/main/java/org/apache/hyracks/control/common/config/OptionTypes.java b/hyracks-fullstack/hyracks/hyracks-control/hyracks-control-common/src/main/java/org/apache/hyracks/control/common/config/OptionTypes.java
index d4c17e47b3..5970abb4c4 100644
--- a/hyracks-fullstack/hyracks/hyracks-control/hyracks-control-common/src/main/java/org/apache/hyracks/control/common/config/OptionTypes.java
+++ b/hyracks-fullstack/hyracks/hyracks-control/hyracks-control-common/src/main/java/org/apache/hyracks/control/common/config/OptionTypes.java
@@ -431,4 +431,8 @@ public class OptionTypes {
             node.put(fieldName, (long) value);
         }
     }
+
+    public static final IOptionType<Long> getRangedLongByteUnit(long min, long max) {
+        return new LongByteUnit(min, max);
+    }
 }


[asterixdb] 10/14: Merge branch 'gerrit/stabilization-667a908755'

Posted by mb...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

mblow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/asterixdb.git

commit 025ed62f64ddc1e5b22360f434c142d2139680e5
Merge: 1b053f3abe 5b13c7979d
Author: Murtadha Hubail <mh...@apache.org>
AuthorDate: Tue Jun 6 14:34:33 2023 +0300

    Merge branch 'gerrit/stabilization-667a908755'
    
    Change-Id: I0bd971a2d2885218746906c16dd32a24d033309d

 .../http/server/QueryServiceRequestParameters.java |  2 ++
 .../request-param/request-param.003.query.sqlpp    | 24 ++++++++++++++++++++++
 .../api/request-param/request-param.003.adm        |  2 ++
 3 files changed, 28 insertions(+)