[Rename] Fix imports in the server module. (#378)
This PR fixes all import issues in the server module resulting from the earlier refactoring. Signed-off-by: Rabi Panda <adnapibar@gmail.com>
This commit is contained in:
parent
cfd8587e5a
commit
bd4972c808
|
@ -962,7 +962,7 @@ public class OpenSearchException extends RuntimeException implements ToXContentF
|
|||
TcpTransport.HttpRequestOnTransportException::new, 125, UNKNOWN_VERSION_ADDED),
|
||||
MAPPER_PARSING_EXCEPTION(org.opensearch.index.mapper.MapperParsingException.class,
|
||||
org.opensearch.index.mapper.MapperParsingException::new, 126, UNKNOWN_VERSION_ADDED),
|
||||
// 127 used to be org.elasticsearch.search.SearchContextException
|
||||
// 127 used to be org.opensearch.search.SearchContextException
|
||||
SEARCH_SOURCE_BUILDER_EXCEPTION(org.opensearch.search.builder.SearchSourceBuilderException.class,
|
||||
org.opensearch.search.builder.SearchSourceBuilderException::new, 128, UNKNOWN_VERSION_ADDED),
|
||||
// 129 was EngineClosedException
|
||||
|
|
|
@ -29,7 +29,7 @@ import org.opensearch.common.io.stream.StreamOutput;
|
|||
import org.opensearch.common.settings.Settings;
|
||||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.monitor.jvm.JvmInfo;
|
||||
import org.opensearch.monitor.jvm.JvmInfo;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.lang.reflect.Field;
|
||||
|
|
|
@ -117,9 +117,9 @@ import org.opensearch.action.admin.indices.dangling.import_index.TransportImport
|
|||
import org.opensearch.action.admin.indices.dangling.list.ListDanglingIndicesAction;
|
||||
import org.opensearch.action.admin.indices.dangling.list.TransportListDanglingIndicesAction;
|
||||
import org.opensearch.action.admin.indices.datastream.CreateDataStreamAction;
|
||||
import org.opensearch.action.admin.indices.datastream.DataStreamsStatsAction;
|
||||
import org.opensearch.action.admin.indices.datastream.DeleteDataStreamAction;
|
||||
import org.opensearch.action.admin.indices.datastream.GetDataStreamAction;
|
||||
import org.opensearch.action.admin.indices.datastream.DataStreamsStatsAction;
|
||||
import org.opensearch.action.admin.indices.delete.DeleteIndexAction;
|
||||
import org.opensearch.action.admin.indices.delete.TransportDeleteIndexAction;
|
||||
import org.opensearch.action.admin.indices.exists.indices.IndicesExistsAction;
|
||||
|
@ -203,10 +203,10 @@ import org.opensearch.action.bulk.TransportShardBulkAction;
|
|||
import org.opensearch.action.delete.DeleteAction;
|
||||
import org.opensearch.action.delete.TransportDeleteAction;
|
||||
import org.opensearch.action.explain.ExplainAction;
|
||||
import org.elasticsearch.action.explain.TransportExplainAction;
|
||||
import org.opensearch.action.explain.TransportExplainAction;
|
||||
import org.opensearch.action.fieldcaps.FieldCapabilitiesAction;
|
||||
import org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction;
|
||||
import org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction;
|
||||
import org.opensearch.action.fieldcaps.TransportFieldCapabilitiesAction;
|
||||
import org.opensearch.action.fieldcaps.TransportFieldCapabilitiesIndexAction;
|
||||
import org.opensearch.action.get.GetAction;
|
||||
import org.opensearch.action.get.MultiGetAction;
|
||||
import org.opensearch.action.get.TransportGetAction;
|
||||
|
|
|
@ -27,15 +27,15 @@ import org.opensearch.common.Nullable;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.lucene.uid.Versions;
|
||||
import org.elasticsearch.index.VersionType;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.VersionType;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Locale;
|
||||
|
||||
import static org.opensearch.action.ValidateActions.addValidationError;
|
||||
import static org.elasticsearch.index.seqno.SequenceNumbers.UNASSIGNED_PRIMARY_TERM;
|
||||
import static org.elasticsearch.index.seqno.SequenceNumbers.UNASSIGNED_SEQ_NO;
|
||||
import static org.opensearch.index.seqno.SequenceNumbers.UNASSIGNED_PRIMARY_TERM;
|
||||
import static org.opensearch.index.seqno.SequenceNumbers.UNASSIGNED_SEQ_NO;
|
||||
|
||||
/**
|
||||
* Generic interface to group ActionRequest, which perform writes to a single document
|
||||
|
@ -132,7 +132,7 @@ public interface DocWriteRequest<T> extends IndicesRequest, Accountable {
|
|||
* sequence number. Must be used in combination with {@link #setIfPrimaryTerm(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
T setIfSeqNo(long seqNo);
|
||||
|
||||
|
@ -141,14 +141,14 @@ public interface DocWriteRequest<T> extends IndicesRequest, Accountable {
|
|||
* primary term. Must be used in combination with {@link #setIfSeqNo(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
T setIfPrimaryTerm(long term);
|
||||
|
||||
/**
|
||||
* If set, only perform this request if the document was last modification was assigned this sequence number.
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
long ifSeqNo();
|
||||
|
||||
|
@ -156,7 +156,7 @@ public interface DocWriteRequest<T> extends IndicesRequest, Accountable {
|
|||
* If set, only perform this request if the document was last modification was assigned this primary term.
|
||||
*
|
||||
* If the document last modification was assigned a different term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
long ifPrimaryTerm();
|
||||
|
||||
|
|
|
@ -21,7 +21,7 @@ package org.opensearch.action;
|
|||
|
||||
import org.opensearch.OpenSearchException;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -20,7 +20,7 @@
|
|||
package org.opensearch.action;
|
||||
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
import org.elasticsearch.index.Index;
|
||||
import org.opensearch.index.Index;
|
||||
|
||||
import java.util.Collection;
|
||||
import java.util.Optional;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action;
|
|||
import org.opensearch.OpenSearchException;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -32,7 +32,7 @@ import org.opensearch.common.io.stream.StreamOutput;
|
|||
import org.opensearch.common.io.stream.Writeable;
|
||||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.time.Instant;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.cluster.allocation;
|
|||
import org.apache.logging.log4j.LogManager;
|
||||
import org.apache.logging.log4j.Logger;
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeAction;
|
||||
import org.opensearch.cluster.ClusterInfo;
|
||||
import org.opensearch.cluster.ClusterInfoService;
|
||||
|
|
|
@ -31,10 +31,10 @@ import org.opensearch.common.xcontent.ToXContentFragment;
|
|||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentFactory;
|
||||
import org.opensearch.http.HttpInfo;
|
||||
import org.elasticsearch.ingest.IngestInfo;
|
||||
import org.elasticsearch.monitor.jvm.JvmInfo;
|
||||
import org.elasticsearch.monitor.os.OsInfo;
|
||||
import org.elasticsearch.monitor.process.ProcessInfo;
|
||||
import org.opensearch.ingest.IngestInfo;
|
||||
import org.opensearch.monitor.jvm.JvmInfo;
|
||||
import org.opensearch.monitor.os.OsInfo;
|
||||
import org.opensearch.monitor.process.ProcessInfo;
|
||||
import org.opensearch.search.aggregations.support.AggregationInfo;
|
||||
import org.opensearch.threadpool.ThreadPoolInfo;
|
||||
import org.opensearch.transport.TransportInfo;
|
||||
|
|
|
@ -21,8 +21,8 @@ package org.opensearch.action.admin.cluster.remote;
|
|||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.opensearch.action.search.SearchTransportService;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.elasticsearch.action.support.HandledTransportAction;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.HandledTransportAction;
|
||||
import org.opensearch.common.inject.Inject;
|
||||
import org.opensearch.tasks.Task;
|
||||
import org.opensearch.transport.RemoteClusterService;
|
||||
|
|
|
@ -21,7 +21,7 @@ package org.opensearch.action.admin.cluster.reroute;
|
|||
|
||||
import org.opensearch.action.support.master.AcknowledgedRequestBuilder;
|
||||
import org.opensearch.client.OpenSearchClient;
|
||||
import org.elasticsearch.cluster.routing.allocation.command.AllocationCommand;
|
||||
import org.opensearch.cluster.routing.allocation.command.AllocationCommand;
|
||||
|
||||
/**
|
||||
* Builder for a cluster reroute request
|
||||
|
|
|
@ -23,7 +23,7 @@ import org.opensearch.Version;
|
|||
import org.opensearch.action.support.master.AcknowledgedResponse;
|
||||
import org.opensearch.cluster.ClusterModule;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
import org.elasticsearch.cluster.routing.allocation.RoutingExplanations;
|
||||
import org.opensearch.cluster.routing.allocation.RoutingExplanations;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.xcontent.ToXContent;
|
||||
|
|
|
@ -25,7 +25,7 @@ import org.opensearch.common.io.stream.StreamOutput;
|
|||
import org.opensearch.common.io.stream.Writeable;
|
||||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
|
|
|
@ -27,7 +27,7 @@ import org.opensearch.cluster.ClusterStateListener;
|
|||
import org.opensearch.cluster.RestoreInProgress;
|
||||
import org.opensearch.cluster.service.ClusterService;
|
||||
import org.opensearch.common.collect.ImmutableOpenMap;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.snapshots.RestoreInfo;
|
||||
import org.opensearch.snapshots.RestoreService;
|
||||
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.cluster.snapshots.status;
|
|||
import org.opensearch.OpenSearchException;
|
||||
import org.opensearch.action.ActionType;
|
||||
import org.opensearch.action.FailedNodeException;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.nodes.BaseNodeRequest;
|
||||
import org.opensearch.action.support.nodes.BaseNodeResponse;
|
||||
import org.opensearch.action.support.nodes.BaseNodesRequest;
|
||||
|
@ -33,8 +33,8 @@ import org.opensearch.cluster.node.DiscoveryNode;
|
|||
import org.opensearch.cluster.service.ClusterService;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.elasticsearch.index.snapshots.IndexShardSnapshotStatus;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.index.snapshots.IndexShardSnapshotStatus;
|
||||
import org.opensearch.snapshots.Snapshot;
|
||||
import org.opensearch.snapshots.SnapshotShardsService;
|
||||
import org.opensearch.threadpool.ThreadPool;
|
||||
|
|
|
@ -19,10 +19,10 @@
|
|||
|
||||
package org.opensearch.action.admin.cluster.state;
|
||||
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.action.support.master.MasterNodeReadOperationRequestBuilder;
|
||||
import org.opensearch.client.OpenSearchClient;
|
||||
import org.opensearch.common.unit.TimeValue;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
|
||||
public class ClusterStateRequestBuilder extends MasterNodeReadOperationRequestBuilder<ClusterStateRequest,
|
||||
ClusterStateResponse, ClusterStateRequestBuilder> {
|
||||
|
@ -80,7 +80,7 @@ public class ClusterStateRequestBuilder extends MasterNodeReadOperationRequestBu
|
|||
}
|
||||
|
||||
/**
|
||||
* Should the cluster state result include the {@link org.elasticsearch.cluster.routing.RoutingTable}. Defaults
|
||||
* Should the cluster state result include the {@link org.opensearch.cluster.routing.RoutingTable}. Defaults
|
||||
* to {@code true}.
|
||||
*/
|
||||
public ClusterStateRequestBuilder setRoutingTable(boolean filter) {
|
||||
|
|
|
@ -21,15 +21,14 @@ package org.opensearch.action.admin.cluster.stats;
|
|||
|
||||
import com.carrotsearch.hppc.ObjectObjectHashMap;
|
||||
import com.carrotsearch.hppc.cursors.ObjectObjectCursor;
|
||||
|
||||
import org.opensearch.action.admin.indices.stats.CommonStats;
|
||||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.cache.query.QueryCacheStats;
|
||||
import org.elasticsearch.index.engine.SegmentsStats;
|
||||
import org.elasticsearch.index.fielddata.FieldDataStats;
|
||||
import org.elasticsearch.index.shard.DocsStats;
|
||||
import org.elasticsearch.index.store.StoreStats;
|
||||
import org.opensearch.index.cache.query.QueryCacheStats;
|
||||
import org.opensearch.index.engine.SegmentsStats;
|
||||
import org.opensearch.index.fielddata.FieldDataStats;
|
||||
import org.opensearch.index.shard.DocsStats;
|
||||
import org.opensearch.index.store.StoreStats;
|
||||
import org.opensearch.search.suggest.completion.CompletionStats;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -36,9 +36,9 @@ import org.opensearch.common.unit.TimeValue;
|
|||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.discovery.DiscoveryModule;
|
||||
import org.elasticsearch.monitor.fs.FsInfo;
|
||||
import org.elasticsearch.monitor.jvm.JvmInfo;
|
||||
import org.elasticsearch.monitor.os.OsInfo;
|
||||
import org.opensearch.monitor.fs.FsInfo;
|
||||
import org.opensearch.monitor.jvm.JvmInfo;
|
||||
import org.opensearch.monitor.os.OsInfo;
|
||||
import org.opensearch.plugins.PluginInfo;
|
||||
import org.opensearch.transport.TransportInfo;
|
||||
|
||||
|
@ -247,7 +247,7 @@ public class ClusterStatsNodes implements ToXContentFragment {
|
|||
final int allocatedProcessors;
|
||||
final ObjectIntHashMap<String> names;
|
||||
final ObjectIntHashMap<String> prettyNames;
|
||||
final org.elasticsearch.monitor.os.OsStats.Mem mem;
|
||||
final org.opensearch.monitor.os.OsStats.Mem mem;
|
||||
|
||||
/**
|
||||
* Build the stats from information about each node.
|
||||
|
@ -285,7 +285,7 @@ public class ClusterStatsNodes implements ToXContentFragment {
|
|||
}
|
||||
}
|
||||
}
|
||||
this.mem = new org.elasticsearch.monitor.os.OsStats.Mem(totalMemory, freeMemory);
|
||||
this.mem = new org.opensearch.monitor.os.OsStats.Mem(totalMemory, freeMemory);
|
||||
}
|
||||
|
||||
public int getAvailableProcessors() {
|
||||
|
@ -296,7 +296,7 @@ public class ClusterStatsNodes implements ToXContentFragment {
|
|||
return allocatedProcessors;
|
||||
}
|
||||
|
||||
public org.elasticsearch.monitor.os.OsStats.Mem getMem() {
|
||||
public org.opensearch.monitor.os.OsStats.Mem getMem() {
|
||||
return mem;
|
||||
}
|
||||
|
||||
|
@ -460,7 +460,7 @@ public class ClusterStatsNodes implements ToXContentFragment {
|
|||
}
|
||||
|
||||
for (NodeStats nodeStats : nodeStatsList) {
|
||||
org.elasticsearch.monitor.jvm.JvmStats js = nodeStats.getJvm();
|
||||
org.opensearch.monitor.jvm.JvmStats js = nodeStats.getJvm();
|
||||
if (js == null) {
|
||||
continue;
|
||||
}
|
||||
|
@ -708,12 +708,12 @@ public class ClusterStatsNodes implements ToXContentFragment {
|
|||
for (NodeStats nodeStat : nodeStats) {
|
||||
if (nodeStat.getIngestStats() != null) {
|
||||
for (Map.Entry<String,
|
||||
List<org.elasticsearch.ingest.IngestStats.ProcessorStat>> processorStats : nodeStat.getIngestStats()
|
||||
List<org.opensearch.ingest.IngestStats.ProcessorStat>> processorStats : nodeStat.getIngestStats()
|
||||
.getProcessorStats().entrySet()) {
|
||||
pipelineIds.add(processorStats.getKey());
|
||||
for (org.elasticsearch.ingest.IngestStats.ProcessorStat stat : processorStats.getValue()) {
|
||||
for (org.opensearch.ingest.IngestStats.ProcessorStat stat : processorStats.getValue()) {
|
||||
stats.compute(stat.getType(), (k, v) -> {
|
||||
org.elasticsearch.ingest.IngestStats.Stats nodeIngestStats = stat.getStats();
|
||||
org.opensearch.ingest.IngestStats.Stats nodeIngestStats = stat.getStats();
|
||||
if (v == null) {
|
||||
return new long[] {
|
||||
nodeIngestStats.getIngestCount(),
|
||||
|
|
|
@ -20,7 +20,7 @@
|
|||
package org.opensearch.action.admin.indices.alias;
|
||||
|
||||
import org.opensearch.OpenSearchGenerationException;
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.ParseField;
|
||||
import org.opensearch.common.Strings;
|
||||
|
@ -34,7 +34,7 @@ import org.opensearch.common.xcontent.XContentBuilder;
|
|||
import org.opensearch.common.xcontent.XContentFactory;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.opensearch.common.xcontent.XContentType;
|
||||
import org.elasticsearch.index.query.QueryBuilder;
|
||||
import org.opensearch.index.query.QueryBuilder;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.io.InputStream;
|
||||
|
|
|
@ -20,7 +20,7 @@ package org.opensearch.action.admin.indices.alias.exists;
|
|||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.opensearch.action.admin.indices.alias.get.GetAliasesRequest;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeReadAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
import org.opensearch.cluster.block.ClusterBlockException;
|
||||
|
|
|
@ -34,7 +34,7 @@ import org.opensearch.common.xcontent.ToXContentFragment;
|
|||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.index.analysis.NameOrDefinition;
|
||||
import org.opensearch.index.analysis.NameOrDefinition;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.ArrayList;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.cache.clear;
|
||||
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.xcontent.ConstructingObjectParser;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.indices.close;
|
|||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionRequestValidationException;
|
||||
import org.opensearch.action.IndicesRequest;
|
||||
import org.elasticsearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.action.support.master.AcknowledgedRequest;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
|
|
|
@ -19,8 +19,8 @@
|
|||
package org.opensearch.action.admin.indices.close;
|
||||
|
||||
import org.opensearch.OpenSearchException;
|
||||
import org.elasticsearch.Version;
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.master.ShardsAcknowledgedResponse;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.Strings;
|
||||
|
@ -30,7 +30,7 @@ import org.opensearch.common.io.stream.Writeable;
|
|||
import org.opensearch.common.util.CollectionUtils;
|
||||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.Index;
|
||||
import org.opensearch.index.Index;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.List;
|
||||
|
|
|
@ -25,7 +25,7 @@ import org.opensearch.action.ActionListener;
|
|||
import org.opensearch.action.admin.indices.flush.FlushRequest;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.replication.ReplicationOperation;
|
||||
import org.elasticsearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationResponse;
|
||||
import org.opensearch.action.support.replication.TransportReplicationAction;
|
||||
import org.opensearch.cluster.action.shard.ShardStateAction;
|
||||
|
|
|
@ -26,7 +26,7 @@ import org.opensearch.cluster.ack.ClusterStateUpdateRequest;
|
|||
import org.opensearch.cluster.block.ClusterBlock;
|
||||
import org.opensearch.cluster.metadata.IndexMetadata;
|
||||
import org.opensearch.common.settings.Settings;
|
||||
import org.elasticsearch.index.Index;
|
||||
import org.opensearch.index.Index;
|
||||
|
||||
import java.util.HashMap;
|
||||
import java.util.HashSet;
|
||||
|
|
|
@ -20,7 +20,7 @@
|
|||
package org.opensearch.action.admin.indices.exists.indices;
|
||||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeReadAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
package org.opensearch.action.admin.indices.exists.types;
|
||||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeReadAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
import org.opensearch.cluster.block.ClusterBlockException;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.flush;
|
||||
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.xcontent.ConstructingObjectParser;
|
||||
|
|
|
@ -19,11 +19,11 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.flush;
|
||||
|
||||
import org.elasticsearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
|
|
|
@ -26,8 +26,8 @@ import org.opensearch.common.io.stream.Writeable;
|
|||
import org.opensearch.common.util.iterable.Iterables;
|
||||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.indices.flush.ShardsSyncedFlushResult;
|
||||
import org.elasticsearch.indices.flush.SyncedFlushService;
|
||||
import org.opensearch.indices.flush.ShardsSyncedFlushResult;
|
||||
import org.opensearch.indices.flush.SyncedFlushService;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -23,7 +23,7 @@ import org.opensearch.action.ActionListener;
|
|||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.HandledTransportAction;
|
||||
import org.opensearch.common.inject.Inject;
|
||||
import org.elasticsearch.indices.flush.SyncedFlushService;
|
||||
import org.opensearch.indices.flush.SyncedFlushService;
|
||||
import org.opensearch.tasks.Task;
|
||||
import org.opensearch.transport.TransportService;
|
||||
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.forcemerge;
|
||||
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.support.broadcast.BroadcastRequest;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.UUIDs;
|
||||
|
@ -57,7 +57,7 @@ public class ForceMergeRequest extends BroadcastRequest<ForceMergeRequest> {
|
|||
|
||||
/**
|
||||
* Force merge UUID to store in the live commit data of a shard under
|
||||
* {@link org.elasticsearch.index.engine.Engine#FORCE_MERGE_UUID_KEY} after force merging it.
|
||||
* {@link org.opensearch.index.engine.Engine#FORCE_MERGE_UUID_KEY} after force merging it.
|
||||
*/
|
||||
@Nullable
|
||||
private final String forceMergeUUID;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.forcemerge;
|
||||
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.xcontent.ConstructingObjectParser;
|
||||
|
|
|
@ -20,7 +20,6 @@
|
|||
package org.opensearch.action.admin.indices.get;
|
||||
|
||||
import com.carrotsearch.hppc.cursors.ObjectObjectCursor;
|
||||
|
||||
import org.apache.lucene.util.CollectionUtil;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionResponse;
|
||||
|
@ -35,7 +34,7 @@ import org.opensearch.common.xcontent.ToXContentObject;
|
|||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.opensearch.common.xcontent.XContentParser.Token;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.ArrayList;
|
||||
|
|
|
@ -33,8 +33,8 @@ import org.opensearch.common.xcontent.XContentBuilder;
|
|||
import org.opensearch.common.xcontent.XContentHelper;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.opensearch.common.xcontent.XContentType;
|
||||
import org.elasticsearch.index.mapper.Mapper;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.mapper.Mapper;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
import org.opensearch.rest.BaseRestHandler;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -20,8 +20,8 @@
|
|||
package org.opensearch.action.admin.indices.mapping.put;
|
||||
|
||||
import com.carrotsearch.hppc.ObjectHashSet;
|
||||
import org.elasticsearch.OpenSearchGenerationException;
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.OpenSearchGenerationException;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionRequestValidationException;
|
||||
import org.opensearch.action.IndicesRequest;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
|
@ -32,13 +32,13 @@ import org.opensearch.common.bytes.BytesArray;
|
|||
import org.opensearch.common.bytes.BytesReference;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.util.CollectionUtils;
|
||||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentFactory;
|
||||
import org.opensearch.common.xcontent.XContentHelper;
|
||||
import org.opensearch.common.xcontent.XContentType;
|
||||
import org.elasticsearch.index.Index;
|
||||
import org.opensearch.index.Index;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.io.InputStream;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.indices.open;
|
|||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionRequestValidationException;
|
||||
import org.opensearch.action.IndicesRequest;
|
||||
import org.elasticsearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.action.support.master.AcknowledgedRequest;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
package org.opensearch.action.admin.indices.readonly;
|
||||
|
||||
import org.opensearch.OpenSearchException;
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.master.ShardsAcknowledgedResponse;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.Strings;
|
||||
|
@ -29,7 +29,7 @@ import org.opensearch.common.io.stream.Writeable;
|
|||
import org.opensearch.common.util.CollectionUtils;
|
||||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.Index;
|
||||
import org.opensearch.index.Index;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.List;
|
||||
|
|
|
@ -24,7 +24,7 @@ import org.opensearch.action.ActionListener;
|
|||
import org.opensearch.action.ActionType;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.replication.ReplicationOperation;
|
||||
import org.elasticsearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationResponse;
|
||||
import org.opensearch.action.support.replication.TransportReplicationAction;
|
||||
import org.opensearch.cluster.action.shard.ShardStateAction;
|
||||
|
|
|
@ -19,13 +19,13 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.recovery;
|
||||
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.Strings;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.indices.recovery.RecoveryState;
|
||||
import org.opensearch.indices.recovery.RecoveryState;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.List;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.refresh;
|
||||
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.xcontent.ConstructingObjectParser;
|
||||
|
|
|
@ -21,7 +21,7 @@ package org.opensearch.action.admin.indices.rollover;
|
|||
import org.opensearch.action.ActionRequestValidationException;
|
||||
import org.opensearch.action.IndicesRequest;
|
||||
import org.opensearch.action.admin.indices.create.CreateIndexRequest;
|
||||
import org.elasticsearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.action.support.master.AcknowledgedRequest;
|
||||
import org.opensearch.common.ParseField;
|
||||
|
@ -33,7 +33,7 @@ import org.opensearch.common.xcontent.ObjectParser;
|
|||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.HashMap;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.segments;
|
||||
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.util.Arrays;
|
||||
import java.util.Iterator;
|
||||
|
|
|
@ -24,13 +24,13 @@ import org.apache.lucene.search.SortField;
|
|||
import org.apache.lucene.search.SortedNumericSortField;
|
||||
import org.apache.lucene.search.SortedSetSortField;
|
||||
import org.apache.lucene.util.Accountable;
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.unit.ByteSizeValue;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.engine.Segment;
|
||||
import org.opensearch.index.engine.Segment;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.ArrayList;
|
||||
|
|
|
@ -23,7 +23,7 @@ import org.opensearch.cluster.routing.ShardRouting;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.io.stream.Writeable;
|
||||
import org.elasticsearch.index.engine.Segment;
|
||||
import org.opensearch.index.engine.Segment;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Iterator;
|
||||
|
|
|
@ -35,7 +35,7 @@ import org.opensearch.common.regex.Regex;
|
|||
import org.opensearch.common.settings.IndexScopedSettings;
|
||||
import org.opensearch.common.settings.Settings;
|
||||
import org.opensearch.common.settings.SettingsFilter;
|
||||
import org.elasticsearch.common.util.CollectionUtils;
|
||||
import org.opensearch.common.util.CollectionUtils;
|
||||
import org.opensearch.index.Index;
|
||||
import org.opensearch.threadpool.ThreadPool;
|
||||
import org.opensearch.transport.TransportService;
|
||||
|
|
|
@ -22,10 +22,10 @@ package org.opensearch.action.admin.indices.shards;
|
|||
import com.carrotsearch.hppc.cursors.IntObjectCursor;
|
||||
import com.carrotsearch.hppc.cursors.ObjectObjectCursor;
|
||||
import org.opensearch.OpenSearchException;
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionResponse;
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.elasticsearch.cluster.node.DiscoveryNode;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.cluster.node.DiscoveryNode;
|
||||
import org.opensearch.common.collect.ImmutableOpenIntMap;
|
||||
import org.opensearch.common.collect.ImmutableOpenMap;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
|
|
|
@ -28,23 +28,23 @@ import org.opensearch.common.unit.ByteSizeValue;
|
|||
import org.opensearch.common.xcontent.ToXContent;
|
||||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.cache.query.QueryCacheStats;
|
||||
import org.elasticsearch.index.cache.request.RequestCacheStats;
|
||||
import org.elasticsearch.index.engine.SegmentsStats;
|
||||
import org.elasticsearch.index.fielddata.FieldDataStats;
|
||||
import org.elasticsearch.index.flush.FlushStats;
|
||||
import org.elasticsearch.index.get.GetStats;
|
||||
import org.elasticsearch.index.merge.MergeStats;
|
||||
import org.elasticsearch.index.recovery.RecoveryStats;
|
||||
import org.elasticsearch.index.refresh.RefreshStats;
|
||||
import org.elasticsearch.index.search.stats.SearchStats;
|
||||
import org.elasticsearch.index.shard.DocsStats;
|
||||
import org.elasticsearch.index.shard.IndexShard;
|
||||
import org.elasticsearch.index.shard.IndexingStats;
|
||||
import org.elasticsearch.index.store.StoreStats;
|
||||
import org.elasticsearch.index.translog.TranslogStats;
|
||||
import org.elasticsearch.index.warmer.WarmerStats;
|
||||
import org.elasticsearch.indices.IndicesQueryCache;
|
||||
import org.opensearch.index.cache.query.QueryCacheStats;
|
||||
import org.opensearch.index.cache.request.RequestCacheStats;
|
||||
import org.opensearch.index.engine.SegmentsStats;
|
||||
import org.opensearch.index.fielddata.FieldDataStats;
|
||||
import org.opensearch.index.flush.FlushStats;
|
||||
import org.opensearch.index.get.GetStats;
|
||||
import org.opensearch.index.merge.MergeStats;
|
||||
import org.opensearch.index.recovery.RecoveryStats;
|
||||
import org.opensearch.index.refresh.RefreshStats;
|
||||
import org.opensearch.index.search.stats.SearchStats;
|
||||
import org.opensearch.index.shard.DocsStats;
|
||||
import org.opensearch.index.shard.IndexShard;
|
||||
import org.opensearch.index.shard.IndexingStats;
|
||||
import org.opensearch.index.store.StoreStats;
|
||||
import org.opensearch.index.translog.TranslogStats;
|
||||
import org.opensearch.index.warmer.WarmerStats;
|
||||
import org.opensearch.indices.IndicesQueryCache;
|
||||
import org.opensearch.search.suggest.completion.CompletionStats;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.indices.stats;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.io.stream.Writeable;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Arrays;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.indices.template.delete;
|
|||
import org.apache.logging.log4j.LogManager;
|
||||
import org.apache.logging.log4j.Logger;
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.master.AcknowledgedResponse;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.indices.template.delete;
|
|||
import org.apache.logging.log4j.LogManager;
|
||||
import org.apache.logging.log4j.Logger;
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.master.AcknowledgedResponse;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
|
|
|
@ -22,7 +22,7 @@ import org.apache.logging.log4j.LogManager;
|
|||
import org.apache.logging.log4j.Logger;
|
||||
import org.apache.logging.log4j.message.ParameterizedMessage;
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.master.AcknowledgedResponse;
|
||||
import org.opensearch.action.support.master.TransportMasterNodeAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.upgrade.get;
|
||||
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.util.Arrays;
|
||||
import java.util.Iterator;
|
||||
|
|
|
@ -23,7 +23,7 @@ package org.opensearch.action.admin.indices.upgrade.post;
|
|||
import org.opensearch.action.support.broadcast.BroadcastShardRequest;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
|
|
|
@ -23,7 +23,7 @@ import org.opensearch.Version;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.io.stream.Writeable;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.text.ParseException;
|
||||
|
|
|
@ -20,7 +20,7 @@
|
|||
package org.opensearch.action.admin.indices.upgrade.post;
|
||||
|
||||
import org.opensearch.Version;
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.collect.Tuple;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
|
|
|
@ -23,8 +23,8 @@ import org.opensearch.action.support.broadcast.BroadcastShardRequest;
|
|||
import org.opensearch.common.Strings;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.query.QueryBuilder;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.query.QueryBuilder;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.search.internal.AliasFilter;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -22,7 +22,7 @@ package org.opensearch.action.admin.indices.validate.query;
|
|||
import org.opensearch.action.support.broadcast.BroadcastShardResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
|
|
|
@ -80,7 +80,7 @@ public class TransportValidateQueryAction extends TransportBroadcastAction<
|
|||
protected void doExecute(Task task, ValidateQueryRequest request, ActionListener<ValidateQueryResponse> listener) {
|
||||
request.nowInMillis = System.currentTimeMillis();
|
||||
LongSupplier timeProvider = () -> request.nowInMillis;
|
||||
ActionListener<org.elasticsearch.index.query.QueryBuilder> rewriteListener = ActionListener.wrap(rewrittenQuery -> {
|
||||
ActionListener<org.opensearch.index.query.QueryBuilder> rewriteListener = ActionListener.wrap(rewrittenQuery -> {
|
||||
request.query(rewrittenQuery);
|
||||
super.doExecute(task, request, listener);
|
||||
},
|
||||
|
|
|
@ -41,7 +41,7 @@ public class ValidateQueryRequestBuilder
|
|||
/**
|
||||
* The query to validate.
|
||||
*
|
||||
* @see org.elasticsearch.index.query.QueryBuilders
|
||||
* @see org.opensearch.index.query.QueryBuilders
|
||||
*/
|
||||
public ValidateQueryRequestBuilder setQuery(QueryBuilder queryBuilder) {
|
||||
request.query(queryBuilder);
|
||||
|
@ -51,7 +51,7 @@ public class ValidateQueryRequestBuilder
|
|||
/**
|
||||
* Indicates if detailed information about the query should be returned.
|
||||
*
|
||||
* @see org.elasticsearch.index.query.QueryBuilders
|
||||
* @see org.opensearch.index.query.QueryBuilders
|
||||
*/
|
||||
public ValidateQueryRequestBuilder setExplain(boolean explain) {
|
||||
request.explain(explain);
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.admin.indices.validate.query;
|
||||
|
||||
import org.elasticsearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.DefaultShardOperationFailedException;
|
||||
import org.opensearch.action.support.broadcast.BroadcastResponse;
|
||||
import org.opensearch.common.ParseField;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
|
|
|
@ -27,7 +27,7 @@ import org.opensearch.common.Strings;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.io.stream.Writeable;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Objects;
|
||||
|
|
|
@ -19,9 +19,9 @@
|
|||
|
||||
package org.opensearch.action.bulk;
|
||||
|
||||
import org.opensearch.OpenSearchException;
|
||||
import org.opensearch.ExceptionsHelper;
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.OpenSearchException;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.DocWriteRequest.OpType;
|
||||
import org.opensearch.action.DocWriteResponse;
|
||||
import org.opensearch.action.delete.DeleteResponse;
|
||||
|
@ -38,8 +38,8 @@ import org.opensearch.common.xcontent.StatusToXContentObject;
|
|||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.index.seqno.SequenceNumbers;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.seqno.SequenceNumbers;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -23,11 +23,11 @@ import org.opensearch.action.DocWriteRequest;
|
|||
import org.opensearch.action.DocWriteResponse;
|
||||
import org.opensearch.action.delete.DeleteResponse;
|
||||
import org.opensearch.action.index.IndexResponse;
|
||||
import org.elasticsearch.action.support.replication.ReplicationResponse;
|
||||
import org.elasticsearch.action.support.replication.TransportWriteAction;
|
||||
import org.elasticsearch.index.engine.Engine;
|
||||
import org.elasticsearch.index.shard.IndexShard;
|
||||
import org.elasticsearch.index.translog.Translog;
|
||||
import org.opensearch.action.support.replication.ReplicationResponse;
|
||||
import org.opensearch.action.support.replication.TransportWriteAction;
|
||||
import org.opensearch.index.engine.Engine;
|
||||
import org.opensearch.index.shard.IndexShard;
|
||||
import org.opensearch.index.translog.Translog;
|
||||
|
||||
import java.util.Arrays;
|
||||
|
||||
|
|
|
@ -21,7 +21,7 @@ package org.opensearch.action.bulk;
|
|||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.opensearch.action.DocWriteRequest;
|
||||
import org.elasticsearch.action.delete.DeleteRequest;
|
||||
import org.opensearch.action.delete.DeleteRequest;
|
||||
import org.opensearch.action.index.IndexRequest;
|
||||
import org.opensearch.client.Client;
|
||||
import org.opensearch.common.Nullable;
|
||||
|
|
|
@ -29,7 +29,7 @@ import org.opensearch.action.delete.DeleteRequest;
|
|||
import org.opensearch.action.index.IndexRequest;
|
||||
import org.opensearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.WriteRequest;
|
||||
import org.elasticsearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.update.UpdateRequest;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.Strings;
|
||||
|
@ -39,7 +39,7 @@ import org.opensearch.common.io.stream.StreamInput;
|
|||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.unit.TimeValue;
|
||||
import org.opensearch.common.xcontent.XContentType;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
import org.opensearch.search.fetch.subphase.FetchSourceContext;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -26,14 +26,14 @@ import org.opensearch.action.index.IndexRequest;
|
|||
import org.opensearch.action.index.IndexRequestBuilder;
|
||||
import org.opensearch.action.support.ActiveShardCount;
|
||||
import org.opensearch.action.support.WriteRequestBuilder;
|
||||
import org.elasticsearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.update.UpdateRequest;
|
||||
import org.opensearch.action.update.UpdateRequestBuilder;
|
||||
import org.opensearch.client.OpenSearchClient;
|
||||
import org.opensearch.common.Nullable;
|
||||
import org.opensearch.common.unit.TimeValue;
|
||||
import org.opensearch.common.xcontent.XContentType;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
|
||||
/**
|
||||
* A bulk request holds an ordered {@link IndexRequest}s and {@link DeleteRequest}s and allows to executes
|
||||
|
|
|
@ -23,7 +23,7 @@ import org.apache.lucene.util.Accountable;
|
|||
import org.apache.lucene.util.RamUsageEstimator;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.support.replication.ReplicatedWriteRequest;
|
||||
import org.elasticsearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
|
|
@ -21,11 +21,11 @@ package org.opensearch.action.bulk;
|
|||
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.DocWriteResponse;
|
||||
import org.elasticsearch.action.support.WriteResponse;
|
||||
import org.opensearch.action.support.WriteResponse;
|
||||
import org.opensearch.action.support.replication.ReplicationResponse;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
|
|
|
@ -20,8 +20,8 @@
|
|||
package org.opensearch.action.bulk;
|
||||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.elasticsearch.index.mapper.Mapping;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.mapper.Mapping;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
public interface MappingUpdatePerformer {
|
||||
|
||||
|
|
|
@ -28,8 +28,8 @@ import org.opensearch.action.ActionListener;
|
|||
import org.opensearch.action.ActionRunnable;
|
||||
import org.opensearch.action.DocWriteRequest;
|
||||
import org.opensearch.action.DocWriteResponse;
|
||||
import org.elasticsearch.action.delete.DeleteRequest;
|
||||
import org.elasticsearch.action.delete.DeleteResponse;
|
||||
import org.opensearch.action.delete.DeleteRequest;
|
||||
import org.opensearch.action.delete.DeleteResponse;
|
||||
import org.opensearch.action.index.IndexRequest;
|
||||
import org.opensearch.action.index.IndexResponse;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
|
|
|
@ -22,10 +22,10 @@ package org.opensearch.action.bulk;
|
|||
import org.opensearch.action.ActionListener;
|
||||
import org.opensearch.action.DocWriteRequest;
|
||||
import org.opensearch.action.DocWriteResponse;
|
||||
import org.elasticsearch.action.support.ActionFilters;
|
||||
import org.elasticsearch.action.support.HandledTransportAction;
|
||||
import org.elasticsearch.action.support.WriteRequest;
|
||||
import org.elasticsearch.action.support.WriteResponse;
|
||||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.HandledTransportAction;
|
||||
import org.opensearch.action.support.WriteRequest;
|
||||
import org.opensearch.action.support.WriteResponse;
|
||||
import org.opensearch.action.support.replication.ReplicatedWriteRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationResponse;
|
||||
import org.opensearch.common.io.stream.Writeable;
|
||||
|
|
|
@ -20,7 +20,7 @@
|
|||
package org.opensearch.action.delete;
|
||||
|
||||
import org.apache.lucene.util.RamUsageEstimator;
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionRequestValidationException;
|
||||
import org.opensearch.action.CompositeIndicesRequest;
|
||||
import org.opensearch.action.DocWriteRequest;
|
||||
|
@ -30,15 +30,15 @@ import org.opensearch.common.Strings;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.lucene.uid.Versions;
|
||||
import org.elasticsearch.index.VersionType;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.VersionType;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
import static org.opensearch.action.ValidateActions.addValidationError;
|
||||
import static org.elasticsearch.index.seqno.SequenceNumbers.UNASSIGNED_PRIMARY_TERM;
|
||||
import static org.elasticsearch.index.seqno.SequenceNumbers.UNASSIGNED_SEQ_NO;
|
||||
import static org.opensearch.index.seqno.SequenceNumbers.UNASSIGNED_PRIMARY_TERM;
|
||||
import static org.opensearch.index.seqno.SequenceNumbers.UNASSIGNED_SEQ_NO;
|
||||
|
||||
/**
|
||||
* A request to delete a document from an index based on its type and id. Best created using
|
||||
|
@ -249,7 +249,7 @@ public class DeleteRequest extends ReplicatedWriteRequest<DeleteRequest>
|
|||
/**
|
||||
* If set, only perform this delete request if the document was last modification was assigned this sequence number.
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public long ifSeqNo() {
|
||||
return ifSeqNo;
|
||||
|
@ -259,7 +259,7 @@ public class DeleteRequest extends ReplicatedWriteRequest<DeleteRequest>
|
|||
* If set, only perform this delete request if the document was last modification was assigned this primary term.
|
||||
*
|
||||
* If the document last modification was assigned a different term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public long ifPrimaryTerm() {
|
||||
return ifPrimaryTerm;
|
||||
|
@ -270,7 +270,7 @@ public class DeleteRequest extends ReplicatedWriteRequest<DeleteRequest>
|
|||
* sequence number. Must be used in combination with {@link #setIfPrimaryTerm(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public DeleteRequest setIfSeqNo(long seqNo) {
|
||||
if (seqNo < 0 && seqNo != UNASSIGNED_SEQ_NO) {
|
||||
|
@ -285,7 +285,7 @@ public class DeleteRequest extends ReplicatedWriteRequest<DeleteRequest>
|
|||
* primary term. Must be used in combination with {@link #setIfSeqNo(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different primary term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public DeleteRequest setIfPrimaryTerm(long term) {
|
||||
if (term < 0) {
|
||||
|
|
|
@ -86,7 +86,7 @@ public class DeleteRequestBuilder extends ReplicationRequestBuilder<DeleteReques
|
|||
* sequence number. Must be used in combination with {@link #setIfPrimaryTerm(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public DeleteRequestBuilder setIfSeqNo(long seqNo) {
|
||||
request.setIfSeqNo(seqNo);
|
||||
|
@ -98,7 +98,7 @@ public class DeleteRequestBuilder extends ReplicationRequestBuilder<DeleteReques
|
|||
* primary term. Must be used in combination with {@link #setIfSeqNo(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public DeleteRequestBuilder setIfPrimaryTerm(long term) {
|
||||
request.setIfPrimaryTerm(term);
|
||||
|
|
|
@ -28,8 +28,8 @@ import org.opensearch.common.io.stream.StreamInput;
|
|||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.elasticsearch.index.query.QueryBuilder;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.query.QueryBuilder;
|
||||
import org.opensearch.search.fetch.subphase.FetchSourceContext;
|
||||
import org.opensearch.search.internal.AliasFilter;
|
||||
|
||||
|
|
|
@ -28,7 +28,7 @@ import org.opensearch.common.xcontent.ConstructingObjectParser;
|
|||
import org.opensearch.common.xcontent.StatusToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.index.get.GetResult;
|
||||
import org.opensearch.index.get.GetResult;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -17,7 +17,7 @@
|
|||
* under the License.
|
||||
*/
|
||||
|
||||
package org.elasticsearch.action.explain;
|
||||
package org.opensearch.action.explain;
|
||||
|
||||
import org.apache.lucene.index.Term;
|
||||
import org.apache.lucene.search.Explanation;
|
||||
|
|
|
@ -27,8 +27,8 @@ import org.opensearch.action.OriginalIndices;
|
|||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.query.QueryBuilder;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.query.QueryBuilder;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Objects;
|
||||
|
|
|
@ -30,7 +30,7 @@ import org.opensearch.common.io.stream.StreamInput;
|
|||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.elasticsearch.index.query.QueryBuilder;
|
||||
import org.opensearch.index.query.QueryBuilder;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Arrays;
|
||||
|
|
|
@ -21,7 +21,7 @@ package org.opensearch.action.fieldcaps;
|
|||
|
||||
import org.opensearch.action.ActionRequestBuilder;
|
||||
import org.opensearch.client.OpenSearchClient;
|
||||
import org.elasticsearch.index.query.QueryBuilder;
|
||||
import org.opensearch.index.query.QueryBuilder;
|
||||
|
||||
public class FieldCapabilitiesRequestBuilder extends ActionRequestBuilder<FieldCapabilitiesRequest, FieldCapabilitiesResponse> {
|
||||
public FieldCapabilitiesRequestBuilder(OpenSearchClient client,
|
||||
|
|
|
@ -17,7 +17,7 @@
|
|||
* under the License.
|
||||
*/
|
||||
|
||||
package org.elasticsearch.action.fieldcaps;
|
||||
package org.opensearch.action.fieldcaps;
|
||||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.opensearch.action.OriginalIndices;
|
||||
|
|
|
@ -17,7 +17,7 @@
|
|||
* under the License.
|
||||
*/
|
||||
|
||||
package org.elasticsearch.action.fieldcaps;
|
||||
package org.opensearch.action.fieldcaps;
|
||||
|
||||
import org.apache.logging.log4j.LogManager;
|
||||
import org.apache.logging.log4j.Logger;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.get;
|
||||
|
||||
import org.elasticsearch.Version;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionRequestValidationException;
|
||||
import org.opensearch.action.RealtimeRequest;
|
||||
import org.opensearch.action.ValidateActions;
|
||||
|
@ -29,8 +29,8 @@ import org.opensearch.common.Strings;
|
|||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.opensearch.common.lucene.uid.Versions;
|
||||
import org.elasticsearch.index.VersionType;
|
||||
import org.elasticsearch.index.mapper.MapperService;
|
||||
import org.opensearch.index.VersionType;
|
||||
import org.opensearch.index.mapper.MapperService;
|
||||
import org.opensearch.search.fetch.subphase.FetchSourceContext;
|
||||
|
||||
import java.io.IOException;
|
||||
|
@ -266,7 +266,7 @@ public class GetRequest extends SingleShardRequest<GetRequest> implements Realti
|
|||
}
|
||||
|
||||
/**
|
||||
* Sets the versioning type. Defaults to {@link org.elasticsearch.index.VersionType#INTERNAL}.
|
||||
* Sets the versioning type. Defaults to {@link org.opensearch.index.VersionType#INTERNAL}.
|
||||
*/
|
||||
public GetRequest versionType(VersionType versionType) {
|
||||
this.versionType = versionType;
|
||||
|
|
|
@ -146,7 +146,7 @@ public class GetRequestBuilder extends SingleShardOperationRequestBuilder<GetReq
|
|||
}
|
||||
|
||||
/**
|
||||
* Sets the versioning type. Defaults to {@link org.elasticsearch.index.VersionType#INTERNAL}.
|
||||
* Sets the versioning type. Defaults to {@link org.opensearch.index.VersionType#INTERNAL}.
|
||||
*/
|
||||
public GetRequestBuilder setVersionType(VersionType versionType) {
|
||||
request.versionType(versionType);
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.get;
|
||||
|
||||
import org.elasticsearch.OpenSearchParseException;
|
||||
import org.opensearch.OpenSearchParseException;
|
||||
import org.opensearch.action.ActionResponse;
|
||||
import org.opensearch.common.ParsingException;
|
||||
import org.opensearch.common.Strings;
|
||||
|
@ -30,7 +30,7 @@ import org.opensearch.common.io.stream.StreamOutput;
|
|||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.index.get.GetResult;
|
||||
import org.opensearch.index.get.GetResult;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Iterator;
|
||||
|
|
|
@ -19,7 +19,7 @@
|
|||
|
||||
package org.opensearch.action.get;
|
||||
|
||||
import org.elasticsearch.OpenSearchParseException;
|
||||
import org.opensearch.OpenSearchParseException;
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.ActionRequest;
|
||||
import org.opensearch.action.ActionRequestValidationException;
|
||||
|
@ -40,7 +40,7 @@ import org.opensearch.common.xcontent.ToXContentObject;
|
|||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.opensearch.common.xcontent.XContentParser.Token;
|
||||
import org.elasticsearch.index.VersionType;
|
||||
import org.opensearch.index.VersionType;
|
||||
import org.opensearch.search.fetch.subphase.FetchSourceContext;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -29,7 +29,7 @@ import org.opensearch.common.xcontent.ToXContentObject;
|
|||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.opensearch.common.xcontent.XContentParser.Token;
|
||||
import org.elasticsearch.index.get.GetResult;
|
||||
import org.opensearch.index.get.GetResult;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.ArrayList;
|
||||
|
|
|
@ -29,7 +29,7 @@ import org.opensearch.cluster.metadata.IndexNameExpressionResolver;
|
|||
import org.opensearch.cluster.service.ClusterService;
|
||||
import org.opensearch.common.inject.Inject;
|
||||
import org.opensearch.common.util.concurrent.AtomicArray;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.tasks.Task;
|
||||
import org.opensearch.transport.TransportService;
|
||||
|
||||
|
|
|
@ -28,7 +28,7 @@ import org.opensearch.action.DocWriteRequest;
|
|||
import org.opensearch.action.RoutingMissingException;
|
||||
import org.opensearch.action.support.IndicesOptions;
|
||||
import org.opensearch.action.support.replication.ReplicatedWriteRequest;
|
||||
import org.elasticsearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.action.support.replication.ReplicationRequest;
|
||||
import org.opensearch.client.Requests;
|
||||
import org.opensearch.cluster.metadata.MappingMetadata;
|
||||
import org.opensearch.cluster.metadata.Metadata;
|
||||
|
@ -39,7 +39,7 @@ import org.opensearch.common.bytes.BytesArray;
|
|||
import org.opensearch.common.bytes.BytesReference;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.common.lucene.uid.Versions;
|
||||
import org.opensearch.common.lucene.uid.Versions;
|
||||
import org.opensearch.common.unit.ByteSizeValue;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentFactory;
|
||||
|
@ -619,7 +619,7 @@ public class IndexRequest extends ReplicatedWriteRequest<IndexRequest> implement
|
|||
* sequence number. Must be used in combination with {@link #setIfPrimaryTerm(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public IndexRequest setIfSeqNo(long seqNo) {
|
||||
if (seqNo < 0 && seqNo != UNASSIGNED_SEQ_NO) {
|
||||
|
@ -634,7 +634,7 @@ public class IndexRequest extends ReplicatedWriteRequest<IndexRequest> implement
|
|||
* primary term. Must be used in combination with {@link #setIfSeqNo(long)}
|
||||
*
|
||||
* If the document last modification was assigned a different term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public IndexRequest setIfPrimaryTerm(long term) {
|
||||
if (term < 0) {
|
||||
|
@ -647,7 +647,7 @@ public class IndexRequest extends ReplicatedWriteRequest<IndexRequest> implement
|
|||
/**
|
||||
* If set, only perform this indexing request if the document was last modification was assigned this sequence number.
|
||||
* If the document last modification was assigned a different sequence number a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public long ifSeqNo() {
|
||||
return ifSeqNo;
|
||||
|
@ -657,7 +657,7 @@ public class IndexRequest extends ReplicatedWriteRequest<IndexRequest> implement
|
|||
* If set, only perform this indexing request if the document was last modification was assigned this primary term.
|
||||
*
|
||||
* If the document last modification was assigned a different term a
|
||||
* {@link org.elasticsearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
* {@link org.opensearch.index.engine.VersionConflictEngineException} will be thrown.
|
||||
*/
|
||||
public long ifPrimaryTerm() {
|
||||
return ifPrimaryTerm;
|
||||
|
|
|
@ -23,7 +23,7 @@ import org.opensearch.action.DocWriteResponse;
|
|||
import org.opensearch.common.Strings;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
|
|
|
@ -28,15 +28,15 @@ import org.opensearch.common.xcontent.StatusToXContentObject;
|
|||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.opensearch.common.xcontent.XContentParser.Token;
|
||||
import org.elasticsearch.ingest.PipelineConfiguration;
|
||||
import org.opensearch.ingest.PipelineConfiguration;
|
||||
import org.opensearch.rest.RestStatus;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.ArrayList;
|
||||
import java.util.Collections;
|
||||
import java.util.HashMap;
|
||||
import java.util.List;
|
||||
import java.util.Map;
|
||||
import java.util.HashMap;
|
||||
|
||||
import static org.opensearch.common.xcontent.XContentParserUtils.ensureExpectedToken;
|
||||
|
||||
|
|
|
@ -26,7 +26,7 @@ import org.opensearch.common.io.stream.StreamOutput;
|
|||
import org.opensearch.common.xcontent.ConstructingObjectParser;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.ingest.IngestDocument;
|
||||
import org.opensearch.ingest.IngestDocument;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
|
|
|
@ -21,9 +21,9 @@ package org.opensearch.action.ingest;
|
|||
|
||||
import org.opensearch.action.ActionListener;
|
||||
import org.opensearch.action.ActionRunnable;
|
||||
import org.elasticsearch.ingest.CompoundProcessor;
|
||||
import org.elasticsearch.ingest.IngestDocument;
|
||||
import org.elasticsearch.ingest.Pipeline;
|
||||
import org.opensearch.ingest.CompoundProcessor;
|
||||
import org.opensearch.ingest.IngestDocument;
|
||||
import org.opensearch.ingest.Pipeline;
|
||||
import org.opensearch.threadpool.ThreadPool;
|
||||
|
||||
import java.util.List;
|
||||
|
@ -31,7 +31,7 @@ import java.util.concurrent.CopyOnWriteArrayList;
|
|||
import java.util.concurrent.atomic.AtomicInteger;
|
||||
import java.util.function.BiConsumer;
|
||||
|
||||
import static org.elasticsearch.ingest.TrackingResultProcessor.decorate;
|
||||
import static org.opensearch.ingest.TrackingResultProcessor.decorate;
|
||||
|
||||
class SimulateExecutionService {
|
||||
|
||||
|
|
|
@ -28,12 +28,12 @@ import org.opensearch.common.logging.DeprecationLogger;
|
|||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentType;
|
||||
import org.elasticsearch.index.VersionType;
|
||||
import org.elasticsearch.ingest.ConfigurationUtils;
|
||||
import org.elasticsearch.ingest.IngestDocument;
|
||||
import org.elasticsearch.ingest.IngestDocument.Metadata;
|
||||
import org.elasticsearch.ingest.IngestService;
|
||||
import org.elasticsearch.ingest.Pipeline;
|
||||
import org.opensearch.index.VersionType;
|
||||
import org.opensearch.ingest.ConfigurationUtils;
|
||||
import org.opensearch.ingest.IngestDocument;
|
||||
import org.opensearch.ingest.IngestDocument.Metadata;
|
||||
import org.opensearch.ingest.IngestService;
|
||||
import org.opensearch.ingest.Pipeline;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.ArrayList;
|
||||
|
|
|
@ -29,8 +29,8 @@ import org.opensearch.common.xcontent.ConstructingObjectParser;
|
|||
import org.opensearch.common.xcontent.ToXContentObject;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.ingest.ConfigurationUtils;
|
||||
import org.elasticsearch.ingest.IngestDocument;
|
||||
import org.opensearch.ingest.ConfigurationUtils;
|
||||
import org.opensearch.ingest.IngestDocument;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Locale;
|
||||
|
|
|
@ -28,8 +28,8 @@ import org.opensearch.common.xcontent.ConstructingObjectParser;
|
|||
import org.opensearch.common.xcontent.ToXContentFragment;
|
||||
import org.opensearch.common.xcontent.XContentBuilder;
|
||||
import org.opensearch.common.xcontent.XContentParser;
|
||||
import org.elasticsearch.ingest.IngestDocument;
|
||||
import org.elasticsearch.ingest.IngestDocument.Metadata;
|
||||
import org.opensearch.ingest.IngestDocument;
|
||||
import org.opensearch.ingest.IngestDocument.Metadata;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.time.ZoneId;
|
||||
|
|
|
@ -25,9 +25,9 @@ import org.opensearch.action.ActionListener;
|
|||
import org.opensearch.action.support.ActionFilters;
|
||||
import org.opensearch.action.support.HandledTransportAction;
|
||||
import org.opensearch.cluster.ClusterState;
|
||||
import org.elasticsearch.cluster.service.ClusterService;
|
||||
import org.opensearch.cluster.service.ClusterService;
|
||||
import org.opensearch.common.inject.Inject;
|
||||
import org.elasticsearch.common.settings.Settings;
|
||||
import org.opensearch.common.settings.Settings;
|
||||
import org.opensearch.node.Node;
|
||||
import org.opensearch.tasks.Task;
|
||||
import org.opensearch.transport.TransportService;
|
||||
|
|
|
@ -20,12 +20,12 @@ package org.opensearch.action.resync;
|
|||
|
||||
import org.opensearch.Version;
|
||||
import org.opensearch.action.index.IndexRequest;
|
||||
import org.elasticsearch.action.support.replication.ReplicatedWriteRequest;
|
||||
import org.opensearch.action.support.replication.ReplicatedWriteRequest;
|
||||
import org.opensearch.common.io.stream.StreamInput;
|
||||
import org.opensearch.common.io.stream.StreamOutput;
|
||||
import org.elasticsearch.index.seqno.SequenceNumbers;
|
||||
import org.elasticsearch.index.shard.ShardId;
|
||||
import org.elasticsearch.index.translog.Translog;
|
||||
import org.opensearch.index.seqno.SequenceNumbers;
|
||||
import org.opensearch.index.shard.ShardId;
|
||||
import org.opensearch.index.translog.Translog;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.util.Arrays;
|
||||
|
|
Some files were not shown because too many files have changed in this diff Show More
Loading…
Reference in New Issue