Search in sources :

Example 6 with Setting

use of org.opensearch.common.settings.Setting in project job-scheduler by opensearch-project.

the class JobSweeperTests method setup.

@Before
public void setup() throws IOException {
    this.client = Mockito.mock(Client.class);
    this.threadPool = Mockito.mock(ThreadPool.class);
    this.scheduler = Mockito.mock(JobScheduler.class);
    this.jobRunner = Mockito.mock(ScheduledJobRunner.class);
    this.jobParser = Mockito.mock(ScheduledJobParser.class);
    // NamedXContentRegistry.Entry xContentRegistryEntry = new NamedXContentRegistry.Entry(ScheduledJobParameter.class,
    // new ParseField("JOB_TYPE"), this.jobParser);
    List<NamedXContentRegistry.Entry> namedXContentRegistryEntries = new ArrayList<>();
    // namedXContentRegistryEntries.add(xContentRegistryEntry);
    this.xContentRegistry = new NamedXContentRegistry(namedXContentRegistryEntries);
    this.settings = Settings.builder().build();
    this.discoveryNode = new DiscoveryNode("node", OpenSearchTestCase.buildNewFakeTransportAddress(), Version.CURRENT);
    Set<Setting<?>> settingSet = new HashSet<>();
    settingSet.addAll(ClusterSettings.BUILT_IN_CLUSTER_SETTINGS);
    settingSet.add(JobSchedulerSettings.REQUEST_TIMEOUT);
    settingSet.add(JobSchedulerSettings.SWEEP_PERIOD);
    settingSet.add(JobSchedulerSettings.SWEEP_BACKOFF_RETRY_COUNT);
    settingSet.add(JobSchedulerSettings.SWEEP_BACKOFF_MILLIS);
    settingSet.add(JobSchedulerSettings.SWEEP_PAGE_SIZE);
    settingSet.add(JobSchedulerSettings.JITTER_LIMIT);
    ClusterSettings clusterSettings = new ClusterSettings(this.settings, settingSet);
    ClusterService originClusterService = ClusterServiceUtils.createClusterService(this.threadPool, discoveryNode, clusterSettings);
    this.clusterService = Mockito.spy(originClusterService);
    ScheduledJobProvider jobProvider = new ScheduledJobProvider("JOB_TYPE", "job-index-name", this.jobParser, this.jobRunner);
    Map<String, ScheduledJobProvider> jobProviderMap = new HashMap<>();
    jobProviderMap.put("index-name", jobProvider);
    sweeper = new JobSweeper(settings, this.client, this.clusterService, this.threadPool, xContentRegistry, jobProviderMap, scheduler, new LockService(client, clusterService));
}
Also used : JobScheduler(org.opensearch.jobscheduler.scheduler.JobScheduler) ScheduledJobParser(org.opensearch.jobscheduler.spi.ScheduledJobParser) DiscoveryNode(org.opensearch.cluster.node.DiscoveryNode) ClusterSettings(org.opensearch.common.settings.ClusterSettings) LockService(org.opensearch.jobscheduler.spi.utils.LockService) HashMap(java.util.HashMap) Setting(org.opensearch.common.settings.Setting) ThreadPool(org.opensearch.threadpool.ThreadPool) ArrayList(java.util.ArrayList) ScheduledJobRunner(org.opensearch.jobscheduler.spi.ScheduledJobRunner) ClusterService(org.opensearch.cluster.service.ClusterService) ScheduledJobProvider(org.opensearch.jobscheduler.ScheduledJobProvider) Client(org.opensearch.client.Client) NamedXContentRegistry(org.opensearch.common.xcontent.NamedXContentRegistry) HashSet(java.util.HashSet) Before(org.junit.Before)

Example 7 with Setting

use of org.opensearch.common.settings.Setting in project OpenSearch by opensearch-project.

the class ScriptServiceTests method testContextCacheStats.

public void testContextCacheStats() throws IOException {
    ScriptContext<?> contextA = randomFrom(contexts.values());
    String aRate = "2/10m";
    ScriptContext<?> contextB = randomValueOtherThan(contextA, () -> randomFrom(contexts.values()));
    String bRate = "3/10m";
    BiFunction<String, String, String> msg = (rate, ctx) -> ("[script] Too many dynamic script compilations within, max: [" + rate + "]; please use indexed, or scripts with parameters instead; this limit can be changed by the [script.context." + ctx + ".max_compilations_rate] setting");
    buildScriptService(Settings.builder().put(SCRIPT_CACHE_SIZE_SETTING.getConcreteSettingForNamespace(contextA.name).getKey(), 1).put(SCRIPT_MAX_COMPILATIONS_RATE_SETTING.getConcreteSettingForNamespace(contextA.name).getKey(), aRate).put(SCRIPT_CACHE_SIZE_SETTING.getConcreteSettingForNamespace(contextB.name).getKey(), 2).put(SCRIPT_MAX_COMPILATIONS_RATE_SETTING.getConcreteSettingForNamespace(contextB.name).getKey(), bRate).build());
    // Context A
    scriptService.compile(new Script(ScriptType.INLINE, "test", "1+1", Collections.emptyMap()), contextA);
    scriptService.compile(new Script(ScriptType.INLINE, "test", "2+2", Collections.emptyMap()), contextA);
    GeneralScriptException gse = expectThrows(GeneralScriptException.class, () -> scriptService.compile(new Script(ScriptType.INLINE, "test", "3+3", Collections.emptyMap()), contextA));
    assertEquals(msg.apply(aRate, contextA.name), gse.getRootCause().getMessage());
    assertEquals(CircuitBreakingException.class, gse.getRootCause().getClass());
    // Context B
    scriptService.compile(new Script(ScriptType.INLINE, "test", "4+4", Collections.emptyMap()), contextB);
    scriptService.compile(new Script(ScriptType.INLINE, "test", "5+5", Collections.emptyMap()), contextB);
    scriptService.compile(new Script(ScriptType.INLINE, "test", "6+6", Collections.emptyMap()), contextB);
    gse = expectThrows(GeneralScriptException.class, () -> scriptService.compile(new Script(ScriptType.INLINE, "test", "7+7", Collections.emptyMap()), contextB));
    assertEquals(msg.apply(bRate, contextB.name), gse.getRootCause().getMessage());
    gse = expectThrows(GeneralScriptException.class, () -> scriptService.compile(new Script(ScriptType.INLINE, "test", "8+8", Collections.emptyMap()), contextB));
    assertEquals(msg.apply(bRate, contextB.name), gse.getRootCause().getMessage());
    assertEquals(CircuitBreakingException.class, gse.getRootCause().getClass());
    // Context specific
    ScriptCacheStats stats = scriptService.cacheStats();
    assertEquals(2L, stats.getContextStats().get(contextA.name).getCompilations());
    assertEquals(1L, stats.getContextStats().get(contextA.name).getCacheEvictions());
    assertEquals(1L, stats.getContextStats().get(contextA.name).getCompilationLimitTriggered());
    assertEquals(3L, stats.getContextStats().get(contextB.name).getCompilations());
    assertEquals(1L, stats.getContextStats().get(contextB.name).getCacheEvictions());
    assertEquals(2L, stats.getContextStats().get(contextB.name).getCompilationLimitTriggered());
    assertNull(scriptService.cacheStats().getGeneralStats());
    // Summed up
    assertEquals(5L, scriptService.stats().getCompilations());
    assertEquals(2L, scriptService.stats().getCacheEvictions());
    assertEquals(3L, scriptService.stats().getCompilationLimitTriggered());
}
Also used : Metadata(org.opensearch.cluster.metadata.Metadata) BytesReference(org.opensearch.common.bytes.BytesReference) SCRIPT_GENERAL_CACHE_EXPIRE_SETTING(org.opensearch.script.ScriptService.SCRIPT_GENERAL_CACHE_EXPIRE_SETTING) BiFunction(java.util.function.BiFunction) HashMap(java.util.HashMap) ResourceNotFoundException(org.opensearch.ResourceNotFoundException) Function(java.util.function.Function) SCRIPT_MAX_COMPILATIONS_RATE_SETTING(org.opensearch.script.ScriptService.SCRIPT_MAX_COMPILATIONS_RATE_SETTING) ClusterState(org.opensearch.cluster.ClusterState) Map(java.util.Map) GetStoredScriptRequest(org.opensearch.action.admin.cluster.storedscripts.GetStoredScriptRequest) XContentFactory(org.opensearch.common.xcontent.XContentFactory) ClusterSettings(org.opensearch.common.settings.ClusterSettings) Before(org.junit.Before) CircuitBreakingException(org.opensearch.common.breaker.CircuitBreakingException) Environment(org.opensearch.env.Environment) Setting(org.opensearch.common.settings.Setting) TimeValue(org.opensearch.common.unit.TimeValue) CoreMatchers.containsString(org.hamcrest.CoreMatchers.containsString) Matchers.notNullValue(org.hamcrest.Matchers.notNullValue) OpenSearchTestCase(org.opensearch.test.OpenSearchTestCase) Set(java.util.Set) SCRIPT_CACHE_SIZE_SETTING(org.opensearch.script.ScriptService.SCRIPT_CACHE_SIZE_SETTING) Settings(org.opensearch.common.settings.Settings) IOException(java.io.IOException) SCRIPT_CACHE_EXPIRE_SETTING(org.opensearch.script.ScriptService.SCRIPT_CACHE_EXPIRE_SETTING) SCRIPT_GENERAL_MAX_COMPILATIONS_RATE_SETTING(org.opensearch.script.ScriptService.SCRIPT_GENERAL_MAX_COMPILATIONS_RATE_SETTING) SCRIPT_GENERAL_CACHE_SIZE_SETTING(org.opensearch.script.ScriptService.SCRIPT_GENERAL_CACHE_SIZE_SETTING) Matchers.sameInstance(org.hamcrest.Matchers.sameInstance) BytesArray(org.opensearch.common.bytes.BytesArray) ClusterName(org.opensearch.cluster.ClusterName) XContentType(org.opensearch.common.xcontent.XContentType) Matchers.is(org.hamcrest.Matchers.is) Collections(java.util.Collections) CoreMatchers.containsString(org.hamcrest.CoreMatchers.containsString)

Example 8 with Setting

use of org.opensearch.common.settings.Setting in project OpenSearch by opensearch-project.

the class ProxyConnectionStrategyTests method testProxyStrategyWillNeedToBeRebuiltIfNumOfSocketsOrAddressesOrServerNameChange.

public void testProxyStrategyWillNeedToBeRebuiltIfNumOfSocketsOrAddressesOrServerNameChange() {
    try (MockTransportService remoteTransport = startTransport("node1", Version.CURRENT)) {
        TransportAddress remoteAddress = remoteTransport.boundAddress().publishAddress();
        try (MockTransportService localService = MockTransportService.createNewService(Settings.EMPTY, Version.CURRENT, threadPool)) {
            localService.start();
            localService.acceptIncomingRequests();
            ClusterConnectionManager connectionManager = new ClusterConnectionManager(profile, localService.transport);
            int numOfConnections = randomIntBetween(4, 8);
            try (RemoteConnectionManager remoteConnectionManager = new RemoteConnectionManager(clusterAlias, connectionManager);
                ProxyConnectionStrategy strategy = new ProxyConnectionStrategy(clusterAlias, localService, remoteConnectionManager, Settings.EMPTY, numOfConnections, remoteAddress.toString(), "server-name")) {
                PlainActionFuture<Void> connectFuture = PlainActionFuture.newFuture();
                strategy.connect(connectFuture);
                connectFuture.actionGet();
                assertTrue(connectionManager.getAllConnectedNodes().stream().anyMatch(n -> n.getAddress().equals(remoteAddress)));
                assertEquals(numOfConnections, connectionManager.size());
                assertTrue(strategy.assertNoRunningConnections());
                Setting<?> modeSetting = RemoteConnectionStrategy.REMOTE_CONNECTION_MODE.getConcreteSettingForNamespace("cluster-alias");
                Setting<?> addressesSetting = ProxyConnectionStrategy.PROXY_ADDRESS.getConcreteSettingForNamespace("cluster-alias");
                Setting<?> socketConnections = ProxyConnectionStrategy.REMOTE_SOCKET_CONNECTIONS.getConcreteSettingForNamespace("cluster-alias");
                Setting<?> serverName = ProxyConnectionStrategy.SERVER_NAME.getConcreteSettingForNamespace("cluster-alias");
                Settings noChange = Settings.builder().put(modeSetting.getKey(), "proxy").put(addressesSetting.getKey(), remoteAddress.toString()).put(socketConnections.getKey(), numOfConnections).put(serverName.getKey(), "server-name").build();
                assertFalse(strategy.shouldRebuildConnection(noChange));
                Settings addressesChanged = Settings.builder().put(modeSetting.getKey(), "proxy").put(addressesSetting.getKey(), remoteAddress.toString()).build();
                assertTrue(strategy.shouldRebuildConnection(addressesChanged));
                Settings socketsChanged = Settings.builder().put(modeSetting.getKey(), "proxy").put(addressesSetting.getKey(), remoteAddress.toString()).put(socketConnections.getKey(), numOfConnections + 1).build();
                assertTrue(strategy.shouldRebuildConnection(socketsChanged));
                Settings serverNameChange = Settings.builder().put(modeSetting.getKey(), "proxy").put(addressesSetting.getKey(), remoteAddress.toString()).put(socketConnections.getKey(), numOfConnections).put(serverName.getKey(), "server-name2").build();
                assertTrue(strategy.shouldRebuildConnection(serverNameChange));
            }
        }
    }
}
Also used : Arrays(java.util.Arrays) Setting(org.opensearch.common.settings.Setting) OpenSearchTestCase(org.opensearch.test.OpenSearchTestCase) ThreadPool(org.opensearch.threadpool.ThreadPool) TestThreadPool(org.opensearch.threadpool.TestThreadPool) Set(java.util.Set) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) Version(org.opensearch.Version) AbstractScopedSettings(org.opensearch.common.settings.AbstractScopedSettings) Settings(org.opensearch.common.settings.Settings) MockTransportService(org.opensearch.test.transport.MockTransportService) Supplier(java.util.function.Supplier) Collectors(java.util.stream.Collectors) Tuple(org.opensearch.common.collect.Tuple) TransportAddress(org.opensearch.common.transport.TransportAddress) HashSet(java.util.HashSet) TimeUnit(java.util.concurrent.TimeUnit) CountDownLatch(java.util.concurrent.CountDownLatch) DiscoveryNode(org.opensearch.cluster.node.DiscoveryNode) List(java.util.List) PlainActionFuture(org.opensearch.action.support.PlainActionFuture) ClusterName(org.opensearch.cluster.ClusterName) ClusterSettings(org.opensearch.common.settings.ClusterSettings) MockTransportService(org.opensearch.test.transport.MockTransportService) TransportAddress(org.opensearch.common.transport.TransportAddress) AbstractScopedSettings(org.opensearch.common.settings.AbstractScopedSettings) Settings(org.opensearch.common.settings.Settings) ClusterSettings(org.opensearch.common.settings.ClusterSettings)

Example 9 with Setting

use of org.opensearch.common.settings.Setting in project OpenSearch by opensearch-project.

the class DedicatedClusterSnapshotRestoreIT method testExceptionWhenRestoringPersistentSettings.

@AwaitsFix(bugUrl = "https://github.com/elastic/elasticsearch/issues/37485")
public void testExceptionWhenRestoringPersistentSettings() {
    logger.info("--> start 2 nodes");
    internalCluster().startNodes(2);
    Client client = client();
    Consumer<String> setSettingValue = value -> {
        client.admin().cluster().prepareUpdateSettings().setPersistentSettings(Settings.builder().put(BrokenSettingPlugin.BROKEN_SETTING.getKey(), value)).execute().actionGet();
    };
    Consumer<String> assertSettingValue = value -> {
        assertThat(client.admin().cluster().prepareState().setRoutingTable(false).setNodes(false).execute().actionGet().getState().getMetadata().persistentSettings().get(BrokenSettingPlugin.BROKEN_SETTING.getKey()), equalTo(value));
    };
    logger.info("--> set test persistent setting");
    setSettingValue.accept("new value");
    assertSettingValue.accept("new value");
    createRepository("test-repo", "fs");
    createFullSnapshot("test-repo", "test-snap");
    assertThat(getSnapshot("test-repo", "test-snap").state(), equalTo(SnapshotState.SUCCESS));
    logger.info("--> change the test persistent setting and break it");
    setSettingValue.accept("new value 2");
    assertSettingValue.accept("new value 2");
    BrokenSettingPlugin.breakSetting(true);
    logger.info("--> restore snapshot");
    try {
        client.admin().cluster().prepareRestoreSnapshot("test-repo", "test-snap").setRestoreGlobalState(true).setWaitForCompletion(true).execute().actionGet();
    } catch (IllegalArgumentException ex) {
        assertEquals(BrokenSettingPlugin.EXCEPTION.getMessage(), ex.getMessage());
    }
    assertSettingValue.accept("new value 2");
}
Also used : RepositoryMissingException(org.opensearch.repositories.RepositoryMissingException) Arrays(java.util.Arrays) Metadata(org.opensearch.cluster.metadata.Metadata) CheckedFunction(org.opensearch.common.CheckedFunction) Matchers.not(org.hamcrest.Matchers.not) ClusterScope(org.opensearch.test.OpenSearchIntegTestCase.ClusterScope) Version(org.opensearch.Version) SnapshotsStatusResponse(org.opensearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse) Strings(org.opensearch.common.Strings) PlainActionFuture(org.opensearch.action.support.PlainActionFuture) RecoveryState(org.opensearch.indices.recovery.RecoveryState) SnapshotStatus(org.opensearch.action.admin.cluster.snapshots.status.SnapshotStatus) Matchers.nullValue(org.hamcrest.Matchers.nullValue) Path(java.nio.file.Path) EnumSet(java.util.EnumSet) OpenSearchAssertions.assertRequestBuilderThrows(org.opensearch.test.hamcrest.OpenSearchAssertions.assertRequestBuilderThrows) Client(org.opensearch.client.Client) TimeValue(org.opensearch.common.unit.TimeValue) NodeClient(org.opensearch.client.node.NodeClient) Matchers.notNullValue(org.hamcrest.Matchers.notNullValue) Matchers.allOf(org.hamcrest.Matchers.allOf) TransportRequestOptions(org.opensearch.transport.TransportRequestOptions) Settings(org.opensearch.common.settings.Settings) TestCustomMetadata(org.opensearch.test.TestCustomMetadata) Scope(org.opensearch.test.OpenSearchIntegTestCase.Scope) TransportService(org.opensearch.transport.TransportService) RetentionLeaseActions(org.opensearch.index.seqno.RetentionLeaseActions) UncheckedIOException(java.io.UncheckedIOException) FileVisitResult(java.nio.file.FileVisitResult) CountDownLatch(java.util.concurrent.CountDownLatch) Matchers.greaterThan(org.hamcrest.Matchers.greaterThan) Matchers.is(org.hamcrest.Matchers.is) Matchers.containsString(org.hamcrest.Matchers.containsString) IndexNameExpressionResolver(org.opensearch.cluster.metadata.IndexNameExpressionResolver) Priority(org.opensearch.common.Priority) Node(org.opensearch.node.Node) ParseField(org.opensearch.common.ParseField) Writeable(org.opensearch.common.io.stream.Writeable) MockTransportService(org.opensearch.test.transport.MockTransportService) ArrayList(java.util.ArrayList) RestoreSnapshotResponse(org.opensearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse) ClusterState(org.opensearch.cluster.ClusterState) BusyMasterServiceDisruption(org.opensearch.test.disruption.BusyMasterServiceDisruption) Matchers.lessThan(org.hamcrest.Matchers.lessThan) Matchers.hasSize(org.hamcrest.Matchers.hasSize) AbstractRestChannel(org.opensearch.rest.AbstractRestChannel) Environment(org.opensearch.env.Environment) Matchers.greaterThanOrEqualTo(org.hamcrest.Matchers.greaterThanOrEqualTo) Files(java.nio.file.Files) RETAIN_ALL(org.opensearch.index.seqno.RetentionLeaseActions.RETAIN_ALL) IOException(java.io.IOException) TransportMessageListener(org.opensearch.transport.TransportMessageListener) Plugin(org.opensearch.plugins.Plugin) NamedXContentRegistry(org.opensearch.common.xcontent.NamedXContentRegistry) RetentionLeases(org.opensearch.index.seqno.RetentionLeases) ClusterService(org.opensearch.cluster.service.ClusterService) ShardStats(org.opensearch.action.admin.indices.stats.ShardStats) IndexRequestBuilder(org.opensearch.action.index.IndexRequestBuilder) BlobStoreRepository(org.opensearch.repositories.blobstore.BlobStoreRepository) NodeRoles.nonMasterNode(org.opensearch.test.NodeRoles.nonMasterNode) ThreadContext(org.opensearch.common.util.concurrent.ThreadContext) XContentParser(org.opensearch.common.xcontent.XContentParser) FakeRestRequest(org.opensearch.test.rest.FakeRestRequest) DiscoveryNode(org.opensearch.cluster.node.DiscoveryNode) Locale(java.util.Locale) SimpleFileVisitor(java.nio.file.SimpleFileVisitor) Collection(java.util.Collection) RestStatus(org.opensearch.rest.RestStatus) ServiceDisruptionScheme(org.opensearch.test.disruption.ServiceDisruptionScheme) MockRepository(org.opensearch.snapshots.mockstore.MockRepository) List(java.util.List) Matchers.equalTo(org.hamcrest.Matchers.equalTo) SnapshotStats(org.opensearch.action.admin.cluster.snapshots.status.SnapshotStats) RestGetRepositoriesAction(org.opensearch.rest.action.admin.cluster.RestGetRepositoriesAction) SnapshotsInProgress(org.opensearch.cluster.SnapshotsInProgress) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) InternalTestCluster(org.opensearch.test.InternalTestCluster) AtomicReference(java.util.concurrent.atomic.AtomicReference) NamedWriteableRegistry(org.opensearch.common.io.stream.NamedWriteableRegistry) PeerRecoveryTargetService(org.opensearch.indices.recovery.PeerRecoveryTargetService) StreamInput(org.opensearch.common.io.stream.StreamInput) SettingsFilter(org.opensearch.common.settings.SettingsFilter) OpenSearchAssertions.assertAcked(org.opensearch.test.hamcrest.OpenSearchAssertions.assertAcked) CreateSnapshotResponse(org.opensearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse) Setting(org.opensearch.common.settings.Setting) TransportRequest(org.opensearch.transport.TransportRequest) RestRequest(org.opensearch.rest.RestRequest) IntHashSet(com.carrotsearch.hppc.IntHashSet) IntSet(com.carrotsearch.hppc.IntSet) RestClusterStateAction(org.opensearch.rest.action.admin.cluster.RestClusterStateAction) BasicFileAttributes(java.nio.file.attribute.BasicFileAttributes) OpenSearchAssertions.assertFutureThrows(org.opensearch.test.hamcrest.OpenSearchAssertions.assertFutureThrows) RestResponse(org.opensearch.rest.RestResponse) ActionFuture(org.opensearch.action.ActionFuture) ActiveShardCount(org.opensearch.action.support.ActiveShardCount) AcknowledgedResponse(org.opensearch.action.support.master.AcknowledgedResponse) ShardId(org.opensearch.index.shard.ShardId) TimeUnit(java.util.concurrent.TimeUnit) Consumer(java.util.function.Consumer) Sets(org.opensearch.common.util.set.Sets) CreateSnapshotRequest(org.opensearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest) GetSnapshotsResponse(org.opensearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse) NamedDiff(org.opensearch.cluster.NamedDiff) Collections(java.util.Collections) Matchers.containsString(org.hamcrest.Matchers.containsString) Client(org.opensearch.client.Client) NodeClient(org.opensearch.client.node.NodeClient)

Example 10 with Setting

use of org.opensearch.common.settings.Setting in project OpenSearch by opensearch-project.

the class AzureStorageSettings method getValue.

private static <T> T getValue(Settings settings, String groupName, Setting<T> setting) {
    final Setting.AffixKey k = (Setting.AffixKey) setting.getRawKey();
    final String fullKey = k.toConcreteKey(groupName).toString();
    return setting.getConcreteSetting(fullKey).get(settings);
}
Also used : Setting(org.opensearch.common.settings.Setting) AffixSetting(org.opensearch.common.settings.Setting.AffixSetting) SecureSetting(org.opensearch.common.settings.SecureSetting) SecureString(org.opensearch.common.settings.SecureString)

Aggregations

Setting (org.opensearch.common.settings.Setting)19 Settings (org.opensearch.common.settings.Settings)16 ClusterSettings (org.opensearch.common.settings.ClusterSettings)10 ClusterState (org.opensearch.cluster.ClusterState)9 HashSet (java.util.HashSet)7 Metadata (org.opensearch.cluster.metadata.Metadata)6 Version (org.opensearch.Version)5 ClusterName (org.opensearch.cluster.ClusterName)5 AbstractScopedSettings (org.opensearch.common.settings.AbstractScopedSettings)5 IndexScopedSettings (org.opensearch.common.settings.IndexScopedSettings)5 ArrayList (java.util.ArrayList)4 Arrays (java.util.Arrays)4 Set (java.util.Set)4 IndexMetadata (org.opensearch.cluster.metadata.IndexMetadata)4 ClusterService (org.opensearch.cluster.service.ClusterService)4 IOException (java.io.IOException)3 Collections (java.util.Collections)3 TimeUnit (java.util.concurrent.TimeUnit)3 Tuple (org.opensearch.common.collect.Tuple)3 HashMap (java.util.HashMap)2