1
0

module-info.java 24 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476
  1. /*
  2. * Copyright Elasticsearch B.V. and/or licensed to Elasticsearch B.V. under one
  3. * or more contributor license agreements. Licensed under the "Elastic License
  4. * 2.0", the "GNU Affero General Public License v3.0 only", and the "Server Side
  5. * Public License v 1"; you may not use this file except in compliance with, at
  6. * your election, the "Elastic License 2.0", the "GNU Affero General Public
  7. * License v3.0 only", or the "Server Side Public License, v 1".
  8. */
  9. import org.elasticsearch.plugins.internal.RestExtension;
  10. /** The Elasticsearch Server Module. */
  11. module org.elasticsearch.server {
  12. requires java.logging;
  13. requires java.security.jgss;
  14. requires java.sql;
  15. requires java.management;
  16. requires jdk.unsupported;
  17. requires java.net.http; // required by ingest-geoip's dependency maxmind.geoip2 https://github.com/elastic/elasticsearch/issues/93553
  18. requires org.elasticsearch.cli;
  19. requires org.elasticsearch.base;
  20. requires org.elasticsearch.nativeaccess;
  21. requires org.elasticsearch.geo;
  22. requires org.elasticsearch.lz4;
  23. requires org.elasticsearch.securesm;
  24. requires org.elasticsearch.xcontent;
  25. requires org.elasticsearch.logging;
  26. requires org.elasticsearch.plugin;
  27. requires org.elasticsearch.plugin.analysis;
  28. requires org.elasticsearch.grok;
  29. requires org.elasticsearch.tdigest;
  30. requires org.elasticsearch.simdvec;
  31. requires org.elasticsearch.entitlement;
  32. requires hppc;
  33. requires HdrHistogram;
  34. requires jopt.simple;
  35. requires log4j2.ecs.layout;
  36. requires org.lz4.java;
  37. requires org.apache.logging.log4j;
  38. requires org.apache.logging.log4j.core;
  39. requires org.apache.lucene.analysis.common;
  40. requires org.apache.lucene.backward_codecs;
  41. requires org.apache.lucene.core;
  42. requires org.apache.lucene.grouping;
  43. requires org.apache.lucene.highlighter;
  44. requires org.apache.lucene.join;
  45. requires org.apache.lucene.memory;
  46. requires org.apache.lucene.misc;
  47. requires org.apache.lucene.queries;
  48. requires org.apache.lucene.queryparser;
  49. requires org.apache.lucene.sandbox;
  50. requires org.apache.lucene.suggest;
  51. exports org.elasticsearch;
  52. exports org.elasticsearch.action;
  53. exports org.elasticsearch.action.admin.cluster.allocation;
  54. exports org.elasticsearch.action.admin.cluster.configuration;
  55. exports org.elasticsearch.action.admin.cluster.coordination;
  56. exports org.elasticsearch.action.admin.cluster.desirednodes;
  57. exports org.elasticsearch.action.admin.cluster.health;
  58. exports org.elasticsearch.action.admin.cluster.migration;
  59. exports org.elasticsearch.action.admin.cluster.node.capabilities;
  60. exports org.elasticsearch.action.admin.cluster.node.hotthreads;
  61. exports org.elasticsearch.action.admin.cluster.node.info;
  62. exports org.elasticsearch.action.admin.cluster.node.reload;
  63. exports org.elasticsearch.action.admin.cluster.node.shutdown;
  64. exports org.elasticsearch.action.admin.cluster.node.stats;
  65. exports org.elasticsearch.action.admin.cluster.node.tasks.cancel;
  66. exports org.elasticsearch.action.admin.cluster.node.tasks.get;
  67. exports org.elasticsearch.action.admin.cluster.node.tasks.list;
  68. exports org.elasticsearch.action.admin.cluster.node.usage;
  69. exports org.elasticsearch.action.admin.cluster.remote;
  70. exports org.elasticsearch.action.admin.cluster.repositories.cleanup;
  71. exports org.elasticsearch.action.admin.cluster.repositories.delete;
  72. exports org.elasticsearch.action.admin.cluster.repositories.get;
  73. exports org.elasticsearch.action.admin.cluster.repositories.put;
  74. exports org.elasticsearch.action.admin.cluster.repositories.verify;
  75. exports org.elasticsearch.action.admin.cluster.reroute;
  76. exports org.elasticsearch.action.admin.cluster.settings;
  77. exports org.elasticsearch.action.admin.cluster.shards;
  78. exports org.elasticsearch.action.admin.cluster.snapshots.clone;
  79. exports org.elasticsearch.action.admin.cluster.snapshots.create;
  80. exports org.elasticsearch.action.admin.cluster.snapshots.delete;
  81. exports org.elasticsearch.action.admin.cluster.snapshots.features;
  82. exports org.elasticsearch.action.admin.cluster.snapshots.get;
  83. exports org.elasticsearch.action.admin.cluster.snapshots.get.shard;
  84. exports org.elasticsearch.action.admin.cluster.snapshots.restore;
  85. exports org.elasticsearch.action.admin.cluster.snapshots.status;
  86. exports org.elasticsearch.action.admin.cluster.state;
  87. exports org.elasticsearch.action.admin.cluster.stats;
  88. exports org.elasticsearch.action.admin.cluster.storedscripts;
  89. exports org.elasticsearch.action.admin.cluster.tasks;
  90. exports org.elasticsearch.action.admin.indices.alias;
  91. exports org.elasticsearch.action.admin.indices.alias.get;
  92. exports org.elasticsearch.action.admin.indices.analyze;
  93. exports org.elasticsearch.action.admin.indices.cache.clear;
  94. exports org.elasticsearch.action.admin.indices.close;
  95. exports org.elasticsearch.action.admin.indices.create;
  96. exports org.elasticsearch.action.admin.indices.dangling;
  97. exports org.elasticsearch.action.admin.indices.dangling.delete;
  98. exports org.elasticsearch.action.admin.indices.dangling.find;
  99. exports org.elasticsearch.action.admin.indices.dangling.import_index;
  100. exports org.elasticsearch.action.admin.indices.dangling.list;
  101. exports org.elasticsearch.action.admin.indices.delete;
  102. exports org.elasticsearch.action.admin.indices.diskusage;
  103. exports org.elasticsearch.action.admin.indices.flush;
  104. exports org.elasticsearch.action.admin.indices.forcemerge;
  105. exports org.elasticsearch.action.admin.indices.get;
  106. exports org.elasticsearch.action.admin.indices.mapping.get;
  107. exports org.elasticsearch.action.admin.indices.mapping.put;
  108. exports org.elasticsearch.action.admin.indices.open;
  109. exports org.elasticsearch.action.admin.indices.readonly;
  110. exports org.elasticsearch.action.admin.indices.recovery;
  111. exports org.elasticsearch.action.admin.indices.refresh;
  112. exports org.elasticsearch.action.admin.indices.resolve;
  113. exports org.elasticsearch.action.admin.indices.rollover;
  114. exports org.elasticsearch.action.admin.indices.segments;
  115. exports org.elasticsearch.action.admin.indices.settings.get;
  116. exports org.elasticsearch.action.admin.indices.settings.put;
  117. exports org.elasticsearch.action.admin.indices.shards;
  118. exports org.elasticsearch.action.admin.indices.shrink;
  119. exports org.elasticsearch.action.admin.indices.stats;
  120. exports org.elasticsearch.action.admin.indices.template.delete;
  121. exports org.elasticsearch.action.admin.indices.template.get;
  122. exports org.elasticsearch.action.admin.indices.template.post;
  123. exports org.elasticsearch.action.admin.indices.template.put;
  124. exports org.elasticsearch.action.admin.indices.validate.query;
  125. exports org.elasticsearch.action.bulk;
  126. exports org.elasticsearch.action.datastreams;
  127. exports org.elasticsearch.action.delete;
  128. exports org.elasticsearch.action.explain;
  129. exports org.elasticsearch.action.fieldcaps;
  130. exports org.elasticsearch.action.get;
  131. exports org.elasticsearch.action.index;
  132. exports org.elasticsearch.action.ingest;
  133. exports org.elasticsearch.action.resync;
  134. exports org.elasticsearch.action.search;
  135. exports org.elasticsearch.action.support;
  136. exports org.elasticsearch.action.support.broadcast;
  137. exports org.elasticsearch.action.support.broadcast.node;
  138. exports org.elasticsearch.action.support.broadcast.unpromotable;
  139. exports org.elasticsearch.action.support.master;
  140. exports org.elasticsearch.action.support.master.info;
  141. exports org.elasticsearch.action.support.nodes;
  142. exports org.elasticsearch.action.support.replication;
  143. exports org.elasticsearch.action.support.single.instance;
  144. exports org.elasticsearch.action.support.single.shard;
  145. exports org.elasticsearch.action.support.tasks;
  146. exports org.elasticsearch.action.termvectors;
  147. exports org.elasticsearch.action.update;
  148. exports org.elasticsearch.bootstrap;
  149. exports org.elasticsearch.client.internal;
  150. exports org.elasticsearch.client.internal.node;
  151. exports org.elasticsearch.client.internal.support;
  152. exports org.elasticsearch.client.internal.transport;
  153. exports org.elasticsearch.cluster;
  154. exports org.elasticsearch.cluster.action.index;
  155. exports org.elasticsearch.cluster.action.shard;
  156. exports org.elasticsearch.cluster.block;
  157. exports org.elasticsearch.cluster.coordination;
  158. exports org.elasticsearch.cluster.coordination.stateless;
  159. exports org.elasticsearch.cluster.health;
  160. exports org.elasticsearch.cluster.metadata;
  161. exports org.elasticsearch.cluster.node;
  162. exports org.elasticsearch.cluster.routing;
  163. exports org.elasticsearch.cluster.routing.allocation;
  164. exports org.elasticsearch.cluster.routing.allocation.allocator;
  165. exports org.elasticsearch.cluster.routing.allocation.command;
  166. exports org.elasticsearch.cluster.routing.allocation.decider;
  167. exports org.elasticsearch.cluster.service;
  168. exports org.elasticsearch.cluster.version;
  169. exports org.elasticsearch.common;
  170. exports org.elasticsearch.common.blobstore;
  171. exports org.elasticsearch.common.blobstore.fs;
  172. exports org.elasticsearch.common.blobstore.support;
  173. exports org.elasticsearch.common.breaker;
  174. exports org.elasticsearch.common.bytes;
  175. exports org.elasticsearch.common.cache;
  176. exports org.elasticsearch.common.cli;
  177. exports org.elasticsearch.common.collect;
  178. exports org.elasticsearch.common.component;
  179. exports org.elasticsearch.common.compress;
  180. exports org.elasticsearch.common.document;
  181. exports org.elasticsearch.common.file;
  182. exports org.elasticsearch.common.geo;
  183. exports org.elasticsearch.common.hash;
  184. exports org.elasticsearch.injection.api;
  185. exports org.elasticsearch.injection.guice;
  186. exports org.elasticsearch.injection.guice.binder;
  187. exports org.elasticsearch.injection.guice.internal;
  188. exports org.elasticsearch.injection.guice.matcher;
  189. exports org.elasticsearch.injection.guice.multibindings;
  190. exports org.elasticsearch.injection.guice.name;
  191. exports org.elasticsearch.injection.guice.spi;
  192. exports org.elasticsearch.injection.guice.util;
  193. exports org.elasticsearch.common.io;
  194. exports org.elasticsearch.common.io.stream;
  195. exports org.elasticsearch.common.logging;
  196. exports org.elasticsearch.common.lucene;
  197. exports org.elasticsearch.common.lucene.index;
  198. exports org.elasticsearch.common.lucene.search;
  199. exports org.elasticsearch.common.lucene.search.function;
  200. exports org.elasticsearch.common.lucene.store;
  201. exports org.elasticsearch.common.lucene.uid;
  202. exports org.elasticsearch.common.metrics;
  203. exports org.elasticsearch.common.network;
  204. exports org.elasticsearch.common.path;
  205. exports org.elasticsearch.common.recycler;
  206. exports org.elasticsearch.common.regex;
  207. exports org.elasticsearch.common.scheduler;
  208. exports org.elasticsearch.common.settings;
  209. exports org.elasticsearch.common.text;
  210. exports org.elasticsearch.common.time;
  211. exports org.elasticsearch.common.transport;
  212. exports org.elasticsearch.common.unit;
  213. exports org.elasticsearch.common.util;
  214. exports org.elasticsearch.common.util.concurrent;
  215. exports org.elasticsearch.common.util.iterable;
  216. exports org.elasticsearch.common.util.set;
  217. exports org.elasticsearch.common.xcontent;
  218. exports org.elasticsearch.common.xcontent.support;
  219. exports org.elasticsearch.discovery;
  220. exports org.elasticsearch.env;
  221. exports org.elasticsearch.features;
  222. exports org.elasticsearch.gateway;
  223. exports org.elasticsearch.health;
  224. exports org.elasticsearch.health.node;
  225. exports org.elasticsearch.health.node.tracker;
  226. exports org.elasticsearch.health.node.selection;
  227. exports org.elasticsearch.health.stats;
  228. exports org.elasticsearch.http;
  229. exports org.elasticsearch.index;
  230. exports org.elasticsearch.index.analysis;
  231. exports org.elasticsearch.index.bulk.stats;
  232. exports org.elasticsearch.index.cache;
  233. exports org.elasticsearch.index.cache.bitset;
  234. exports org.elasticsearch.index.cache.query;
  235. exports org.elasticsearch.index.cache.request;
  236. exports org.elasticsearch.index.codec;
  237. exports org.elasticsearch.index.codec.tsdb;
  238. exports org.elasticsearch.index.codec.bloomfilter;
  239. exports org.elasticsearch.index.codec.zstd;
  240. exports org.elasticsearch.index.engine;
  241. exports org.elasticsearch.index.fielddata;
  242. exports org.elasticsearch.index.fielddata.fieldcomparator;
  243. exports org.elasticsearch.index.fielddata.ordinals;
  244. exports org.elasticsearch.index.fielddata.plain;
  245. exports org.elasticsearch.index.fieldvisitor;
  246. exports org.elasticsearch.index.flush;
  247. exports org.elasticsearch.index.get;
  248. exports org.elasticsearch.index.mapper;
  249. exports org.elasticsearch.index.mapper.flattened;
  250. exports org.elasticsearch.index.mapper.vectors;
  251. exports org.elasticsearch.index.merge;
  252. exports org.elasticsearch.index.query;
  253. exports org.elasticsearch.index.query.functionscore;
  254. exports org.elasticsearch.index.query.support;
  255. exports org.elasticsearch.index.recovery;
  256. exports org.elasticsearch.index.refresh;
  257. exports org.elasticsearch.index.reindex;
  258. exports org.elasticsearch.index.search;
  259. exports org.elasticsearch.index.search.stats;
  260. exports org.elasticsearch.index.seqno;
  261. exports org.elasticsearch.index.shard;
  262. exports org.elasticsearch.index.similarity;
  263. exports org.elasticsearch.index.snapshots;
  264. exports org.elasticsearch.index.snapshots.blobstore;
  265. exports org.elasticsearch.index.stats;
  266. exports org.elasticsearch.index.store;
  267. exports org.elasticsearch.index.termvectors;
  268. exports org.elasticsearch.index.translog;
  269. exports org.elasticsearch.index.warmer;
  270. exports org.elasticsearch.indices;
  271. exports org.elasticsearch.indices.analysis;
  272. exports org.elasticsearch.indices.breaker;
  273. exports org.elasticsearch.indices.cluster;
  274. exports org.elasticsearch.indices.fielddata.cache;
  275. exports org.elasticsearch.indices.recovery;
  276. exports org.elasticsearch.indices.recovery.plan;
  277. exports org.elasticsearch.indices.store;
  278. exports org.elasticsearch.inference;
  279. exports org.elasticsearch.ingest;
  280. exports org.elasticsearch.internal
  281. to
  282. org.elasticsearch.serverless.version,
  283. org.elasticsearch.serverless.buildinfo,
  284. org.elasticsearch.serverless.constants;
  285. exports org.elasticsearch.lucene.analysis.miscellaneous;
  286. exports org.elasticsearch.lucene.grouping;
  287. exports org.elasticsearch.lucene.queries;
  288. exports org.elasticsearch.lucene.search.uhighlight;
  289. exports org.elasticsearch.lucene.search.vectorhighlight;
  290. exports org.elasticsearch.lucene.similarity;
  291. exports org.elasticsearch.lucene.util;
  292. exports org.elasticsearch.monitor;
  293. exports org.elasticsearch.monitor.fs;
  294. exports org.elasticsearch.monitor.jvm;
  295. exports org.elasticsearch.monitor.os;
  296. exports org.elasticsearch.monitor.process;
  297. exports org.elasticsearch.node;
  298. exports org.elasticsearch.node.internal to org.elasticsearch.internal.sigterm;
  299. exports org.elasticsearch.persistent;
  300. exports org.elasticsearch.persistent.decider;
  301. exports org.elasticsearch.plugins;
  302. exports org.elasticsearch.plugins.interceptor to org.elasticsearch.security, org.elasticsearch.serverless.rest;
  303. exports org.elasticsearch.plugins.spi;
  304. exports org.elasticsearch.repositories;
  305. exports org.elasticsearch.repositories.blobstore;
  306. exports org.elasticsearch.repositories.fs;
  307. exports org.elasticsearch.reservedstate;
  308. exports org.elasticsearch.rest;
  309. exports org.elasticsearch.rest.action;
  310. exports org.elasticsearch.rest.action.admin.cluster;
  311. exports org.elasticsearch.rest.action.admin.cluster.dangling;
  312. exports org.elasticsearch.rest.action.admin.indices;
  313. exports org.elasticsearch.rest.action.cat;
  314. exports org.elasticsearch.rest.action.document;
  315. exports org.elasticsearch.rest.action.ingest;
  316. exports org.elasticsearch.rest.action.search;
  317. exports org.elasticsearch.script;
  318. exports org.elasticsearch.script.field;
  319. exports org.elasticsearch.script.field.vectors;
  320. exports org.elasticsearch.search;
  321. exports org.elasticsearch.search.aggregations;
  322. exports org.elasticsearch.search.aggregations.bucket;
  323. exports org.elasticsearch.search.aggregations.bucket.composite;
  324. exports org.elasticsearch.search.aggregations.bucket.countedterms;
  325. exports org.elasticsearch.search.aggregations.bucket.filter;
  326. exports org.elasticsearch.search.aggregations.bucket.geogrid;
  327. exports org.elasticsearch.search.aggregations.bucket.global;
  328. exports org.elasticsearch.search.aggregations.bucket.histogram;
  329. exports org.elasticsearch.search.aggregations.bucket.missing;
  330. exports org.elasticsearch.search.aggregations.bucket.nested;
  331. exports org.elasticsearch.search.aggregations.bucket.range;
  332. exports org.elasticsearch.search.aggregations.bucket.sampler;
  333. exports org.elasticsearch.search.aggregations.bucket.sampler.random;
  334. exports org.elasticsearch.search.aggregations.bucket.terms;
  335. exports org.elasticsearch.search.aggregations.bucket.terms.heuristic;
  336. exports org.elasticsearch.search.aggregations.metrics;
  337. exports org.elasticsearch.search.aggregations.pipeline;
  338. exports org.elasticsearch.search.aggregations.support;
  339. exports org.elasticsearch.search.aggregations.support.values;
  340. exports org.elasticsearch.search.builder;
  341. exports org.elasticsearch.search.collapse;
  342. exports org.elasticsearch.search.dfs;
  343. exports org.elasticsearch.search.fetch;
  344. exports org.elasticsearch.search.fetch.subphase;
  345. exports org.elasticsearch.search.fetch.subphase.highlight;
  346. exports org.elasticsearch.search.internal;
  347. exports org.elasticsearch.search.lookup;
  348. exports org.elasticsearch.search.profile;
  349. exports org.elasticsearch.search.profile.aggregation;
  350. exports org.elasticsearch.search.profile.dfs;
  351. exports org.elasticsearch.search.profile.query;
  352. exports org.elasticsearch.search.query;
  353. exports org.elasticsearch.search.rank;
  354. exports org.elasticsearch.search.rank.context;
  355. exports org.elasticsearch.search.rank.feature;
  356. exports org.elasticsearch.search.rank.rerank;
  357. exports org.elasticsearch.search.rescore;
  358. exports org.elasticsearch.search.retriever;
  359. exports org.elasticsearch.search.retriever.rankdoc;
  360. exports org.elasticsearch.search.runtime;
  361. exports org.elasticsearch.search.searchafter;
  362. exports org.elasticsearch.search.slice;
  363. exports org.elasticsearch.search.sort;
  364. exports org.elasticsearch.search.suggest;
  365. exports org.elasticsearch.search.suggest.completion;
  366. exports org.elasticsearch.search.suggest.completion.context;
  367. exports org.elasticsearch.search.suggest.phrase;
  368. exports org.elasticsearch.search.suggest.term;
  369. exports org.elasticsearch.search.vectors;
  370. exports org.elasticsearch.shutdown;
  371. exports org.elasticsearch.snapshots;
  372. exports org.elasticsearch.synonyms;
  373. exports org.elasticsearch.tasks;
  374. exports org.elasticsearch.threadpool;
  375. exports org.elasticsearch.transport;
  376. exports org.elasticsearch.upgrades;
  377. exports org.elasticsearch.usage;
  378. exports org.elasticsearch.watcher;
  379. opens org.elasticsearch.common.logging to org.apache.logging.log4j.core;
  380. exports org.elasticsearch.action.datastreams.lifecycle;
  381. exports org.elasticsearch.action.datastreams.autosharding;
  382. exports org.elasticsearch.action.downsample;
  383. exports org.elasticsearch.plugins.internal
  384. to
  385. org.elasticsearch.metering,
  386. org.elasticsearch.stateless,
  387. org.elasticsearch.settings.secure,
  388. org.elasticsearch.serverless.constants,
  389. org.elasticsearch.serverless.apifiltering,
  390. org.elasticsearch.internal.security;
  391. exports org.elasticsearch.telemetry.tracing;
  392. exports org.elasticsearch.telemetry;
  393. exports org.elasticsearch.telemetry.metric;
  394. provides java.util.spi.CalendarDataProvider with org.elasticsearch.common.time.IsoCalendarDataProvider;
  395. provides org.elasticsearch.xcontent.ErrorOnUnknown with org.elasticsearch.common.xcontent.SuggestingErrorOnUnknown;
  396. provides org.elasticsearch.xcontent.XContentBuilderExtension with org.elasticsearch.common.xcontent.XContentElasticsearchExtension;
  397. provides org.elasticsearch.cli.CliToolProvider
  398. with
  399. org.elasticsearch.cluster.coordination.NodeToolCliProvider,
  400. org.elasticsearch.index.shard.ShardToolCliProvider;
  401. uses org.elasticsearch.reservedstate.ReservedClusterStateHandlerProvider;
  402. uses org.elasticsearch.jdk.ModuleQualifiedExportsService;
  403. uses org.elasticsearch.node.internal.TerminationHandlerProvider;
  404. uses org.elasticsearch.internal.VersionExtension;
  405. uses org.elasticsearch.internal.BuildExtension;
  406. uses org.elasticsearch.features.FeatureSpecification;
  407. uses org.elasticsearch.plugins.internal.LoggingDataProvider;
  408. provides org.elasticsearch.features.FeatureSpecification
  409. with
  410. org.elasticsearch.action.bulk.BulkFeatures,
  411. org.elasticsearch.features.FeatureInfrastructureFeatures,
  412. org.elasticsearch.health.HealthFeatures,
  413. org.elasticsearch.cluster.service.TransportFeatures,
  414. org.elasticsearch.cluster.metadata.MetadataFeatures,
  415. org.elasticsearch.rest.RestFeatures,
  416. org.elasticsearch.indices.IndicesFeatures,
  417. org.elasticsearch.repositories.RepositoriesFeatures,
  418. org.elasticsearch.action.admin.cluster.allocation.AllocationStatsFeatures,
  419. org.elasticsearch.index.mapper.MapperFeatures,
  420. org.elasticsearch.ingest.IngestGeoIpFeatures,
  421. org.elasticsearch.search.SearchFeatures,
  422. org.elasticsearch.script.ScriptFeatures,
  423. org.elasticsearch.search.retriever.RetrieversFeatures,
  424. org.elasticsearch.reservedstate.service.FileSettingsFeatures,
  425. org.elasticsearch.action.admin.cluster.stats.ClusterStatsFeatures;
  426. uses org.elasticsearch.plugins.internal.SettingsExtension;
  427. uses RestExtension;
  428. uses org.elasticsearch.action.admin.cluster.node.info.ComponentVersionNumber;
  429. provides org.apache.lucene.codecs.PostingsFormat
  430. with
  431. org.elasticsearch.index.codec.bloomfilter.ES85BloomFilterPostingsFormat,
  432. org.elasticsearch.index.codec.bloomfilter.ES87BloomFilterPostingsFormat,
  433. org.elasticsearch.index.codec.postings.ES812PostingsFormat;
  434. provides org.apache.lucene.codecs.DocValuesFormat with org.elasticsearch.index.codec.tsdb.ES87TSDBDocValuesFormat;
  435. provides org.apache.lucene.codecs.KnnVectorsFormat
  436. with
  437. org.elasticsearch.index.codec.vectors.ES813FlatVectorFormat,
  438. org.elasticsearch.index.codec.vectors.ES813Int8FlatVectorFormat,
  439. org.elasticsearch.index.codec.vectors.ES814HnswScalarQuantizedVectorsFormat,
  440. org.elasticsearch.index.codec.vectors.ES815HnswBitVectorsFormat,
  441. org.elasticsearch.index.codec.vectors.ES815BitFlatVectorFormat,
  442. org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsFormat,
  443. org.elasticsearch.index.codec.vectors.ES816HnswBinaryQuantizedVectorsFormat;
  444. provides org.apache.lucene.codecs.Codec
  445. with
  446. org.elasticsearch.index.codec.Elasticsearch814Codec,
  447. org.elasticsearch.index.codec.Elasticsearch816Codec;
  448. provides org.apache.logging.log4j.core.util.ContextDataProvider with org.elasticsearch.common.logging.DynamicContextDataProvider;
  449. exports org.elasticsearch.cluster.routing.allocation.shards
  450. to
  451. org.elasticsearch.shardhealth,
  452. org.elasticsearch.serverless.shardhealth,
  453. org.elasticsearch.serverless.apifiltering;
  454. exports org.elasticsearch.lucene.spatial;
  455. exports org.elasticsearch.inference.configuration;
  456. exports org.elasticsearch.monitor.metrics;
  457. }