123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476 |
- /*
- * Copyright Elasticsearch B.V. and/or licensed to Elasticsearch B.V. under one
- * or more contributor license agreements. Licensed under the "Elastic License
- * 2.0", the "GNU Affero General Public License v3.0 only", and the "Server Side
- * Public License v 1"; you may not use this file except in compliance with, at
- * your election, the "Elastic License 2.0", the "GNU Affero General Public
- * License v3.0 only", or the "Server Side Public License, v 1".
- */
- import org.elasticsearch.plugins.internal.RestExtension;
- /** The Elasticsearch Server Module. */
- module org.elasticsearch.server {
- requires java.logging;
- requires java.security.jgss;
- requires java.sql;
- requires java.management;
- requires jdk.unsupported;
- requires java.net.http; // required by ingest-geoip's dependency maxmind.geoip2 https://github.com/elastic/elasticsearch/issues/93553
- requires org.elasticsearch.cli;
- requires org.elasticsearch.base;
- requires org.elasticsearch.nativeaccess;
- requires org.elasticsearch.geo;
- requires org.elasticsearch.lz4;
- requires org.elasticsearch.securesm;
- requires org.elasticsearch.xcontent;
- requires org.elasticsearch.logging;
- requires org.elasticsearch.plugin;
- requires org.elasticsearch.plugin.analysis;
- requires org.elasticsearch.grok;
- requires org.elasticsearch.tdigest;
- requires org.elasticsearch.simdvec;
- requires org.elasticsearch.entitlement;
- requires hppc;
- requires HdrHistogram;
- requires jopt.simple;
- requires log4j2.ecs.layout;
- requires org.lz4.java;
- requires org.apache.logging.log4j;
- requires org.apache.logging.log4j.core;
- requires org.apache.lucene.analysis.common;
- requires org.apache.lucene.backward_codecs;
- requires org.apache.lucene.core;
- requires org.apache.lucene.grouping;
- requires org.apache.lucene.highlighter;
- requires org.apache.lucene.join;
- requires org.apache.lucene.memory;
- requires org.apache.lucene.misc;
- requires org.apache.lucene.queries;
- requires org.apache.lucene.queryparser;
- requires org.apache.lucene.sandbox;
- requires org.apache.lucene.suggest;
- exports org.elasticsearch;
- exports org.elasticsearch.action;
- exports org.elasticsearch.action.admin.cluster.allocation;
- exports org.elasticsearch.action.admin.cluster.configuration;
- exports org.elasticsearch.action.admin.cluster.coordination;
- exports org.elasticsearch.action.admin.cluster.desirednodes;
- exports org.elasticsearch.action.admin.cluster.health;
- exports org.elasticsearch.action.admin.cluster.migration;
- exports org.elasticsearch.action.admin.cluster.node.capabilities;
- exports org.elasticsearch.action.admin.cluster.node.hotthreads;
- exports org.elasticsearch.action.admin.cluster.node.info;
- exports org.elasticsearch.action.admin.cluster.node.reload;
- exports org.elasticsearch.action.admin.cluster.node.shutdown;
- exports org.elasticsearch.action.admin.cluster.node.stats;
- exports org.elasticsearch.action.admin.cluster.node.tasks.cancel;
- exports org.elasticsearch.action.admin.cluster.node.tasks.get;
- exports org.elasticsearch.action.admin.cluster.node.tasks.list;
- exports org.elasticsearch.action.admin.cluster.node.usage;
- exports org.elasticsearch.action.admin.cluster.remote;
- exports org.elasticsearch.action.admin.cluster.repositories.cleanup;
- exports org.elasticsearch.action.admin.cluster.repositories.delete;
- exports org.elasticsearch.action.admin.cluster.repositories.get;
- exports org.elasticsearch.action.admin.cluster.repositories.put;
- exports org.elasticsearch.action.admin.cluster.repositories.verify;
- exports org.elasticsearch.action.admin.cluster.reroute;
- exports org.elasticsearch.action.admin.cluster.settings;
- exports org.elasticsearch.action.admin.cluster.shards;
- exports org.elasticsearch.action.admin.cluster.snapshots.clone;
- exports org.elasticsearch.action.admin.cluster.snapshots.create;
- exports org.elasticsearch.action.admin.cluster.snapshots.delete;
- exports org.elasticsearch.action.admin.cluster.snapshots.features;
- exports org.elasticsearch.action.admin.cluster.snapshots.get;
- exports org.elasticsearch.action.admin.cluster.snapshots.get.shard;
- exports org.elasticsearch.action.admin.cluster.snapshots.restore;
- exports org.elasticsearch.action.admin.cluster.snapshots.status;
- exports org.elasticsearch.action.admin.cluster.state;
- exports org.elasticsearch.action.admin.cluster.stats;
- exports org.elasticsearch.action.admin.cluster.storedscripts;
- exports org.elasticsearch.action.admin.cluster.tasks;
- exports org.elasticsearch.action.admin.indices.alias;
- exports org.elasticsearch.action.admin.indices.alias.get;
- exports org.elasticsearch.action.admin.indices.analyze;
- exports org.elasticsearch.action.admin.indices.cache.clear;
- exports org.elasticsearch.action.admin.indices.close;
- exports org.elasticsearch.action.admin.indices.create;
- exports org.elasticsearch.action.admin.indices.dangling;
- exports org.elasticsearch.action.admin.indices.dangling.delete;
- exports org.elasticsearch.action.admin.indices.dangling.find;
- exports org.elasticsearch.action.admin.indices.dangling.import_index;
- exports org.elasticsearch.action.admin.indices.dangling.list;
- exports org.elasticsearch.action.admin.indices.delete;
- exports org.elasticsearch.action.admin.indices.diskusage;
- exports org.elasticsearch.action.admin.indices.flush;
- exports org.elasticsearch.action.admin.indices.forcemerge;
- exports org.elasticsearch.action.admin.indices.get;
- exports org.elasticsearch.action.admin.indices.mapping.get;
- exports org.elasticsearch.action.admin.indices.mapping.put;
- exports org.elasticsearch.action.admin.indices.open;
- exports org.elasticsearch.action.admin.indices.readonly;
- exports org.elasticsearch.action.admin.indices.recovery;
- exports org.elasticsearch.action.admin.indices.refresh;
- exports org.elasticsearch.action.admin.indices.resolve;
- exports org.elasticsearch.action.admin.indices.rollover;
- exports org.elasticsearch.action.admin.indices.segments;
- exports org.elasticsearch.action.admin.indices.settings.get;
- exports org.elasticsearch.action.admin.indices.settings.put;
- exports org.elasticsearch.action.admin.indices.shards;
- exports org.elasticsearch.action.admin.indices.shrink;
- exports org.elasticsearch.action.admin.indices.stats;
- exports org.elasticsearch.action.admin.indices.template.delete;
- exports org.elasticsearch.action.admin.indices.template.get;
- exports org.elasticsearch.action.admin.indices.template.post;
- exports org.elasticsearch.action.admin.indices.template.put;
- exports org.elasticsearch.action.admin.indices.validate.query;
- exports org.elasticsearch.action.bulk;
- exports org.elasticsearch.action.datastreams;
- exports org.elasticsearch.action.delete;
- exports org.elasticsearch.action.explain;
- exports org.elasticsearch.action.fieldcaps;
- exports org.elasticsearch.action.get;
- exports org.elasticsearch.action.index;
- exports org.elasticsearch.action.ingest;
- exports org.elasticsearch.action.resync;
- exports org.elasticsearch.action.search;
- exports org.elasticsearch.action.support;
- exports org.elasticsearch.action.support.broadcast;
- exports org.elasticsearch.action.support.broadcast.node;
- exports org.elasticsearch.action.support.broadcast.unpromotable;
- exports org.elasticsearch.action.support.master;
- exports org.elasticsearch.action.support.master.info;
- exports org.elasticsearch.action.support.nodes;
- exports org.elasticsearch.action.support.replication;
- exports org.elasticsearch.action.support.single.instance;
- exports org.elasticsearch.action.support.single.shard;
- exports org.elasticsearch.action.support.tasks;
- exports org.elasticsearch.action.termvectors;
- exports org.elasticsearch.action.update;
- exports org.elasticsearch.bootstrap;
- exports org.elasticsearch.client.internal;
- exports org.elasticsearch.client.internal.node;
- exports org.elasticsearch.client.internal.support;
- exports org.elasticsearch.client.internal.transport;
- exports org.elasticsearch.cluster;
- exports org.elasticsearch.cluster.action.index;
- exports org.elasticsearch.cluster.action.shard;
- exports org.elasticsearch.cluster.block;
- exports org.elasticsearch.cluster.coordination;
- exports org.elasticsearch.cluster.coordination.stateless;
- exports org.elasticsearch.cluster.health;
- exports org.elasticsearch.cluster.metadata;
- exports org.elasticsearch.cluster.node;
- exports org.elasticsearch.cluster.routing;
- exports org.elasticsearch.cluster.routing.allocation;
- exports org.elasticsearch.cluster.routing.allocation.allocator;
- exports org.elasticsearch.cluster.routing.allocation.command;
- exports org.elasticsearch.cluster.routing.allocation.decider;
- exports org.elasticsearch.cluster.service;
- exports org.elasticsearch.cluster.version;
- exports org.elasticsearch.common;
- exports org.elasticsearch.common.blobstore;
- exports org.elasticsearch.common.blobstore.fs;
- exports org.elasticsearch.common.blobstore.support;
- exports org.elasticsearch.common.breaker;
- exports org.elasticsearch.common.bytes;
- exports org.elasticsearch.common.cache;
- exports org.elasticsearch.common.cli;
- exports org.elasticsearch.common.collect;
- exports org.elasticsearch.common.component;
- exports org.elasticsearch.common.compress;
- exports org.elasticsearch.common.document;
- exports org.elasticsearch.common.file;
- exports org.elasticsearch.common.geo;
- exports org.elasticsearch.common.hash;
- exports org.elasticsearch.injection.api;
- exports org.elasticsearch.injection.guice;
- exports org.elasticsearch.injection.guice.binder;
- exports org.elasticsearch.injection.guice.internal;
- exports org.elasticsearch.injection.guice.matcher;
- exports org.elasticsearch.injection.guice.multibindings;
- exports org.elasticsearch.injection.guice.name;
- exports org.elasticsearch.injection.guice.spi;
- exports org.elasticsearch.injection.guice.util;
- exports org.elasticsearch.common.io;
- exports org.elasticsearch.common.io.stream;
- exports org.elasticsearch.common.logging;
- exports org.elasticsearch.common.lucene;
- exports org.elasticsearch.common.lucene.index;
- exports org.elasticsearch.common.lucene.search;
- exports org.elasticsearch.common.lucene.search.function;
- exports org.elasticsearch.common.lucene.store;
- exports org.elasticsearch.common.lucene.uid;
- exports org.elasticsearch.common.metrics;
- exports org.elasticsearch.common.network;
- exports org.elasticsearch.common.path;
- exports org.elasticsearch.common.recycler;
- exports org.elasticsearch.common.regex;
- exports org.elasticsearch.common.scheduler;
- exports org.elasticsearch.common.settings;
- exports org.elasticsearch.common.text;
- exports org.elasticsearch.common.time;
- exports org.elasticsearch.common.transport;
- exports org.elasticsearch.common.unit;
- exports org.elasticsearch.common.util;
- exports org.elasticsearch.common.util.concurrent;
- exports org.elasticsearch.common.util.iterable;
- exports org.elasticsearch.common.util.set;
- exports org.elasticsearch.common.xcontent;
- exports org.elasticsearch.common.xcontent.support;
- exports org.elasticsearch.discovery;
- exports org.elasticsearch.env;
- exports org.elasticsearch.features;
- exports org.elasticsearch.gateway;
- exports org.elasticsearch.health;
- exports org.elasticsearch.health.node;
- exports org.elasticsearch.health.node.tracker;
- exports org.elasticsearch.health.node.selection;
- exports org.elasticsearch.health.stats;
- exports org.elasticsearch.http;
- exports org.elasticsearch.index;
- exports org.elasticsearch.index.analysis;
- exports org.elasticsearch.index.bulk.stats;
- exports org.elasticsearch.index.cache;
- exports org.elasticsearch.index.cache.bitset;
- exports org.elasticsearch.index.cache.query;
- exports org.elasticsearch.index.cache.request;
- exports org.elasticsearch.index.codec;
- exports org.elasticsearch.index.codec.tsdb;
- exports org.elasticsearch.index.codec.bloomfilter;
- exports org.elasticsearch.index.codec.zstd;
- exports org.elasticsearch.index.engine;
- exports org.elasticsearch.index.fielddata;
- exports org.elasticsearch.index.fielddata.fieldcomparator;
- exports org.elasticsearch.index.fielddata.ordinals;
- exports org.elasticsearch.index.fielddata.plain;
- exports org.elasticsearch.index.fieldvisitor;
- exports org.elasticsearch.index.flush;
- exports org.elasticsearch.index.get;
- exports org.elasticsearch.index.mapper;
- exports org.elasticsearch.index.mapper.flattened;
- exports org.elasticsearch.index.mapper.vectors;
- exports org.elasticsearch.index.merge;
- exports org.elasticsearch.index.query;
- exports org.elasticsearch.index.query.functionscore;
- exports org.elasticsearch.index.query.support;
- exports org.elasticsearch.index.recovery;
- exports org.elasticsearch.index.refresh;
- exports org.elasticsearch.index.reindex;
- exports org.elasticsearch.index.search;
- exports org.elasticsearch.index.search.stats;
- exports org.elasticsearch.index.seqno;
- exports org.elasticsearch.index.shard;
- exports org.elasticsearch.index.similarity;
- exports org.elasticsearch.index.snapshots;
- exports org.elasticsearch.index.snapshots.blobstore;
- exports org.elasticsearch.index.stats;
- exports org.elasticsearch.index.store;
- exports org.elasticsearch.index.termvectors;
- exports org.elasticsearch.index.translog;
- exports org.elasticsearch.index.warmer;
- exports org.elasticsearch.indices;
- exports org.elasticsearch.indices.analysis;
- exports org.elasticsearch.indices.breaker;
- exports org.elasticsearch.indices.cluster;
- exports org.elasticsearch.indices.fielddata.cache;
- exports org.elasticsearch.indices.recovery;
- exports org.elasticsearch.indices.recovery.plan;
- exports org.elasticsearch.indices.store;
- exports org.elasticsearch.inference;
- exports org.elasticsearch.ingest;
- exports org.elasticsearch.internal
- to
- org.elasticsearch.serverless.version,
- org.elasticsearch.serverless.buildinfo,
- org.elasticsearch.serverless.constants;
- exports org.elasticsearch.lucene.analysis.miscellaneous;
- exports org.elasticsearch.lucene.grouping;
- exports org.elasticsearch.lucene.queries;
- exports org.elasticsearch.lucene.search.uhighlight;
- exports org.elasticsearch.lucene.search.vectorhighlight;
- exports org.elasticsearch.lucene.similarity;
- exports org.elasticsearch.lucene.util;
- exports org.elasticsearch.monitor;
- exports org.elasticsearch.monitor.fs;
- exports org.elasticsearch.monitor.jvm;
- exports org.elasticsearch.monitor.os;
- exports org.elasticsearch.monitor.process;
- exports org.elasticsearch.node;
- exports org.elasticsearch.node.internal to org.elasticsearch.internal.sigterm;
- exports org.elasticsearch.persistent;
- exports org.elasticsearch.persistent.decider;
- exports org.elasticsearch.plugins;
- exports org.elasticsearch.plugins.interceptor to org.elasticsearch.security, org.elasticsearch.serverless.rest;
- exports org.elasticsearch.plugins.spi;
- exports org.elasticsearch.repositories;
- exports org.elasticsearch.repositories.blobstore;
- exports org.elasticsearch.repositories.fs;
- exports org.elasticsearch.reservedstate;
- exports org.elasticsearch.rest;
- exports org.elasticsearch.rest.action;
- exports org.elasticsearch.rest.action.admin.cluster;
- exports org.elasticsearch.rest.action.admin.cluster.dangling;
- exports org.elasticsearch.rest.action.admin.indices;
- exports org.elasticsearch.rest.action.cat;
- exports org.elasticsearch.rest.action.document;
- exports org.elasticsearch.rest.action.ingest;
- exports org.elasticsearch.rest.action.search;
- exports org.elasticsearch.script;
- exports org.elasticsearch.script.field;
- exports org.elasticsearch.script.field.vectors;
- exports org.elasticsearch.search;
- exports org.elasticsearch.search.aggregations;
- exports org.elasticsearch.search.aggregations.bucket;
- exports org.elasticsearch.search.aggregations.bucket.composite;
- exports org.elasticsearch.search.aggregations.bucket.countedterms;
- exports org.elasticsearch.search.aggregations.bucket.filter;
- exports org.elasticsearch.search.aggregations.bucket.geogrid;
- exports org.elasticsearch.search.aggregations.bucket.global;
- exports org.elasticsearch.search.aggregations.bucket.histogram;
- exports org.elasticsearch.search.aggregations.bucket.missing;
- exports org.elasticsearch.search.aggregations.bucket.nested;
- exports org.elasticsearch.search.aggregations.bucket.range;
- exports org.elasticsearch.search.aggregations.bucket.sampler;
- exports org.elasticsearch.search.aggregations.bucket.sampler.random;
- exports org.elasticsearch.search.aggregations.bucket.terms;
- exports org.elasticsearch.search.aggregations.bucket.terms.heuristic;
- exports org.elasticsearch.search.aggregations.metrics;
- exports org.elasticsearch.search.aggregations.pipeline;
- exports org.elasticsearch.search.aggregations.support;
- exports org.elasticsearch.search.aggregations.support.values;
- exports org.elasticsearch.search.builder;
- exports org.elasticsearch.search.collapse;
- exports org.elasticsearch.search.dfs;
- exports org.elasticsearch.search.fetch;
- exports org.elasticsearch.search.fetch.subphase;
- exports org.elasticsearch.search.fetch.subphase.highlight;
- exports org.elasticsearch.search.internal;
- exports org.elasticsearch.search.lookup;
- exports org.elasticsearch.search.profile;
- exports org.elasticsearch.search.profile.aggregation;
- exports org.elasticsearch.search.profile.dfs;
- exports org.elasticsearch.search.profile.query;
- exports org.elasticsearch.search.query;
- exports org.elasticsearch.search.rank;
- exports org.elasticsearch.search.rank.context;
- exports org.elasticsearch.search.rank.feature;
- exports org.elasticsearch.search.rank.rerank;
- exports org.elasticsearch.search.rescore;
- exports org.elasticsearch.search.retriever;
- exports org.elasticsearch.search.retriever.rankdoc;
- exports org.elasticsearch.search.runtime;
- exports org.elasticsearch.search.searchafter;
- exports org.elasticsearch.search.slice;
- exports org.elasticsearch.search.sort;
- exports org.elasticsearch.search.suggest;
- exports org.elasticsearch.search.suggest.completion;
- exports org.elasticsearch.search.suggest.completion.context;
- exports org.elasticsearch.search.suggest.phrase;
- exports org.elasticsearch.search.suggest.term;
- exports org.elasticsearch.search.vectors;
- exports org.elasticsearch.shutdown;
- exports org.elasticsearch.snapshots;
- exports org.elasticsearch.synonyms;
- exports org.elasticsearch.tasks;
- exports org.elasticsearch.threadpool;
- exports org.elasticsearch.transport;
- exports org.elasticsearch.upgrades;
- exports org.elasticsearch.usage;
- exports org.elasticsearch.watcher;
- opens org.elasticsearch.common.logging to org.apache.logging.log4j.core;
- exports org.elasticsearch.action.datastreams.lifecycle;
- exports org.elasticsearch.action.datastreams.autosharding;
- exports org.elasticsearch.action.downsample;
- exports org.elasticsearch.plugins.internal
- to
- org.elasticsearch.metering,
- org.elasticsearch.stateless,
- org.elasticsearch.settings.secure,
- org.elasticsearch.serverless.constants,
- org.elasticsearch.serverless.apifiltering,
- org.elasticsearch.internal.security;
- exports org.elasticsearch.telemetry.tracing;
- exports org.elasticsearch.telemetry;
- exports org.elasticsearch.telemetry.metric;
- provides java.util.spi.CalendarDataProvider with org.elasticsearch.common.time.IsoCalendarDataProvider;
- provides org.elasticsearch.xcontent.ErrorOnUnknown with org.elasticsearch.common.xcontent.SuggestingErrorOnUnknown;
- provides org.elasticsearch.xcontent.XContentBuilderExtension with org.elasticsearch.common.xcontent.XContentElasticsearchExtension;
- provides org.elasticsearch.cli.CliToolProvider
- with
- org.elasticsearch.cluster.coordination.NodeToolCliProvider,
- org.elasticsearch.index.shard.ShardToolCliProvider;
- uses org.elasticsearch.reservedstate.ReservedClusterStateHandlerProvider;
- uses org.elasticsearch.jdk.ModuleQualifiedExportsService;
- uses org.elasticsearch.node.internal.TerminationHandlerProvider;
- uses org.elasticsearch.internal.VersionExtension;
- uses org.elasticsearch.internal.BuildExtension;
- uses org.elasticsearch.features.FeatureSpecification;
- uses org.elasticsearch.plugins.internal.LoggingDataProvider;
- provides org.elasticsearch.features.FeatureSpecification
- with
- org.elasticsearch.action.bulk.BulkFeatures,
- org.elasticsearch.features.FeatureInfrastructureFeatures,
- org.elasticsearch.health.HealthFeatures,
- org.elasticsearch.cluster.service.TransportFeatures,
- org.elasticsearch.cluster.metadata.MetadataFeatures,
- org.elasticsearch.rest.RestFeatures,
- org.elasticsearch.indices.IndicesFeatures,
- org.elasticsearch.repositories.RepositoriesFeatures,
- org.elasticsearch.action.admin.cluster.allocation.AllocationStatsFeatures,
- org.elasticsearch.index.mapper.MapperFeatures,
- org.elasticsearch.ingest.IngestGeoIpFeatures,
- org.elasticsearch.search.SearchFeatures,
- org.elasticsearch.script.ScriptFeatures,
- org.elasticsearch.search.retriever.RetrieversFeatures,
- org.elasticsearch.reservedstate.service.FileSettingsFeatures,
- org.elasticsearch.action.admin.cluster.stats.ClusterStatsFeatures;
- uses org.elasticsearch.plugins.internal.SettingsExtension;
- uses RestExtension;
- uses org.elasticsearch.action.admin.cluster.node.info.ComponentVersionNumber;
- provides org.apache.lucene.codecs.PostingsFormat
- with
- org.elasticsearch.index.codec.bloomfilter.ES85BloomFilterPostingsFormat,
- org.elasticsearch.index.codec.bloomfilter.ES87BloomFilterPostingsFormat,
- org.elasticsearch.index.codec.postings.ES812PostingsFormat;
- provides org.apache.lucene.codecs.DocValuesFormat with org.elasticsearch.index.codec.tsdb.ES87TSDBDocValuesFormat;
- provides org.apache.lucene.codecs.KnnVectorsFormat
- with
- org.elasticsearch.index.codec.vectors.ES813FlatVectorFormat,
- org.elasticsearch.index.codec.vectors.ES813Int8FlatVectorFormat,
- org.elasticsearch.index.codec.vectors.ES814HnswScalarQuantizedVectorsFormat,
- org.elasticsearch.index.codec.vectors.ES815HnswBitVectorsFormat,
- org.elasticsearch.index.codec.vectors.ES815BitFlatVectorFormat,
- org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsFormat,
- org.elasticsearch.index.codec.vectors.ES816HnswBinaryQuantizedVectorsFormat;
- provides org.apache.lucene.codecs.Codec
- with
- org.elasticsearch.index.codec.Elasticsearch814Codec,
- org.elasticsearch.index.codec.Elasticsearch816Codec;
- provides org.apache.logging.log4j.core.util.ContextDataProvider with org.elasticsearch.common.logging.DynamicContextDataProvider;
- exports org.elasticsearch.cluster.routing.allocation.shards
- to
- org.elasticsearch.shardhealth,
- org.elasticsearch.serverless.shardhealth,
- org.elasticsearch.serverless.apifiltering;
- exports org.elasticsearch.lucene.spatial;
- exports org.elasticsearch.inference.configuration;
- exports org.elasticsearch.monitor.metrics;
- }
|