server/src/main/java/org/opensearch/repositories/blobstore/BlobStoreRepository.java (7 lines):
- line 965: // TODO: Getting here means repository corruption. We should find a way of dealing with this instead of just
- line 1109: * TODO: Add shard level cleanups
- line 1110: * TODO: Add unreferenced index metadata cleanup
- line 1180: // TODO: Include the current generation here once we remove keeping index-(N-1) around from #writeIndexGen
- line 1228: // TODO: We shouldn't be blanket catching and suppressing all exceptions here and instead handle them safely upstream.
- line 1267: // TODO: We shouldn't be blanket catching and suppressing all exceptions here and instead handle them safely upstream.
- line 2344: // TODO apparently we don't use the MetadataSnapshot#.recoveryDiff(...) here but we should
server/src/main/java/org/opensearch/search/aggregations/support/CoreValuesSourceType.java (6 lines):
- line 82: // TODO: Is this the correct exception type here?
- line 104: /* TODO: this silently ignores a timezone argument, whereas NumberFieldType#docValueFormat throws if given a time zone.
- line 169: // TODO: Is this the correct exception type here?
- line 180: // TODO: also support the structured formats of geo points
- line 193: // TODO: Is this the correct exception type here?
- line 207: // TODO: Is this the correct exception type here?
modules/lang-painless/src/main/java/org/opensearch/painless/MethodWriter.java (6 lines):
- line 145: // TODO: introduce a way to ignore internal statements so this assert is not triggered
- line 146: // TODO: https://github.com/elastic/elasticsearch/issues/51836
- line 157: // TODO: maybe track these in bitsets too? this is trickier...
- line 184: // TODO: remove this when the transition from Joda to Java datetimes is completed
- line 222: // TODO: remove this when the transition from Joda to Java datetimes is completed
- line 245: // TODO: remove this when the transition from Joda to Java datetimes is completed
server/src/internalClusterTest/java/org/opensearch/versioning/SimpleVersioningIT.java (6 lines):
- line 239: // TODO: This behavior breaks rest api returning http status 201
- line 359: // TODO: ADD SEQ NO!
- line 614: // TODO: sometimes use _bulk API
- line 615: // TODO: test non-aborting exceptions (Rob suggested field where positions overflow)
- line 617: // TODO: not great we don't test deletes GC here:
- line 713: // TODO: sometimes use bulk:
server/src/main/java/org/opensearch/index/engine/Engine.java (6 lines):
- line 120: public static final String SYNC_COMMIT_ID = "sync_id"; // TODO: remove sync_id in 3.0
- line 125: public static final String SEARCH_SOURCE = "search"; // TODO: Make source of search enum?
- line 587: // TODO: A better exception goes here
- line 887: // TODO: consider moving this to StoreStats
- line 1057: // TODO: add more fine grained mem stats values to per segment info here
- line 1869: // TODO we might force a flush in the future since we have the write lock already even though recoveries
server/src/main/java/org/opensearch/snapshots/SnapshotsService.java (6 lines):
- line 410: // TODO: create snapshot UUID in CreateSnapshotRequest and make this operation idempotent to cleanly deal with transport layer
- line 567: // TODO: It is worth revisiting the design choice of creating a placeholder entry in snapshots-in-progress here once we have a cache
- line 578: // TODO: create snapshot UUID in CloneSnapshotRequest and make this operation idempotent to cleanly deal with transport layer
- line 713: // TODO: we could skip this step for snapshots with state SUCCESS
- line 1616: // TODO: Restart snapshot on another node?
- line 1918: * TODO: optimize this to execute in a single CS update together with finalizing the latest snapshot
server/src/main/resources/org/opensearch/bootstrap/security.policy (5 lines):
- line 104: // TODO: clean all these property writes up, and don't allow any more in. these are all bogus!
- line 107: // TODO: put these in doPrivileged and move these to test-framework.policy
- line 118: // TODO: set this with gradle or some other way that repros with seed?
- line 121: // TODO: these simply trigger a noisy warning if its unable to clear the properties
- line 136: // (TODO: clean this up?)
modules/lang-painless/src/main/java/org/opensearch/painless/AnalyzerCaster.java (5 lines):
- line 90: // TODO: remove this when the transition from Joda to Java datetimes is completed
- line 98: // TODO: remove this when the transition from Joda to Java datetimes is completed
- line 596: // TODO: In the rare case we still haven't reached a correct promotion we need
- line 597: // TODO: to calculate the highest upper bound for the two types and return that.
- line 598: // TODO: However, for now we just return objectType that may require an extra cast.
buildSrc/src/main/java/org/opensearch/gradle/OpenSearchTestBasePlugin.java (5 lines):
- line 106: // TODO remove once jvm.options are added to test system properties
- line 175: // TODO: remove setting logging level via system property
- line 183: // TODO: remove this once ctx isn't added to update script params in 7.0
- line 186: // TODO: remove this property in 8.0
- line 189: // TODO: remove this once cname is prepended to transport.publish_address by default in 8.0
server/src/main/java/org/opensearch/common/Rounding.java (5 lines):
- line 642: // TODO this is used in date range's collect so we should optimize it too
- line 682: // TODO this is actually used date range's collect so we should optimize it
- line 1030: // TODO this is used in date range's collect so we should optimize it too
- line 1055: // TODO this is used in date range's collect so we should optimize it too
- line 1135: return offsetInstant.toEpochMilli(); // TODO or throw something?
modules/analysis-common/src/main/java/org/opensearch/analysis/common/CommonAnalysisPlugin.java (4 lines):
- line 373: // TODO deprecate and remove in API
- line 511: // TODO this one seems useless
- line 616: // TODO deprecate and remove in API
- line 620: // Temporary shim for aliases. TODO deprecate after they are moved
buildSrc/src/main/java/org/opensearch/gradle/precommit/DependencyLicensesTask.java (4 lines):
- line 119: // TODO: we should be able to default this to eg compile deps, but we need to move the licenses
- line 220: // TODO: why do we support suffix of LICENSE *and* LICENSE.txt??
- line 321: // TODO: shouldn't have to trim, sha files should not have trailing newline
- line 358: // try the other suffix...TODO: get rid of this, just support ending in .txt
server/src/main/java/org/opensearch/index/mapper/FieldMapper.java (4 lines):
- line 82: // TODO move to KeywordFieldMapper.Builder
- line 84: // TODO move to text-specific builder base class
- line 422: // TODO: should be validating if index options go "up" (but "down" is ok)
- line 627: // TODO: multi fields are really just copy fields, we just need to expose "sub fields" or something that can be part
server/src/main/java/org/opensearch/index/shard/IndexShard.java (4 lines):
- line 1107: // TODO: clean this up when types are gone
- line 1880: // TODO: Don't enable this leniency unless users explicitly opt-in
- line 2961: // TODO: Create a proper object to encapsulate the recovery context
- line 3982: // TODO: add a dedicate recovery stats for the reset translog
buildSrc/src/main/java/org/opensearch/gradle/precommit/TestingConventionsTasks.java (4 lines):
- line 226: .filter(this::seemsLikeATest) // TODO when base classes are set, check for classes that extend them
- line 229: // TODO: check for non public classes that seem like tests
- line 230: // TODO: check for abstract classes that implement the naming conventions
- line 261: // TODO: check that the testing tasks are included in the right task based on the name ( from the rule )
server/src/main/java/org/opensearch/index/store/Store.java (4 lines):
- line 235: // TODO this should be caught by lucene - EOF is almost certainly an index corruption
- line 675: // TODO do we need to also fail this if we can't delete the pending commit file?
- line 922: // TODO we should check the checksum in lucene if we hit an exception
- line 1620: // TODO: Asserts the starting commit is a safe commit once peer-recovery sets global checkpoint.
server/src/main/java/org/opensearch/Build.java (4 lines):
- line 213: // TODO - clean up this code when we remove all v6 bwc tests.
- line 214: // TODO - clean this up when OSS flavor is removed in all of the code base
- line 242: // TODO - clean up this code when we remove all v6 bwc tests.
- line 243: // TODO - clean this up when OSS flavor is removed in all of the code base
server/src/main/java/org/opensearch/common/inject/InjectorImpl.java (4 lines):
- line 344: // TODO: for the above example, remove the binding for BarImpl if the binding for FooImpl fails
- line 394: // TODO: Method interceptors could actually enable us to implement
- line 447: // Make sure it's not the same type. TODO: Can we check for deeper loops?
- line 494: // Make sure it's not the same type. TODO: Can we check for deeper cycles?
modules/lang-expression/src/main/java/org/opensearch/script/expression/ExpressionScriptEngine.java (3 lines):
- line 329: // TODO: if some uses it in a scoring expression, they will get a nasty failure when evaluating...need a
- line 402: // TODO: if some uses it in a scoring expression, they will get a nasty failure when evaluating...need a
- line 527: // TODO: document and/or error if params contains _score?
server/src/main/java/org/opensearch/common/geo/GeoPolygonDecomposer.java (3 lines):
- line 309: // TODO: Check if we could save the set null step
- line 511: // TODO Can this actually happen? Needs a test to exercise it, or else needs to be removed.
- line 518: index = 0; // TODO Should this be pos instead of 0? This assigns exact matches to the southernmost component.
server/src/main/java/org/opensearch/action/search/SearchPhaseController.java (3 lines):
- line 318: // TODO it would be nice to assert this in the future
- line 375: // TODO it would be nice to assert this in the future
- line 571: * //TODO: instead of throwing error, find a way to sort long and unsigned_long together
modules/lang-painless/src/main/java/org/opensearch/painless/phase/DefaultSemanticAnalysisPhase.java (3 lines):
- line 2822: // TODO: remove ZonedDateTime exception when JodaCompatibleDateTime is removed
- line 3098: // TODO: remove ZonedDateTime exception when JodaCompatibleDateTime is removed
- line 3289: // TODO: remove ZonedDateTime exception when JodaCompatibleDateTime is removed
plugins/repository-azure/src/main/java/org/opensearch/repositories/azure/AzureBlobStore.java (3 lines):
- line 227: // TODO: reconsider reverting to simplified approach once https://github.com/Azure/azure-sdk-for-java/issues/26064
- line 332: // TODO: reconsider reverting to simplified approach once https://github.com/Azure/azure-sdk-for-java/issues/26064
- line 380: // TODO: reconsider reverting to simplified approach once https://github.com/Azure/azure-sdk-for-java/issues/26064
distribution/tools/plugin-cli/src/main/java/org/opensearch/plugins/InstallPluginCommand.java (3 lines):
- line 842: // TODO: optimize to skip any bundles not connected to the candidate plugin?
- line 848: // TODO: no jars should be an error
- line 849: // TODO: verify the classname exists in one of the jars!
buildSrc/src/main/java/org/opensearch/gradle/testclusters/OpenSearchNode.java (3 lines):
- line 645: // TODO revisit when moving to shorter paths on CI by using Teamcity
- line 707: * //TODO: Remove this when system modules are available
- line 1263: // TODO: Remove these once https://github.com/elastic/elasticsearch/issues/46091 is fixed
server/src/main/java/org/opensearch/indices/SystemIndexDescriptor.java (3 lines):
- line 105: // TODO: Index settings and mapping
- line 106: // TODO: getThreadpool()
- line 107: // TODO: Upgrade handling (reindex script?)
server/src/main/java/org/opensearch/search/rescore/QueryRescorer.java (3 lines):
- line 74: // TODO: shouldn't this be up to the ScoreMode? I.e., we should just invoke ScoreMode.combine, passing 0.0f for the
- line 169: // TODO: shouldn't this be up to the ScoreMode? I.e., we should just invoke ScoreMode.combine, passing 0.0f for the
- line 174: // TODO: this is wrong, i.e. we are comparing apples and oranges at this point. It would be better if we always rescored all
server/src/main/java/org/opensearch/indices/recovery/RecoverySourceHandler.java (3 lines):
- line 385: final long phase1ThrottlingWaitTime = 0L; // TODO: return the actual throttle time
- line 489: // TODO: We shouldn't use the generic thread pool here as we already execute this from the generic pool.
- line 995: // TODO: make relocated async
server/src/main/java/org/opensearch/common/util/CuckooFilter.java (3 lines):
- line 134: // TODO this is probably super slow, but just used for testing atm
- line 356: // TODO implement semi-sorting
- line 497: * TODO: there are schemes to avoid powers of two, might want to investigate those
server/src/main/java/org/opensearch/cluster/routing/RoutingNodes.java (3 lines):
- line 176: // TODO: check primary == null || primary.active() after all tests properly add ReplicaAfterPrimaryActiveAllocationDecider
- line 421: // TODO these are used on tests only - move into utils class
- line 436: // TODO these are used on tests only - move into utils class
server/src/main/java/org/opensearch/index/mapper/DocumentParser.java (3 lines):
- line 617: // TODO: shouldn't this skip, not parse?
- line 693: // TODO: passing null to an object seems bogus?
- line 818: // TODO how do we identify dynamically that its a binary value?
server/src/main/java/org/opensearch/OpenSearchException.java (3 lines):
- line 537: // TODO move subclasses that print out simple metadata to using addMetadata directly and support also numbers and booleans.
- line 538: // TODO rename metadataToXContent and have only SearchPhaseExecutionException use it, which prints out complex objects
- line 699: // TODO: do we really need to make the exception name in underscore casing?
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/AutoDateHistogramAggregator.java (3 lines):
- line 144: // TODO: Remove null usage here, by using a different aggregator for create
- line 461: private long nextRebucketAt = 1000; // TODO this could almost certainly start higher when asMultiBucketAggregator is gone
- line 623: * TODO it'd be faster if we could apply the merging on the fly as we
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/LongKeyedBucketOrds.java (3 lines):
- line 248: // TODO it'd be faster to count the number of buckets in a list of these ords rather than one at a time
- line 265: // TODO this is fairly expensive to compute. Can we avoid needing it?
- line 275: // TODO it'd be faster to iterate many ords at once rather than one at a time
server/src/main/java/org/opensearch/snapshots/RestoreService.java (3 lines):
- line 516: // TODO: Should all existing templates be deleted first?
- line 526: // TODO: Should we restore them at the end?
- line 596: // TODO: Enable restore for open indices
server/src/main/java/org/opensearch/cluster/routing/allocation/allocator/BalancedShardsAllocator.java (3 lines):
- line 626: * TODO we could be a bit smarter here, we don't need to fully sort necessarily
- line 869: // TODO maybe we can respect throttling here too?
- line 935: * TODO: We could be smarter here and group the shards by index and then
server/src/main/java/org/opensearch/transport/TransportService.java (3 lines):
- line 723: // TODO: capture the connection instead so that we can cancel child tasks on the remote connections.
- line 848: // TODO we can probably fold this entire request ID dance into connection.sendReqeust but it will be a bigger refactoring
- line 1015: // TODO we should makes this a hard validation and throw an exception but we need a good way to add backwards layer
server/src/main/java/org/opensearch/cluster/metadata/Metadata.java (3 lines):
- line 700: // TODO: This can be moved to IndexNameExpressionResolver too, but this means that we will support wildcards and other expressions
- line 1459: // TODO: We should move these datastructures to IndexNameExpressionResolver, this will give the following benefits:
- line 1551: // TODO: I think we can remove these arrays. it isn't worth the effort, for operations on all indices.
server/src/main/java/org/opensearch/common/geo/builders/PolygonBuilder.java (3 lines):
- line 557: // TODO Can this actually happen? Needs a test to exercise it, or else needs to be removed.
- line 564: index = 0; // TODO Should this be pos instead of 0? This assigns exact matches to the southernmost component.
- line 603: // TODO: Check if we could save the set null step
server/src/main/java/org/opensearch/env/Environment.java (2 lines):
- line 60: // TODO: move PathUtils to be package-private here instead of
- line 298: // TODO: rename all these "file" methods to "dir"
server/src/main/java/org/opensearch/index/shard/ShardPath.java (2 lines):
- line 248: // TODO: this is a hack!! We should instead keep track of incoming (relocated) shards since we know
- line 255: // TODO - do we need something more extensible? Yet, this does the job for now...
libs/core/src/main/java/org/opensearch/core/internal/io/IOUtils.java (2 lines):
- line 227: // TODO: remove this leniency
- line 275: // TODO: replace with constants class if needed (cf. org.apache.lucene.util.Constants)
server/src/main/java/org/opensearch/action/update/UpdateHelper.java (2 lines):
- line 386: // TODO when using delete/none, we can still return the source as bytes by generating it (using the sourceContentType)
- line 465: // TODO: can we remove this leniency yet??
server/src/main/java/org/opensearch/gateway/GatewayMetaState.java (2 lines):
- line 315: // TODO: can we get rid of this hack?
- line 506: // by this version of OpenSearch. TODO TBD should we avoid indexing when possible?
plugins/ingest-attachment/src/main/plugin-metadata/plugin-security.policy (2 lines):
- line 38: // TODO: fix PDFBox not to actually install bouncy castle like this
- line 41: // TODO: fix POI XWPF to not do this: https://bz.apache.org/bugzilla/show_bug.cgi?id=58597
server/src/main/java/org/opensearch/common/inject/internal/MoreTypes.java (2 lines):
- line 165: // TODO: Is this sufficient?
- line 197: // TODO: save a .clone() call
plugins/repository-s3/src/main/plugin-metadata/plugin-security.policy (2 lines):
- line 35: // TODO: get these fixed in aws sdk
- line 47: // TODO: get these fixed in aws sdk
server/src/main/java/org/opensearch/search/aggregations/support/ValueType.java (2 lines):
- line 62: // TODO: what is the difference between "number" and "numeric"?
- line 149: // TODO: do not be lenient here
server/src/main/java/org/opensearch/script/JodaCompatibleZonedDateTime.java (2 lines):
- line 521: // TODO: replace with bwc formatter
- line 528: // TODO: replace with bwc formatter
plugins/discovery-gce/src/main/java/org/opensearch/cloud/gce/GceInstancesServiceImpl.java (2 lines):
- line 95: // TODO: get this fixed
- line 227: // TODO: get this fixed
server/src/main/java/org/opensearch/index/query/ScriptQueryBuilder.java (2 lines):
- line 210: // TODO: how can we compute this?
- line 219: // TODO: Change this to true when we can assume that scripts are pure functions
server/src/main/java/org/opensearch/common/settings/Settings.java (2 lines):
- line 1075: // TODO: do this without a serialization round-trip
- line 1241: // TODO We could use an FST internally to make things even faster and more compact
server/src/main/java/org/opensearch/action/support/replication/ReplicationOperation.java (2 lines):
- line 191: // TODO: fail shard? This will otherwise have the local / global checkpoint info lagging, or possibly have replicas
- line 266: // Only report "critical" exceptions - TODO: Reach out to the master node to get the latest shard state then report.
server/src/main/java/org/opensearch/index/shard/OpenSearchMergePolicy.java (2 lines):
- line 116: // TODO: Use IndexUpgradeMergePolicy instead. We should be comparing codecs,
- line 122: // TODO: we could check IndexWriter.getMergingSegments and avoid adding merges that IW will just reject?
plugins/repository-s3/src/main/java/org/opensearch/repositories/s3/S3Service.java (2 lines):
- line 160: // TODO: Remove this once fixed in the AWS SDK
- line 193: // TODO: remove this leniency, these settings should exist together and be validated
server/src/main/java/org/opensearch/index/query/MoreLikeThisQueryBuilder.java (2 lines):
- line 551: // TODO we allow null here for the _all field, but this is forbidden in the parser. Re-check
- line 1265: // TODO this needs heavy cleanups before we can rewrite it
server/src/main/java/org/opensearch/index/IndexService.java (2 lines):
- line 425: * TODO: we execute this in parallel but it's a synced method. Yet, we might
- line 456: // TODO: we should, instead, hold a "bytes reserved" of how large we anticipate this shard will be, e.g. for a shard
server/src/internalClusterTest/java/org/opensearch/search/aggregations/bucket/LongTermsIT.java (2 lines):
- line 126: private static final int NUM_DOCS = 5; // TODO randomize the size?
- line 150: IndexRequestBuilder[] highCardBuilders = new IndexRequestBuilder[100]; // TODO randomize the size?
plugins/analysis-smartcn/src/main/java/org/opensearch/plugin/analysis/smartcn/AnalysisSmartChinesePlugin.java (2 lines):
- line 57: // TODO: deprecate and remove, this is a noop token filter; it's here for backwards compat before we had "smartcn_tokenizer"
- line 66: // TODO: deprecate and remove, this is an alias to "smartcn_tokenizer"; it's here for backwards compat
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/TermsAggregatorFactory.java (2 lines):
- line 124: // TODO this exception message is not really accurate for the string case. It's really disallowing regex + formatter
- line 134: // TODO: [Zach] we might want refactor and remove ExecutionMode#create(), moving that logic outside the enum
server/src/main/java/org/opensearch/cluster/metadata/MetadataIndexTemplateService.java (2 lines):
- line 373: // TODO: perhaps introduce a ComponentTemplateMissingException?
- line 890: // TODO: in 8.0+, only allow updating index templates, not adding new ones
buildSrc/src/main/groovy/org/opensearch/gradle/MavenFilteringHack.groovy (2 lines):
- line 35: * Gradle provides "expansion" functionality using groovy's SimpleTemplatingEngine (TODO: check name).
- line 41: * TODO: we should get rid of this hack, and make the rest tests use some other identifier
server/src/main/java/org/opensearch/search/sort/GeoDistanceSortBuilder.java (2 lines):
- line 629: // TODO implement the single point optimization above
- line 672: // TODO this lines up with FieldSortBuilder. Share?
server/src/main/java/org/opensearch/action/admin/indices/alias/IndicesAliasesRequest.java (2 lines):
- line 274: // TODO fix for backport of https://github.com/elastic/elasticsearch/pull/52547
- line 298: // TODO fix for backport https://github.com/elastic/elasticsearch/pull/52547
server/src/internalClusterTest/java/org/opensearch/indices/IndicesOptionsIntegrationIT.java (2 lines):
- line 319: // TODO: temporary work-around for #5531
- line 444: // TODO: temporary work-around for #5531
server/src/main/java/org/opensearch/cluster/coordination/OpenSearchNodeCommand.java (2 lines):
- line 96: // TODO: Try to parse other named objects (e.g. stored scripts, ingest pipelines) that are part of core es as well?
- line 104: // TODO: Make Condition non-pluggable
buildSrc/src/main/java/org/opensearch/gradle/internal/BwcSetupExtension.java (2 lines):
- line 87: // TODO revisit
- line 134: // TODO resolve
server/src/main/java/org/opensearch/index/mapper/DynamicTemplate.java (2 lines):
- line 324: // TODO: remove this in 6.0
- line 325: // TODO: how to do it in the future?
server/src/main/java/org/opensearch/search/aggregations/pipeline/MovingFunctions.java (2 lines):
- line 342: // TODO if perf is a problem, we can specialize a subclass to avoid conditionals on each iteration
- line 365: // TODO perhaps pad out seasonal to a power of 2 and use a mask instead of modulo?
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/IncludeExclude.java (2 lines):
- line 82: // TODO: move all aggs to the same package so that this stuff could be pkg-private
- line 293: // TODO: specialize based on compiled.type: for ALL and prefixes (sinkState >= 0 ) we can avoid i/o and just set bits.
modules/lang-painless/src/main/java/org/opensearch/painless/Compiler.java (2 lines):
- line 236: // TODO: Make this phase optional #60156
- line 271: // TODO: Make this phase optional #60156
server/src/main/java/org/opensearch/bootstrap/SystemCallFilter.java (2 lines):
- line 589: // TODO: add OpenBSD to Lucene Constants
- line 590: // TODO: JNA doesn't have netbsd support, but this mechanism should work there too.
server/src/main/java/org/opensearch/search/aggregations/support/ValuesSourceAggregationBuilder.java (2 lines):
- line 236: // TODO: deprecate this so we don't need to carry around a useless null in the wire format
- line 323: // TODO: This is nonsense. We allow the value to be null (via constructor), but don't allow it to be set to null. This means
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/VariableWidthHistogramAggregator.java (2 lines):
- line 292: // TODO: (maybe) Create a new bucket for all distant docs and merge down to shardSize buckets at end
- line 346: * TODO: Make this more efficient
server/src/main/java/org/opensearch/index/ShardIndexingPressureSettings.java (2 lines):
- line 14: * This class contains all the settings which are required and owned by {TODO link ShardIndexingPressure}. These will be
- line 16: * {TODO link ShardIndexingPressureMemoryManager} and {TODO link ShardIndexingPressureStore}
server/src/main/java/org/opensearch/indices/cluster/IndicesClusterStateService.java (2 lines):
- line 230: // TODO: feels hacky, a block disables state persistence, and then we clean the allocated shards, maybe another flag in blocks?
- line 279: if (masterNode != null) { // TODO: can we remove this? Is resending shard failures the responsibility of shardStateAction?
server/src/main/java/org/opensearch/index/get/ShardGetService.java (2 lines):
- line 383: // TODO: The source might be parsed and available in the sourceLookup but that one uses unordered maps so different.
- line 412: // TODO: The source might parsed and available in the sourceLookup but that one uses unordered maps so different. Do we care?
server/src/main/java/org/opensearch/index/engine/InternalEngine.java (2 lines):
- line 1289: // TODO: can we enable this check for all origins except primary on the leader?
- line 1912: // TODO: maybe we should just put a scheduled job in threadPool?
server/src/main/java/org/opensearch/common/network/NetworkService.java (2 lines):
- line 181: // TODO: needs to be InetAddress[]
- line 195: // TODO: allow publishing multiple addresses
server/src/main/java/org/opensearch/index/engine/LuceneChangesSnapshot.java (2 lines):
- line 299: // TODO: Callers should ask for the range that source should be retained. Thus we should always
- line 310: // TODO: pass the latest timestamp from engine.
server/src/main/java/org/opensearch/cluster/coordination/Coordinator.java (2 lines):
- line 1743: // TODO: only here temporarily for BWC development, remove once complete
- line 1748: // TODO: only here temporarily for BWC development, remove once complete
server/src/main/java/org/opensearch/cluster/metadata/IndexNameExpressionResolver.java (2 lines):
- line 615: // TODO: it appears that this can never be true?
- line 988: // TODO why does wildcard resolver throw exceptions regarding non wildcarded expressions? This should not be done here.
modules/lang-painless/src/main/java/org/opensearch/painless/Def.java (2 lines):
- line 73: // TODO: Once Java has a factory for those in java.lang.invoke.MethodHandles, use it:
- line 1509: // TODO: remove this when the transition from Joda to Java datetimes is completed
server/src/main/java/org/opensearch/index/seqno/ReplicationTracker.java (2 lines):
- line 315: // TODO improve this measure for when nested docs are in use
- line 496: // TODO after backporting we expect this never to happen in 8.x, so adjust this to throw an exception instead.
server/src/main/java/org/opensearch/common/inject/LookupProcessor.java (2 lines):
- line 55: errors.merge(e.getErrors()); // TODO: source
- line 68: errors.merge(e.getErrors()); // TODO: source
server/src/main/java/org/opensearch/search/sort/BucketedSort.java (2 lines):
- line 210: // TODO we usually have a heap here so we could use that to build the results sorted.
- line 418: // TODO a "bottom up" insert would save a couple of comparisons. Worth it?
server/src/main/java/org/opensearch/common/util/concurrent/OpenSearchExecutors.java (2 lines):
- line 317: // TODO this should only be allowed in tests
- line 323: // TODO missing node names should only be allowed in tests
server/src/main/java/org/opensearch/index/query/QueryShardContext.java (2 lines):
- line 316: * TODO: remove this by moving defaults into mappers themselves
- line 327: * TODO: remove this by moving defaults into mappers themselves
server/src/main/java/org/apache/lucene/search/uhighlight/CustomFieldHighlighter.java (2 lines):
- line 116: // TODO: use FieldHighlighter::highlightOffsetsEnums and modify BoundedBreakIteratorScanner to work with it
- line 172: // TODO: use FieldHighlighter::maybeAddPassage
server/src/main/java/org/opensearch/search/aggregations/AggregationPhase.java (2 lines):
- line 77: // TODO: report on child aggs as well
- line 121: // TODO: report on sub collectors
modules/lang-painless/src/main/java/org/opensearch/painless/WriterConstants.java (2 lines):
- line 85: // TODO: remove this when the transition from Joda to Java datetimes is completed
- line 160: // TODO: remove this when the transition from Joda to Java datetimes is completed
buildSrc/src/main/java/org/opensearch/gradle/OpenSearchJavaPlugin.java (2 lines):
- line 163: // TODO Discuss moving compileOptions.getCompilerArgs() to use provider api with Gradle team.
- line 183: // TODO: this probably shouldn't apply to groovy at all?
server/src/main/java/org/opensearch/search/suggest/completion/context/CategoryContextMapping.java (1 line):
- line 153: // TODO we should be checking mapped field types, not lucene field types
server/src/main/java/org/opensearch/action/support/nodes/BaseNodeRequest.java (1 line):
- line 42: // TODO: this class can be removed in master once 7.x is bumped to 7.4.0
server/src/main/java/org/opensearch/common/settings/KeyStoreWrapper.java (1 line):
- line 584: // TODO: make settings accessible only to code that registered the setting
server/src/main/java/org/opensearch/search/suggest/phrase/WordScorer.java (1 line):
- line 47: //TODO public for tests
server/src/main/java/org/opensearch/action/search/BottomSortValuesCollector.java (1 line):
- line 100: // TODO: we should fail the entire request because the topdocs
server/src/internalClusterTest/java/org/opensearch/search/sort/SimpleSortIT.java (1 line):
- line 355: // TODO: sort shouldn't fail when sort field is mapped dynamically
server/src/main/java/org/opensearch/search/suggest/term/TermSuggester.java (1 line):
- line 66: // TODO: Extend DirectSpellChecker in 4.1, to get the raw suggested words as BytesRef
server/src/main/java/org/opensearch/common/text/Text.java (1 line):
- line 139: // TODO: TextBytesOptimization we can use a buffer here to convert it? maybe add a
server/src/main/java/org/opensearch/common/lucene/search/function/FunctionScoreQuery.java (1 line):
- line 517: return Float.MAX_VALUE; // TODO: what would be a good upper bound?
buildSrc/src/integTest/groovy/org/opensearch/gradle/fixtures/AbstractGradleFuncTest.groovy (1 line):
- line 125: //TODO: cleanup
server/src/main/java/org/opensearch/common/settings/SettingsModule.java (1 line):
- line 110: // TODO remove in 6.0!!
server/src/main/java/org/opensearch/search/aggregations/metrics/AbstractInternalHDRPercentiles.java (1 line):
- line 205: // TODO: upgrade the HDRHistogram library
libs/nio/src/main/java/org/opensearch/nio/utils/ExceptionsHelper.java (1 line):
- line 37: // TODO: This should eventually be removed once ExceptionsHelper is moved to a core library jar
server/src/main/java/org/opensearch/common/time/JavaDateMathParser.java (1 line):
- line 78: // TODO only millisecond granularity here!
server/src/main/java/org/opensearch/indices/store/IndicesStore.java (1 line):
- line 90: // TODO this class can be foled into either IndicesService and partially into IndicesClusterStateService
server/src/main/java/org/apache/lucene/search/grouping/CollapsingTopDocsCollector.java (1 line):
- line 54: * TODO: If the sort is based on score we should propagate the mininum competitive score when orderedGroups
is full.
modules/aggs-matrix-stats/src/main/java/org/opensearch/search/aggregations/matrix/stats/MatrixStatsAggregator.java (1 line):
- line 126: // TODO: Fix matrix stats to treat neg inf as any other value
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/SignificantTextAggregatorFactory.java (1 line):
- line 138: // TODO - need to check with mapping that this is indeed a text field....
server/src/main/java/org/opensearch/action/admin/cluster/node/info/PluginsAndModules.java (1 line):
- line 103: // TODO: not ideal, make a better api for this (e.g. with jar metadata, and so on)
server/src/main/java/org/opensearch/search/aggregations/metrics/CardinalityAggregator.java (1 line):
- line 93: // TODO: Stop using nulls here
server/src/main/java/org/opensearch/search/suggest/phrase/Correction.java (1 line):
- line 40: //TODO public for tests
buildSrc/reaper/src/main/java/org/elasticsearch/gradle/reaper/package-info.java (1 line):
- line 24: * TODO - Need to add package description
server/src/main/java/org/opensearch/common/lucene/Lucene.java (1 line):
- line 548: // TODO: improve serialization of BigInteger
server/src/main/java/org/opensearch/common/io/stream/StreamOutput.java (1 line):
- line 820: // TODO: improve serialization of BigInteger
server/src/main/java/org/opensearch/cluster/service/ClusterService.java (1 line):
- line 161: * TODO: Should be renamed to appliedState / appliedClusterState
modules/lang-expression/src/internalClusterTest/java/org/opensearch/script/expression/MoreExpressionIT.java (1 line):
- line 76: // TODO: please convert to unit tests!
server/src/main/java/org/opensearch/action/termvectors/TermVectorsRequest.java (1 line):
- line 112: // TODO: change to String[]
server/src/main/java/org/opensearch/index/fielddata/ordinals/GlobalOrdinalsIndexFieldData.java (1 line):
- line 150: // TODO: break down ram usage?
server/src/main/java/org/opensearch/index/similarity/SimilarityService.java (1 line):
- line 189: // TODO we can maybe factor out MapperService here entirely by introducing an interface for the lookup?
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/RangeHistogramAggregator.java (1 line):
- line 89: // TODO: Stop using nulls here
server/src/main/java/org/opensearch/rest/RestRequest.java (1 line):
- line 558: // TODO stop ignoring parameters such as charset...
server/src/main/java/org/opensearch/index/mapper/Mapper.java (1 line):
- line 220: * TODO: make this protected once Mapper and FieldMapper are merged together */
server/src/main/java/org/opensearch/bootstrap/BootstrapSettings.java (1 line):
- line 42: // TODO: remove this hack when insecure defaults are removed from java
server/src/main/java/org/opensearch/action/search/AbstractSearchAsyncAction.java (1 line):
- line 611: // TODO: Until we implement the retry mechanism for point in times (i.e., replace an unavailable shard with an equivalent copy),
server/src/internalClusterTest/java/org/opensearch/cluster/routing/allocation/decider/DiskThresholdDeciderIT.java (1 line):
- line 335: // even though it's now possible to achieve better balance, so we have to do an explicit reroute. TODO fix this?
server/src/main/java/org/opensearch/index/mapper/DateFieldMapper.java (1 line):
- line 589: // TODO maybe aggs should force millis because lots so of other places want nanos?
server/src/main/java/org/opensearch/search/aggregations/pipeline/BucketSelectorPipelineAggregator.java (1 line):
- line 113: // TODO: can we use one instance of the script for all buckets? it should be stateless?
plugins/ingest-attachment/src/main/java/org/opensearch/ingest/attachment/AttachmentProcessor.java (1 line):
- line 137: // TODO: stop using LanguageIdentifier...
client/rest/src/main/java/org/opensearch/client/RestClient.java (1 line):
- line 244: // TODO should we throw an IAE if we have two nodes with the same host?
server/src/main/java/org/opensearch/search/aggregations/support/MissingValues.java (1 line):
- line 56: // TODO: we could specialize the single value case
distribution/tools/launchers/src/main/java/org/opensearch/tools/launchers/SystemJvmOptions.java (1 line):
- line 104: * //TODO COMPAT will be deprecated in jdk14 https://bugs.openjdk.java.net/browse/JDK-8232906
server/src/main/java/org/opensearch/search/query/QueryPhase.java (1 line):
- line 93: // TODO: remove this property
server/src/main/java/org/opensearch/search/fetch/subphase/highlight/FragmentBuilderHelper.java (1 line):
- line 97: // TODO maybe we need a getter on Namedanalyzer that tells if this uses broken Analysis
server/src/main/java/org/opensearch/index/mapper/AllFieldMapper.java (1 line):
- line 50: * TODO: Remove in 8
server/src/main/java/org/opensearch/action/support/IndicesOptions.java (1 line):
- line 75: // TODO why do we let patterns like "none,all" or "open,none,closed" get used. The location of 'none' in the array changes the
server/src/main/java/org/opensearch/search/aggregations/support/AggregationPath.java (1 line):
- line 229: // TODO both unwrap and subAggregator are only used here!
server/src/main/java/org/opensearch/monitor/os/OsProbe.java (1 line):
- line 610: // TODO: return a prettier name on non-Linux OS
server/src/main/java/org/apache/lucene/queryparser/classic/XQueryParser.java (1 line):
- line 42: * TODO: We should maybe rewrite this with the flexible query parser which matches the same syntax with more freedom.
server/src/main/java/org/opensearch/action/search/SearchPhaseContext.java (1 line):
- line 52: // TODO maybe we can make this concrete later - for now we just implement this in the base class for all initial phases
server/src/main/java/org/opensearch/common/settings/Setting.java (1 line):
- line 1830: // TODO this one's two argument get is still broken
server/src/main/java/org/opensearch/search/aggregations/support/ValuesSourceConfig.java (1 line):
- line 322: // TODO: resolve no longer generates invalid configs. Once VSConfig is immutable, we can drop this check
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/NumericHistogramAggregator.java (1 line):
- line 92: // TODO: Stop using null here
server/src/main/java/org/opensearch/search/aggregations/metrics/GeoBoundsAggregator.java (1 line):
- line 75: // TODO: stop expecting nulls here
server/src/main/java/org/opensearch/search/aggregations/metrics/AvgAggregator.java (1 line):
- line 70: // TODO Stop expecting nulls here
modules/lang-painless/src/main/java/org/opensearch/painless/Utility.java (1 line):
- line 65: // TODO: remove this when the transition from Joda to Java datetimes is completed
server/src/main/java/org/opensearch/index/get/GetResult.java (1 line):
- line 312: // TODO: can we avoid having an exception here?
server/src/main/java/org/opensearch/watcher/FileWatcher.java (1 line):
- line 108: // TODO we might use the new NIO2 API to get real notification?
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/InternalSignificantTerms.java (1 line):
- line 129: // TODO we should refactor to remove this, since buckets should be immutable after they are generated.
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/DateHistogramAggregatorFactory.java (1 line):
- line 107: // TODO: Is there a reason not to get the prepared rounding in the supplier itself?
server/src/main/java/org/opensearch/cluster/ClusterModule.java (1 line):
- line 310: // TODO: this is public so allocation benchmark can access the default deciders...can we do that in another way?
server/src/main/java/org/opensearch/search/aggregations/metrics/MaxAggregator.java (1 line):
- line 73: // TODO stop expecting nulls here
server/src/main/java/org/opensearch/search/SearchModule.java (1 line):
- line 1018: // TODO remove funky contexts
server/src/main/java/org/opensearch/index/query/functionscore/DecayFunctionBuilder.java (1 line):
- line 232: // TODO these ain't gonna work with runtime fields
modules/lang-painless/src/main/java/org/opensearch/painless/action/PainlessExecuteAction.java (1 line):
- line 489: // TODO: is MANAGEMENT TP the right TP? Right now this is an admin api (see action name).
server/src/main/java/org/opensearch/action/search/ClearScrollController.java (1 line):
- line 83: // TODO: replace this with #closeContexts
server/src/main/java/org/opensearch/transport/Transport.java (1 line):
- line 277: // TODO: Only visible for testing. Perhaps move StubbableTransport from
server/src/main/java/org/opensearch/cluster/routing/allocation/decider/ThrottlingAllocationDecider.java (1 line):
- line 179: // TODO: Should index creation not be throttled for primary shards?
plugins/discovery-ec2/src/main/plugin-metadata/plugin-security.policy (1 line):
- line 35: // TODO: get these fixed in aws sdk
server/src/main/java/org/opensearch/bootstrap/OpenSearchPolicy.java (1 line):
- line 162: // TODO: remove this hack when insecure defaults are removed from java
server/src/main/java/org/opensearch/cluster/coordination/PublicationTransportHandler.java (1 line):
- line 92: // TODO: look into these and check how to get rid of them
buildSrc/src/main/java/org/opensearch/gradle/BwcVersions.java (1 line):
- line 374: // TODO remove this filter once legacy ES versions are no longer supported
server/src/main/java/org/opensearch/search/SearchHit.java (1 line):
- line 674: // TODO: can we avoid having an exception here?
buildSrc/src/main/java/org/opensearch/gradle/precommit/ForbiddenPatternsTask.java (1 line):
- line 177: // TODO: fail if pattern contains a newline, it won't work (currently)
server/src/main/java/org/opensearch/action/admin/cluster/repositories/cleanup/TransportCleanupRepositoryAction.java (1 line):
- line 83: * and any delete/write operations. TODO: This will not work if we also want to clean up at the shard level as those will involve writes
server/src/main/java/org/opensearch/persistent/PersistentTasksCustomMetadata.java (1 line):
- line 81: // TODO: Implement custom Diff for tasks
server/src/internalClusterTest/java/org/opensearch/indices/store/IndicesStoreIntegrationIT.java (1 line):
- line 421: // TODO: we should add an easier to do this. It's too much of a song and dance..
server/src/main/java/org/opensearch/index/store/FsDirectoryFactory.java (1 line):
- line 199: // TODO it would be nice to share code between PreLoadMMapDirectory and HybridDirectory but due to the nesting aspect of
server/src/internalClusterTest/java/org/opensearch/search/sort/FieldSortIT.java (1 line):
- line 901: // TODO: WTF?
server/src/main/java/org/opensearch/index/engine/EngineConfig.java (1 line):
- line 246: // TODO: Remove this escape hatch in 8.x
modules/parent-join/src/main/java/org/opensearch/join/query/HasChildQueryBuilder.java (1 line):
- line 380: // TODO: Find a way to remove this query and let doToQuery(...) just return the query from JoinUtil.createJoinQuery(...)
server/src/main/java/org/opensearch/common/settings/AbstractScopedSettings.java (1 line):
- line 1021: // TODO this should be replaced by Setting.Property.HIDDEN or something like this.
server/src/main/java/org/apache/lucene/search/vectorhighlight/CustomFieldQuery.java (1 line):
- line 54: // TODO: remove me!
server/src/internalClusterTest/java/org/opensearch/search/query/ExistsIT.java (1 line):
- line 61: // TODO: move this to a unit test somewhere...
server/src/main/java/org/opensearch/action/search/SearchType.java (1 line):
- line 85: } else if (id == 1 || id == 3) { // TODO this bwc layer can be removed once this is back-ported to 5.3 QUERY_AND_FETCH is removed
server/src/main/java/org/opensearch/common/lucene/uid/PerThreadIDVersionAndSeqNoLookup.java (1 line):
- line 66: // TODO: do we really need to store all this stuff? some if it might not speed up anything.
server/src/main/java/org/opensearch/action/ingest/IngestActionForwarder.java (1 line):
- line 50: * TODO: move this into IngestService and make index/bulk actions call that
server/src/main/java/org/opensearch/search/aggregations/metrics/MinAggregator.java (1 line):
- line 73: // TODO: Stop using nulls here
server/src/main/java/org/opensearch/common/network/NetworkModule.java (1 line):
- line 195: // TODO: we need another name than "http transport"....so confusing with transportClient...
server/src/main/java/org/opensearch/common/geo/builders/EnvelopeBuilder.java (1 line):
- line 102: // TODO support Z??
server/src/internalClusterTest/java/org/opensearch/search/fetch/subphase/highlight/HighlighterSearchIT.java (1 line):
- line 132: // TODO as we move analyzers out of the core we need to move some of these into HighlighterWithAnalyzersTests
server/src/main/java/org/opensearch/search/profile/AbstractInternalProfileTree.java (1 line):
- line 174: // TODO this would be better done bottom-up instead of top-down to avoid
server/src/main/java/org/opensearch/search/aggregations/support/AggregationInspectionHelper.java (1 line):
- line 180: // TODO this could be incorrect... e.g. +1 + -1
server/src/main/java/org/opensearch/search/aggregations/InternalOrder.java (1 line):
- line 63: // TODO merge the contents of this file into BucketOrder. The way it is now is relic.
server/src/main/java/org/apache/lucene/queries/BlendedTermQuery.java (1 line):
- line 128: // TODO: Maybe it could also make sense to assume independent distributions of documents and eg. have:
server/src/internalClusterTest/java/org/opensearch/snapshots/SharedClusterSnapshotRestoreIT.java (1 line):
- line 1938: // TODO: Fix repo cleanup logic to handle these leaked snap-file and only exclude test-repo (the mock repo) here.
server/src/main/java/org/opensearch/snapshots/InternalSnapshotsInfoService.java (1 line):
- line 179: // TODO Maybe just clear out non-ongoing snapshot recoveries is the node is master eligible, so that we don't
server/src/main/java/org/opensearch/plugins/PluginInfo.java (1 line):
- line 408: // TODO: since the plugins are unique by their directory name, this should only be a name check, version should not matter?
server/src/internalClusterTest/java/org/opensearch/indices/memory/breaker/RandomExceptionCircuitBreakerIT.java (1 line):
- line 253: // TODO: Generalize this class and add it as a utility
server/src/main/java/org/opensearch/action/admin/cluster/snapshots/status/TransportSnapshotsStatusAction.java (1 line):
- line 358: // TODO: add the differentiation on the metadata level in the next major release
server/src/main/java/org/opensearch/env/OpenSearchFileStore.java (1 line):
- line 60: // TODO: move PathUtils to be package-private here instead of
libs/x-content/src/main/java/org/opensearch/common/xcontent/XContentParser.java (1 line):
- line 270: // TODO remove context entirely when it isn't needed
modules/transport-netty4/src/yamlRestTest/java/org/opensearch/http/netty4/Netty4ClientYamlTestSuiteIT.java (1 line):
- line 44: //TODO: This is a *temporary* workaround to ensure a timeout does not mask other problems
server/src/main/java/org/opensearch/common/inject/ConstructorInjector.java (1 line):
- line 83: // TODO (crazybob): if we can't proxy this object, can we proxy the other object?
plugins/repository-hdfs/src/main/java/org/opensearch/repositories/hdfs/HdfsPlugin.java (1 line):
- line 70: // TODO: remove THIS when hadoop is fixed
server/src/main/java/org/opensearch/search/aggregations/metrics/ValueCountAggregator.java (1 line):
- line 74: // TODO: stop expecting nulls here
server/src/internalClusterTest/java/org/opensearch/search/aggregations/pipeline/DateDerivativeIT.java (1 line):
- line 106: // TODO: would be nice to have more random data here
server/src/main/java/org/opensearch/action/admin/indices/flush/TransportShardFlushAction.java (1 line):
- line 120: // TODO: Remove this transition in OpenSearch 3.0
server/src/main/java/org/opensearch/bootstrap/StartupException.java (1 line):
- line 48: // TODO: remove this when guice is removed, and exceptions are cleaned up
modules/reindex/src/main/java/org/opensearch/index/reindex/BulkByScrollParallelizationHelper.java (1 line):
- line 197: // TODO move the request to the correct node. maybe here or somehow do it as part of startup for reindex in general....
server/src/main/java/org/opensearch/search/fetch/subphase/InnerHitsContext.java (1 line):
- line 101: // TODO: when types are complete removed just use String instead for the id:
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/SignificanceLookup.java (1 line):
- line 217: // TODO this method helps because of asMultiBucketAggregator. Once we remove it we can move this logic into the aggregators.
server/src/main/java/org/opensearch/action/support/replication/TransportReplicationAction.java (1 line):
- line 714: // TODO: Evaluate if we still need to catch this exception
server/src/main/java/org/opensearch/index/fielddata/SortedBinaryDocValues.java (1 line):
- line 44: // TODO: Should it expose a count (current approach) or return null when there are no more values?
server/src/main/java/org/opensearch/search/suggest/phrase/LinearInterpolatingScorer.java (1 line):
- line 41: //TODO public for tests
server/src/main/java/org/opensearch/index/mapper/MetadataFieldMapper.java (1 line):
- line 59: // TODO: remove the fieldType parameter which is only used for bw compat with pre-2.0
server/src/main/java/org/apache/lucene/search/uhighlight/BoundedBreakIteratorScanner.java (1 line):
- line 53: * TODO: We should be able to create passages incrementally, starting from the offset of the first match and expanding or not
server/src/main/java/org/opensearch/indices/IndicesRequestCache.java (1 line):
- line 259: // TODO: more detailed ram usage?
server/src/main/java/org/opensearch/common/util/CombinedRateLimiter.java (1 line):
- line 45: // TODO: This rate limiter has some concurrency issues between the two maybePause operations
server/src/main/java/org/opensearch/index/fielddata/NumericDoubleValues.java (1 line):
- line 49: // TODO: this interaction with sort comparators is really ugly...
server/src/main/java/org/opensearch/script/ScriptContextInfo.java (1 line):
- line 354: // TODO: ensure empty/no PARAMETERS if parameterTypes.length == 0?
server/src/internalClusterTest/java/org/opensearch/search/basic/SearchWhileCreatingIndexIT.java (1 line):
- line 68: // TODO: randomize the wait for active shards value on index creation and ensure the appropriate
server/src/main/java/org/opensearch/gateway/Gateway.java (1 line):
- line 129: } // TODO if this logging statement is correct then we are missing an else here
server/src/main/java/org/opensearch/cluster/metadata/Manifest.java (1 line):
- line 60: // TODO revisit missing and unknown constants once Zen2 BWC is ready
server/src/internalClusterTest/java/org/opensearch/search/aggregations/bucket/RangeIT.java (1 line):
- line 913: // TODO: use diamond once JI-9019884 is fixed
server/src/main/java/org/opensearch/action/search/SearchResponseMerger.java (1 line):
- line 83: // TODO it may make sense to integrate the remote clusters responses as a shard response in the initial search phase and ignore hits coming
server/src/main/java/org/opensearch/cluster/routing/allocation/DiskThresholdMonitor.java (1 line):
- line 139: // TODO find a better way to limit concurrent updates (and potential associated reroutes) while allowing tests to ensure that
server/src/main/java/org/opensearch/cluster/routing/allocation/decider/AwarenessAllocationDecider.java (1 line):
- line 215: // TODO should we remove ones that are not part of full list?
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/DateRangeHistogramAggregator.java (1 line):
- line 117: // TODO: Stop using null here
server/src/main/java/org/opensearch/index/mapper/MappedFieldType.java (1 line):
- line 216: // TODO: Standardize exception types
server/src/main/java/org/opensearch/cluster/metadata/MetadataUpdateSettingsService.java (1 line):
- line 209: * TODO: should we update the in-sync allocation IDs once the data is deleted by the node?
buildSrc/src/main/groovy/org/opensearch/gradle/plugin/PluginBuildPlugin.groovy (1 line):
- line 224: from('src/main/packaging') // TODO: move all config/bin/_size/etc into packaging
server/src/main/java/org/opensearch/common/collect/MapBuilder.java (1 line):
- line 101: // TODO: follow the directions in the Javadoc for this method
server/src/main/java/org/opensearch/index/mapper/BinaryRangeUtil.java (1 line):
- line 151: // TODO: Support for exclusive ranges, pending resolution of #40601
server/src/main/java/org/opensearch/search/suggest/phrase/CandidateGenerator.java (1 line):
- line 41: //TODO public for tests
plugins/discovery-ec2/src/main/java/org/opensearch/discovery/ec2/Ec2DiscoveryPlugin.java (1 line):
- line 81: // TODO: fix that
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/DateHistogramAggregator.java (1 line):
- line 110: // TODO: Stop using null here
server/src/main/java/org/apache/lucene/analysis/miscellaneous/DeDuplicatingTokenFilter.java (1 line):
- line 125: // TODO consider changing this implementation to emit tokens as-we-go
server/src/main/java/org/opensearch/index/reindex/AbstractBulkByScrollRequest.java (1 line):
- line 472: // TODO It'd be nice not to refresh on every slice. Instead we should refresh after the sub requests finish.
server/src/main/java/org/opensearch/common/inject/internal/ConstructionContext.java (1 line):
- line 77: // TODO: if I create a proxy which implements all the interfaces of
server/src/main/java/org/opensearch/SpecialPermission.java (1 line):
- line 80: // TODO: if we really need we can break out name (e.g. "hack" or "scriptEngineService" or whatever).
server/src/main/java/org/opensearch/rest/RestController.java (1 line):
- line 295: // TODO: Count requests double in the circuit breaker if they need copying?
server/src/main/java/org/opensearch/index/reindex/LeaderBulkByScrollTaskState.java (1 line):
- line 128: // TODO cancel when a slice fails?
server/src/main/java/org/opensearch/common/xcontent/SuggestingErrorOnUnknown.java (1 line):
- line 61: // TODO it'd be nice to combine this with BaseRestHandler's implementation.
modules/parent-join/src/internalClusterTest/java/org/opensearch/join/aggregations/AbstractParentChildTestCase.java (1 line):
- line 81: // TODO: this array is always of length 1, and testChildrenAggs fails if this is changed
server/src/main/java/org/opensearch/index/mapper/RangeType.java (1 line):
- line 135: // TODO: Implement this.
server/src/main/java/org/opensearch/index/mapper/LegacyGeoShapeFieldMapper.java (1 line):
- line 598: // TODO we should allow this, but at the moment levels is used to build bookkeeping variables
plugins/discovery-gce/src/main/java/org/opensearch/cloud/gce/GceMetadataService.java (1 line):
- line 92: // TODO: get this fixed
client/rest-high-level/src/main/java/org/opensearch/client/cluster/RemoteConnectionInfo.java (1 line):
- line 91: // TODO: deprecate and remove this field in favor of initialConnectionTimeout field that is of type TimeValue.
server/src/main/java/org/opensearch/action/support/RetryableAction.java (1 line):
- line 130: // TODO: The only implementations of this class use SAME which means the execution will not be
modules/opensearch-dashboards/src/main/java/org/opensearch/dashboards/OpenSearchDashboardsPlugin.java (1 line):
- line 115: // TODO need to figure out what subset of system indices OpenSearch Dashboards should have access to via these APIs
server/src/internalClusterTest/java/org/opensearch/gateway/RecoveryFromGatewayIT.java (1 line):
- line 440: // TODO: remove once refresh doesn't fail immediately if there a master block:
buildSrc/src/main/java/org/opensearch/gradle/RepositoriesSetupPlugin.java (1 line):
- line 65: // TODO: remove this with gradle 7.0, which no longer allows insecure urls
server/src/main/java/org/opensearch/action/explain/TransportExplainAction.java (1 line):
- line 74: // TODO: AggregatedDfs. Currently the idf can be different then when executing a normal search with explain.
server/src/main/java/org/opensearch/index/engine/LiveVersionMap.java (1 line):
- line 463: // TODO: useful to break down RAM usage here?
server/src/main/java/org/opensearch/cluster/service/MasterService.java (1 line):
- line 374: // TODO: do we want to call updateTask.onFailure here?
modules/lang-painless/src/main/java/org/opensearch/painless/PainlessScript.java (1 line):
- line 92: // TODO: if this is still too long, truncate and use ellipses
server/src/main/java/org/opensearch/index/similarity/SimilarityProviders.java (1 line):
- line 100: // TODO: be and g and both based on the bose-einstein model.
server/src/main/java/org/opensearch/common/lucene/search/function/ScriptScoreQuery.java (1 line):
- line 290: return Float.MAX_VALUE; // TODO: what would be a good upper bound?
server/src/main/java/org/opensearch/index/mapper/AbstractPointGeometryFieldMapper.java (1 line):
- line 178: // TODO make this un-updateable
server/src/main/java/org/opensearch/action/admin/cluster/stats/ClusterStatsNodes.java (1 line):
- line 212: // TODO: do we need to report zeros?
server/src/internalClusterTest/java/org/opensearch/threadpool/SimpleThreadPoolIT.java (1 line):
- line 106: if (threadName.contains("[node_s_0]") // TODO: this can't possibly be right! single node and integ test are unrelated!
server/src/main/java/org/opensearch/search/suggest/phrase/MultiCandidateGeneratorWrapper.java (1 line):
- line 42: //TODO public for tests
plugins/discovery-gce/src/main/java/org/opensearch/discovery/gce/RetryHttpInitializerWrapper.java (1 line):
- line 84: // TODO: figure out why GCE is so bad like this
server/src/main/java/org/opensearch/search/aggregations/bucket/missing/MissingAggregator.java (1 line):
- line 65: // TODO: Stop using nulls here
server/src/main/java/org/opensearch/cluster/metadata/MetadataCreateIndexService.java (1 line):
- line 957: // TODO: this logic can be removed when the current major version is 8
server/src/main/java/org/opensearch/cluster/RepositoryCleanupInProgress.java (1 line):
- line 73: // TODO: Should we allow parallelism across repositories here maybe?
server/src/main/java/org/opensearch/action/fieldcaps/TransportFieldCapabilitiesAction.java (1 line):
- line 129: // TODO we should somehow inform the user that we failed
plugins/repository-azure/src/main/java/org/opensearch/repositories/azure/AzureBlobContainer.java (1 line):
- line 166: // TODO: Upgrade to newer non-blocking Azure SDK 11 and execute delete requests in parallel that way.
plugins/ingest-attachment/src/main/java/org/opensearch/ingest/attachment/TikaImpl.java (1 line):
- line 187: // TODO remove this and from plugin-security.policy when JDK 11 is the only one we support
server/src/main/java/org/opensearch/common/inject/Scopes.java (1 line):
- line 131: // TODO: use diamond operator once JI-9019884 is fixed
server/src/main/java/org/opensearch/search/query/QuerySearchResult.java (1 line):
- line 129: * TODO: Currently we need the concrete aggregators to build empty responses. This means that we cannot
server/src/main/java/org/opensearch/index/search/SimpleQueryStringQueryParser.java (1 line):
- line 261: // TODO: we should not ignore the exception and return a prefix query with the original term ?
server/src/main/java/org/opensearch/search/aggregations/metrics/StatsAggregator.java (1 line):
- line 72: // TODO: stop using nulls here
server/src/main/java/org/opensearch/search/aggregations/metrics/ScriptedMetricAggregator.java (1 line):
- line 113: return ScoreMode.COMPLETE; // TODO: how can we know if the script relies on scores?
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/RareTermsAggregatorFactory.java (1 line):
- line 98: ExecutionMode execution = ExecutionMode.MAP; // TODO global ords not implemented yet, only supports "map"
libs/geo/src/main/java/org/opensearch/geometry/utils/WellKnownText.java (1 line):
- line 478: // TODO: Add 3D support
modules/transport-netty4/src/internalClusterTest/java/org/opensearch/rest/discovery/Zen2RestApiIT.java (1 line):
- line 62: // should be able to move these tests to run against a proper cluster instead. TODO do this.
server/src/main/java/org/opensearch/search/aggregations/metrics/NumericMetricsAggregator.java (1 line):
- line 91: // TODO it'd be faster replace hasMetric and metric with something that returned a function from long to double.
buildSrc/src/main/java/org/opensearch/gradle/internal/InternalBwcGitPlugin.java (1 line):
- line 87: // TODO Gradle should provide property based configuration here
server/src/main/java/org/opensearch/indices/store/TransportNodesListShardStoreMetadata.java (1 line):
- line 187: // TODO: Fallback for BWC with older predecessor (ES) versions.
modules/lang-expression/src/internalClusterTest/java/org/opensearch/script/expression/StoredExpressionIT.java (1 line):
- line 51: //TODO: please convert to unit tests!
server/src/main/resources/org/opensearch/bootstrap/untrusted.policy (1 line):
- line 39: // TODO: clean this up / only give it to engines that really must have it
server/src/main/java/org/opensearch/action/support/nodes/BaseNodesRequest.java (1 line):
- line 54: * TODO: get rid of this and resolve it to concrete nodes in the rest layer
server/src/main/java/org/opensearch/cluster/routing/RoutingNode.java (1 line):
- line 247: // TODO: change caller logic in RoutingNodes so that this check can go away
server/src/main/java/org/opensearch/common/inject/matcher/Matchers.java (1 line):
- line 336: // TODO minJava >= 9 : use ClassLoader.getDefinedPackage and remove @SuppressForbidden
buildSrc/src/main/java/org/opensearch/gradle/vagrant/VagrantExtension.java (1 line):
- line 67: // TODO: should verify this against the Vagrantfile, but would need to do so in afterEvaluate once vagrantfile is unmodifiable
server/src/main/java/org/opensearch/cluster/routing/allocation/command/MoveAllocationCommand.java (1 line):
- line 162: // TODO we can possibly support also relocating cases, where we cancel relocation and move...
plugins/repository-gcs/src/main/java/org/opensearch/repositories/gcs/GoogleCloudStorageRetryingInputStream.java (1 line):
- line 248: // TODO: check that object did not change when stream is reopened (e.g. based on etag)
server/src/main/java/org/opensearch/plugins/PluginsService.java (1 line):
- line 178: // TODO: remove this leniency, but tests bogusly rely on it
server/src/main/java/org/opensearch/action/admin/indices/upgrade/get/TransportUpgradeStatusAction.java (1 line):
- line 146: // TODO: this comparison is bogus! it would cause us to upgrade even with the same format
server/src/main/java/org/opensearch/action/support/single/instance/InstanceShardOperationRequest.java (1 line):
- line 49: // TODO: This request and its associated transport action can be folded into UpdateRequest which is its only concrete production code
server/src/main/java/org/opensearch/search/aggregations/metrics/TopHitsAggregator.java (1 line):
- line 153: // TODO: can we pass trackTotalHits=subSearchContext.trackTotalHits(){
server/src/main/java/org/opensearch/Version.java (1 line):
- line 340: * TODO - uncomment this logic from OpenSearch version 3 onwards
plugins/discovery-ec2/src/main/java/org/opensearch/discovery/ec2/AwsEc2ServiceImpl.java (1 line):
- line 84: // TODO: remove this leniency, these settings should exist together and be validated
server/src/internalClusterTest/java/org/opensearch/search/profile/aggregation/AggregationProfilerIT.java (1 line):
- line 252: // TODO we only index single valued docs but the ordinals ends up with multi valued sometimes
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/BytesKeyedBucketOrds.java (1 line):
- line 180: // TODO we can almost certainly do better here by building something fit for purpose rather than trying to lego together stuff
server/src/main/java/org/opensearch/action/search/CanMatchPreFilterSearchPhase.java (1 line):
- line 188: // TODO: we could fail the request because there is a high probability
server/src/main/java/org/opensearch/rest/action/cat/RestIndicesAction.java (1 line):
- line 684: // TODO: expose docs stats for replicated closed indices
plugins/discovery-ec2/qa/amazon-ec2/src/yamlRestTest/java/org/opensearch/discovery/ec2/AmazonEC2Fixture.java (1 line):
- line 125: // TODO: Implement IMDSv2 behavior here. For now this just returns a 403 which makes the SDK fall back to IMDSv1
server/src/main/java/org/opensearch/threadpool/AutoQueueAdjustingExecutorBuilder.java (1 line):
- line 235: // TODO: in a subsequent change we hope to extend ThreadPool.Info to be more specific for the thread pool type
server/src/main/java/org/opensearch/index/translog/TranslogWriter.java (1 line):
- line 280: // TODO: We haven't had timestamp for Index operations in Lucene yet, we need to loosen this check without timestamp.
server/src/main/java/org/opensearch/index/MergePolicyConfig.java (1 line):
- line 203: // TODO is this really a good default number for max_merge_segment, what happens for large indices,
server/src/main/java/org/opensearch/search/aggregations/bucket/composite/DateHistogramValuesSourceBuilder.java (1 line):
- line 295: // TODO once composite is plugged in to the values source registry or at least understands Date values source types use it
server/src/main/java/org/opensearch/common/lucene/search/TopDocsAndMaxScore.java (1 line):
- line 40: // TODO: Remove this class when https://github.com/elastic/elasticsearch/issues/32981 is addressed.
server/src/main/java/org/opensearch/common/geo/builders/ShapeBuilder.java (1 line):
- line 89: // TODO how might we use JtsSpatialContextFactory to configure the context (esp. for non-geo)?
server/src/main/java/org/opensearch/cluster/node/DiscoveryNode.java (1 line):
- line 75: // TODO: make this a proper setting validation logic, requiring multi-settings validation
modules/aggs-matrix-stats/src/main/java/org/opensearch/search/aggregations/matrix/stats/MatrixStatsAggregatorFactory.java (1 line):
- line 87: // TODO: There must be a better option than this.
server/src/internalClusterTest/java/org/opensearch/index/store/CorruptedFileIT.java (1 line):
- line 543: * TODO once checksum verification on snapshotting is implemented this test needs to be fixed or split into several
server/src/internalClusterTest/java/org/opensearch/search/aggregations/bucket/DoubleTermsIT.java (1 line):
- line 139: private static final int NUM_DOCS = 5; // TODO: randomize the size?
server/src/main/java/org/opensearch/index/mapper/ParametrizedFieldMapper.java (1 line):
- line 139: // TODO remove when everything is parametrized
server/src/main/java/org/opensearch/index/query/TermsSetQueryBuilder.java (1 line):
- line 351: // TODO: Change this to true when we can assume that scripts are pure functions
server/src/main/java/org/apache/lucene/index/OneMergeHelper.java (1 line):
- line 63: * TODO: The number of bytes written during the merge should be accessible in OneMerge.
server/src/main/java/org/opensearch/repositories/blobstore/package-info.java (1 line):
- line 178: * TODO: Remove this section once BwC logic it references is removed
server/src/main/java/org/opensearch/action/search/TransportSearchScrollAction.java (1 line):
- line 82: case ParsedScrollId.QUERY_AND_FETCH_TYPE: // TODO can we get rid of this?
modules/lang-painless/src/main/java/org/opensearch/painless/SimpleChecksAdapter.java (1 line):
- line 48: // TODO: we should really try to get this fixed in ASM!
server/src/main/java/org/opensearch/cluster/metadata/IndexMetadata.java (1 line):
- line 1645: // TODO: do this in 6.0:
server/src/internalClusterTest/java/org/opensearch/search/aggregations/bucket/DateHistogramIT.java (1 line):
- line 147: // TODO: would be nice to have more random data here
plugins/repository-gcs/src/main/java/org/opensearch/repositories/gcs/GoogleCloudStorageHttpStatsCollector.java (1 line):
- line 81: // TODO keep track of unsuccessful requests in different entries
server/src/main/java/org/opensearch/common/util/concurrent/QueueResizingOpenSearchThreadPoolExecutor.java (1 line):
- line 54: // This is a random starting point alpha. TODO: revisit this with actual testing and/or make it configurable
server/src/main/java/org/opensearch/indices/analysis/AnalysisModule.java (1 line):
- line 289: // TODO: pluggability?
server/src/internalClusterTest/java/org/opensearch/cluster/allocation/ClusterRerouteIT.java (1 line):
- line 355: // TODO can we get around this? the cluster is RED, so what do we wait for?
server/src/main/java/org/opensearch/common/inject/util/Modules.java (1 line):
- line 265: // TODO: bind the overridden keys using multibinder
server/src/main/java/org/opensearch/index/search/MultiMatchQuery.java (1 line):
- line 338: // TODO: can we improve this?
server/src/main/java/org/opensearch/index/fielddata/fieldcomparator/BytesRefFieldComparatorSource.java (1 line):
- line 171: // TODO: move this out if we need it for other reasons
buildSrc/src/main/java/org/opensearch/gradle/precommit/ForbiddenApisPrecommitPlugin.java (1 line):
- line 90: // TODO: forbidden apis does not yet support java 15, rethink using runtime version
server/src/main/java/org/opensearch/search/aggregations/bucket/composite/CompositeAggregator.java (1 line):
- line 260: // TODO: can we handle missing bucket when using index sort optimization ?
server/src/main/java/org/opensearch/index/engine/CompletionStatsCache.java (1 line):
- line 105: // TODO: currently we load up the suggester for reporting its size
server/src/main/java/org/opensearch/cluster/coordination/NodeToolCli.java (1 line):
- line 46: // TODO execute CommandLoggingConfigurator.configureLoggingWithoutConfig() in the constructor of commands, not in beforeMain
server/src/main/java/org/opensearch/transport/TransportLogger.java (1 line):
- line 162: // TODO: Maybe Fix for BWC
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/InternalVariableWidthHistogram.java (1 line):
- line 559: // TODO: Think of a fairer way to do this. Should prev.max = cur.min?
server/src/main/java/org/opensearch/search/SearchPhaseResult.java (1 line):
- line 134: // TODO: this seems wrong, SearchPhaseResult should have a writeTo?
server/src/main/java/org/opensearch/action/admin/indices/datastream/DeleteDataStreamAction.java (1 line):
- line 240: // TODO: change order when delete index api also updates the data stream the index to be removed is member of
server/src/internalClusterTest/java/org/opensearch/search/aggregations/pipeline/MovAvgIT.java (1 line):
- line 424: // TODO perhaps pad out seasonal to a power of 2 and use a mask instead of modulo?
plugins/repository-hdfs/src/main/java/org/opensearch/repositories/hdfs/HdfsBlobContainer.java (1 line):
- line 77: // TODO: See if we can get precise result reporting.
plugins/repository-s3/src/main/java/org/opensearch/repositories/s3/S3RepositoryPlugin.java (1 line):
- line 70: // TODO: fix that
server/src/main/java/org/opensearch/common/settings/SecureSetting.java (1 line):
- line 140: // TODO: override toXContent
server/src/main/java/org/opensearch/node/InternalSettingsPreparer.java (1 line):
- line 57: * TODO: Refactor this as transport client is removed and this used to prepare settings for the transport client by
server/src/main/java/org/opensearch/search/aggregations/metrics/SumAggregator.java (1 line):
- line 68: // TODO: stop expecting nulls here
server/src/main/java/org/opensearch/gateway/TransportNodesListGatewayStartedShards.java (1 line):
- line 162: // TODO: Fallback for BWC with older OpenSearch versions.
server/src/main/java/org/opensearch/repositories/RepositoriesService.java (1 line):
- line 409: // TODO: this catch is bogus, it means the old repo is already closed,
server/src/main/java/org/opensearch/common/inject/spi/InjectionPoint.java (1 line):
- line 308: // TODO (crazybob): Filter out overridden members.
server/src/main/java/org/opensearch/cluster/routing/allocation/command/CancelAllocationCommand.java (1 line):
- line 200: // TODO: We don't have to remove a cancelled shard from in-sync set once we have a strict resync implementation.
server/src/main/java/org/opensearch/action/search/TransportSearchAction.java (1 line):
- line 892: // TODO: I think startTime() should become part of ActionRequest and that should be used both for index name
server/src/main/java/org/opensearch/search/aggregations/support/ValuesSource.java (1 line):
- line 123: // TODO lookup the min and max rounding when appropriate
libs/core/src/main/java/org/opensearch/common/io/PathUtils.java (1 line):
- line 51: // TODO: can we move this to the .env package and make it package-private?
server/src/main/java/org/opensearch/search/aggregations/metrics/GeoCentroidAggregator.java (1 line):
- line 69: // TODO: Stop expecting nulls here
server/src/main/java/org/opensearch/index/translog/MultiSnapshot.java (1 line):
- line 79: // TODO: Read translog forward in 9.0+
server/src/main/java/org/opensearch/search/aggregations/bucket/sampler/SamplerAggregator.java (1 line):
- line 59: * TODO currently the diversity feature of this agg offers only 'script' and
server/src/main/java/org/opensearch/search/aggregations/metrics/ExtendedStatsAggregator.java (1 line):
- line 79: // TODO: stop depending on nulls here
server/src/main/java/org/opensearch/action/search/DfsQueryPhase.java (1 line):
- line 86: // TODO we can potentially also consume the actual per shard results from the initial phase here in the aggregateDfs
server/src/main/java/org/opensearch/search/aggregations/bucket/terms/RareTermsAggregationBuilder.java (1 line):
- line 158: // TODO review: what size cap should we put on this?
server/src/main/java/org/opensearch/search/aggregations/metrics/MetricInspectionHelper.java (1 line):
- line 65: // TODO better way to know if the scripted metric received documents?
server/src/internalClusterTest/java/org/opensearch/search/aggregations/bucket/GeoDistanceIT.java (1 line):
- line 446: // TODO: use diamond once JI-9019884 is fixed
server/src/main/java/org/opensearch/search/aggregations/bucket/histogram/LongBounds.java (1 line):
- line 175: // TODO: Should we rather pass roundUp=true?