iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/StatementAnalyzer.java (10 lines): - line 937: // TODO for more precise error location, pass the mismatching select expression instead of - line 971: // TODO: extract candidate names from SELECT, WHERE, HAVING, GROUP BY and ORDER BY expressions - line 2029: // TODO Auth control - line 2526: column.getAlias().isPresent()); // TODO don't use analysis as a side-channel. Use - line 2781: // TODO: discover columns lazily based on where they are needed (to support connectors that - line 2869: // TODO coerce the whole Row and add an Optimizer rule that converts CAST(ROW(...) AS - line 3571: // TODO: recursive references could be supported in subquery before the point of shadowing. - line 3793: // TODO: collect errors and return them all at once - line 3893: // TODO: use real scope when parameter in offset and limit is supported - line 3931: // TODO: Ensure the disjointness of expressions and allow Or filter iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/iterative/rule/ExpressionRewriteRuleSet.java (8 lines): - line 66: // TODO add it back after we support AggregationNode - line 76: // TODO add it back after we support JoinNode - line 81: // TODO add it back after we support ValuesNode - line 86: // TODO add it back after we support PatternRecognitionNode - line 120: // TODO add it back after we support AggregationNode - line 203: // TODO add it back after we support JoinNode - line 253: // TODO add it back after we support ValuesNode - line 310: // TODO add it back after we support PatternRecognitionNode iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/distribution/SourceRewriter.java (8 lines): - line 417: // TODO how about UDAF? - line 684: // TODO: (xingtanzjr) a temporary way to resolve the distribution of single SeriesScanNode issue - line 1002: // TODO add new type of Node, just traverse all child nodes sequentially in the future - line 1090: // TODO InnerTimeJoinNode's header - line 1171: // TODO: (xingtanzjr) optimize the procedure here to remove duplicated TimeJoinNode - line 1417: // TODO: use 2 phase aggregation to optimize the query - line 1514: // TODO: (xingtanzjr) consider to implement the descriptor construction in every class - line 1666: // TODO: (xingtanzjr) need to confirm the logic when processing UDF iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/receiver/protocol/pipeconsensus/PipeConsensusReceiver.java (8 lines): - line 186: // TODO: check memory when logging WAL(in further version) - line 192: // TODO: support batch transfer(in further version) - line 427: // TODO: turn it to debug after GA - line 546: // TODO: turn it to debug after GA - line 1273: // TODO: remove it into debug after GA - line 1288: // TODO: remove it into debug after GA - line 1509: // TODO: Turn it to debug after GA - line 1554: // TODO: Turn it to debug after GA iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/schema/view/LogicalViewSchema.java (7 lines): - line 86: // TODO: CRTODO:add new CompressionType - line 92: // TODO: CRTODO: add new TSEncoding - line 113: // TODO: CRTODO: add new TSEncoding - line 119: // TODO: CRTODO: is this ok to return a null value? - line 125: // TODO: CRTODO: is this ok to return a null value? - line 180: // TODO: CRTODO: the size of buffer is not calculated! - line 189: // TODO: CRTODO: the size of buffer is not calculated! iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/IrExpressionInterpreter.java (6 lines): - line 523: // TODO use the following after we implement InterpretedFunctionInvoker - line 555: // TODO use the following after we implement InterpretedFunctionInvoker - line 647: // TODO use the following after we implement InterpretedFunctionInvoker - line 654: // TODO define method contract or split into separate methods, as flip(EQUAL) is a negation, - line 713: // TODO use the following after we implement InterpretedFunctionInvoker - line 833: // TODO use the following after we implement InterpretedFunctionInvoker iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/partition/DataPartition.java (5 lines): - line 214: // TODO return the latest dataRegionReplicaSet for each time partition - line 216: // IMPORTANT TODO: (xingtanzjr) need to handle the situation for write operation that there are - line 241: // TODO return the latest dataRegionReplicaSet for each time partition - line 256: // IMPORTANT TODO: (xingtanzjr) need to handle the situation for write operation that there - line 273: // TODO: (xingtanzjr) how to handle this exception in IoTDB iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/InternalPage.java (5 lines): - line 82: // TODO: remove debug parameter INTERNAL_SPLIT_VALVE - line 238: // TODO: initiation and registration methods in SchemaFile - line 501: // for lowest 2 bytes denote key offset, FIXME: '+6' is dependent on encoding of - line 527: // TODO: before leaf node implement cascade delete, - line 586: // TODO: check whether reasonable to throw an unchecked iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/DataRegion.java (4 lines): - line 2268: // TODO: how to avoid partial deletion? - line 2269: // FIXME: notice that if we may remove a SGProcessor out of memory, we need to close all opened - line 2735: // TODO please consider concurrency with read and insert method. - line 3076: // TODO: do more precise control iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/event/response/SubscriptionEventTabletResponse.java (4 lines): - line 124: // TODO: avoid completely rewinding the iterator - line 183: // TODO: TBD. - line 205: // TODO: split tablets - line 219: // TODO: split tablets iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/exchange/MPPDataExchangeManager.java (4 lines): - line 438: // TODO: (xingtanzjr) should we remove the sink from MPPDataExchangeManager ? - line 631: // TODO: replace with callbacks to decouple MPPDataExchangeManager from - line 697: // TODO: replace with callbacks to decouple MPPDataExchangeManager from - line 731: // TODO: replace with callbacks to decouple MPPDataExchangeManager from iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/execution/config/executor/ClusterConfigTaskExecutor.java (4 lines): - line 361: /** FIXME Consolidate this clientManager with the upper one. */ - line 1558: // TODO: send all paths in one RPC - line 2420: // TODO: currently use root to create topic - line 3136: // TODO Do not modify Statement in Analyzer iotdb-client/session/src/main/java/org/apache/iotdb/session/subscription/consumer/base/AbstractSubscriptionConsumer.java (4 lines): - line 577: // TODO: ignore possible interrupted state? - line 635: // TODO: reuse previous timer? - line 673: // TODO: maybe we can poll a few more times - line 686: // TODO: associated with timeoutMs instead of hardcoding iotdb-client/cli/src/main/java/org/apache/iotdb/cli/AbstractCli.java (4 lines): - line 127: // TODO: Make non-static - line 129: // TODO: Make non-static - line 131: // TODO: Make non-static - line 133: // TODO: Make non-static iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/fetcher/TableDeviceSchemaFetcher.java (3 lines): - line 208: // TODO table metadata: implement deduplicate during schemaRegion execution - line 209: // TODO table metadata: need further process on input predicates and transform them into - line 397: // TODO table metadata: process cases that selected attr columns different from those used for iotdb-client/jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBDriver.java (3 lines): - line 76: // TODO Auto-generated method stub - line 82: // TODO Auto-generated method stub - line 93: // TODO Auto-generated method stub iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/pagemgr/PageManager.java (3 lines): - line 181: // TODO: reserve order of insert in container may be better - line 194: // TODO optimization if many device only using template but has no child - line 732: // TODO: to support extreme large MNode iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/execution/QueryExecution.java (3 lines): - line 174: // TODO move this judgement to analyze state? - line 553: // TODO: (xingtanzjr) use more TSStatusCode if the QueryState isn't FINISHED - line 556: // TODO: (xingtanzjr) use more accurate error handling iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/scheduler/FixedRateFragInsStateTracker.java (3 lines): - line 54: // TODO: (xingtanzjr) consider how much Interval is OK for state tracker - line 115: // TODO: (xingtanzjr) a strange case here is that sometimes - line 147: // TODO: do nothing ? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/iterative/rule/SimplifyExpressions.java (3 lines): - line 78: // TODO add it back after we support JoinNode - line 80: // TODO add it back after we support ValuesNode - line 82: // TODO add it back after we support PatternRecognitionNode iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/thrift/impl/DataNodeInternalRPCServiceImpl.java (3 lines): - line 1688: // TODO: Not supported by DeletionEntry, fetch blacklist from schema region - line 2535: // TODO: return which DataNode fail - line 2777: // TODO what need to clean? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/AnalyzeVisitor.java (3 lines): - line 1148: *

TODO: support slimit/soffset/value filter - line 1197: // TODO: support alias - line 3731: // TODO Constant folding optimization for Where Predicate after True/False Constant introduced iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/AliasIndexPage.java (3 lines): - line 39: *

TODO: Another abstract class for this and InternalPage is expected - line 302: // TODO: implement bulk split further - line 481: // TODO: check whether reasonable to throw an unchecked iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/thrift/impl/ClientRPCServiceImpl.java (3 lines): - line 1359: // TODO implement - line 1780: // TODO audit log, quota, StatementType - line 3042: // TODO deal with the sg name here iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/iot/IoTConsensusServerImpl.java (3 lines): - line 316: // TODO: zero copy ? - line 407: // TODO: (xingtanzjr) throw exception if the snapshot load failed - line 518: // TODO: (xingtanzjr) design more reliable way for IoTConsensus iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/optimizations/PushPredicateIntoTableScan.java (3 lines): - line 372: // TODO: in case of grouping sets, we should be able to push the filters over grouping keys - line 402: // TODO: we should be able to infer if conditions on grouping() correspond to - line 947: // TODO: see if there are predicates that can be inferred from the semi join output iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/util/builder/PipeTableModelTsFileBuilderV2.java (3 lines): - line 66: // TODO: remove me later if stable - line 138: // TODO: handle ex - line 228: // TODO: cast iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/util/builder/PipeTreeModelTsFileBuilderV2.java (3 lines): - line 58: // TODO: remove me later if stable - line 127: // TODO: handle ex - line 170: // TODO: cast iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/schema/ClusterSchemaManager.java (3 lines): - line 429: // TODO: Inform DataNodes - line 442: // TODO: Inform DataNodes - line 455: // TODO: Inform DataNodes iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/partition/SchemaPartition.java (3 lines): - line 36: // TODO: Remove this class - line 87: // TODO return the latest dataRegionReplicaSet for each time partition - line 103: // TODO: (xingtanzjr) how to handle this exception in IoTDB iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/scheduler/load/LoadTsFileScheduler.java (3 lines): - line 361: // TODO: retry. - line 381: stateMachine.transitionToFailed(status); // TODO: record more status - line 417: // TODO: retry. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/MTreeBelowSGCachedImpl.java (3 lines): - line 1344: // TODO: This interface should not be exposed to SchemaRegion - line 1349: // TODO: This interface should not be exposed to SchemaRegion - line 1358: // TODO: This interface should not be exposed to SchemaRegion iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/node/metadata/write/view/AlterLogicalViewNode.java (3 lines): - line 65: // TODO: Add auth check for source paths - line 102: // TODO: CRTODO, complete this method - line 132: // TODO: CRTODO, complete this method iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/processor/twostage/plugin/TwoStageCountProcessor.java (3 lines): - line 243: // TODO: Collect watermark events. We ignore it because they may cause OOM in collector. - line 274: // TODO: table model database name is not supported - line 293: // TODO: optimize the combine result fetching with batch fetching iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/subscription/AbstractOperateSubscriptionProcedure.java (2 lines): - line 64: // TODO: consider serializing this variable later - line 69: // TODO: consider serializing this variable later iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/client/ClientPoolFactory.java (2 lines): - line 368: // TODO: consider timeout and evict strategy. - line 401: // TODO: consider timeout and evict strategy. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/execution/config/TableConfigTaskVisitor.java (2 lines): - line 501: // TODO: Place the check at statement analyzer - line 763: // TODO: support validation for other properties iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/EqualityInference.java (2 lines): - line 130: // TODO: be more precise in determining the cost of an expression - line 339: // TODO: this rewrite can probably be made more sophisticated iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/service/thrift/ConfigNodeRPCServiceProcessor.java (2 lines): - line 429: // TODO: Support alter the following fields - line 833: // TODO: Perhaps we should find some other way of shutting down the config node, adding iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/event/batch/SubscriptionPipeTabletEventBatch.java (2 lines): - line 127: // TODO: more precise computation - line 143: // TODO: more precise computation iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/node/ClusterNodeStartUtils.java (2 lines): - line 307: // TODO: Accept internal TEndPoints - line 319: // TODO: Accept internal TEndPoints iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/node/NodeManager.java (2 lines): - line 299: // TODO: invoke a force heartbeat to update new DataNode's status immediately - line 1141: // TODO get real lowest load data node after scoring algorithm being implemented iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/extractor/dataregion/realtime/matcher/CachedSchemaPatternMatcher.java (2 lines): - line 143: // TODO: consider table pattern? - line 154: // TODO: Check the role to determine whether to match with tree model or table model iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/resource/wal/hardlink/PipeWALHardlinkResourceManager.java (2 lines): - line 90: // TODO: Check me! Make sure the file is not a hardlink. - line 91: // TODO: IF user specify a wal by config, will the method work? iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/node/RemoveDataNodesProcedure.java (2 lines): - line 170: // TODO: need to improve the coordinator selection method here, maybe through load - line 198: // TODO terminate all the uncompleted remove datanode process iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/RecordUtils.java (2 lines): - line 48: * TODO: Guardian statements on higher stack NEEDED. The longest ALIAS is limited to 0x7fff(32767) - line 237: * FIXME: recLen is not futile although 'never used', since when decode from a buffer, this field iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/pagemgr/BTreePageManager.java (2 lines): - line 119: // TODO: inefficient to build B+Tree up-to-bottom, improve further - line 338: // TODO: may produce fractured page iotdb-core/datanode/src/main/java/org/apache/iotdb/db/service/metrics/ProcessMetrics.java (2 lines): - line 133: // TODO maybe following metrics can be removed - line 179: // TODO maybe duplicated with thread info in jvm related metrics iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/resource/wal/hardlink/PipeWALHardlinkResource.java (2 lines): - line 38: // TODO: hardlink - line 44: // TODO: hardlink iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/pipe/plugin/DropPipePluginProcedure.java (2 lines): - line 225: // TODO: we should drop the pipe plugin on data nodes properly with RuntimeAgent's help - line 232: // TODO: we should drop the pipe plugin on config nodes properly with RuntimeCoordinator's help iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/ExpressionAnalyzer.java (2 lines): - line 655: // TODO: figure out a type-agnostic way of dealing with this. Maybe add a special unary - line 1088: // TODO: this should be multiset(row(...)) iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/rest/v2/handler/StatementConstructionHandler.java (2 lines): - line 58: // TODO: remove the check for table model - line 221: // TODO: remove the check for table model iotdb-protocol/thrift-datanode/src/main/thrift/datanode.thrift (2 lines): - line 170: // TODO: Need to supply more fields according to implementation - line 304: // TODO: schemaLimitLevel is not used from 1.3.0, keep it for compatibility iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/pipe/event/EnrichedEvent.java (2 lines): - line 323: // TODO: persist regionId in EnrichedEvent - line 336: // TODO: consider tablePattern iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/OperatorTreeGenerator.java (2 lines): - line 2631: // TODO we should also sort the InputLocation for each column if they are not overlapped - line 2741: // TODO implement pipeline division for shuffle sink iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/broker/SubscriptionPrefetchingQueue.java (2 lines): - line 269: // TODO: more refined behavior (prefetch/serialize/...) control - line 401: // TODO: iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/operator/source/ActiveDeviceRegionScanOperator.java (2 lines): - line 93: // TODO: use IDeviceID interface to get ttl - line 95: // TODO: make it more readable, like "30 days" or "10 hours" iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/payload/evolvable/batch/PipeTabletEventTsFileBatch.java (2 lines): - line 135: // TODO: Currently, PipeTreeModelTsFileBuilderV2 still uses PipeTreeModelTsFileBuilder as a - line 151: // TODO: Currently, PipeTableModelTsFileBuilderV2 still uses PipeTableModelTsFileBuilder as a iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/ProcedureManager.java (2 lines): - line 1042: // TODO: choose the DataNode which has lowest load - line 1148: // TODO: choose the DataNode which has lowest load iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/protocol/pipeconsensus/PipeConsensusAsyncConnector.java (2 lines): - line 81: // TODO: Optimize the network and disk io for TsFile onComplete - line 82: // TODO: support Tablet Batch iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/SchemaFile.java (2 lines): - line 69: // TODO: Useless - line 417: /** TODO: shall merge with PageManager#reEstimateSegSize */ iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/agent/SubscriptionBrokerAgent.java (2 lines): - line 60: // TODO: currently we fetch messages from all topics - line 179: // TODO: consider more robust metadata semantics iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/WrappedSegment.java (2 lines): - line 388: // TODO: implement bulk split further - line 449: // FIXME flag of split page is not always the same iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/type/TypeSignatureTranslator.java (2 lines): - line 70: // // TODO: Eventually, we should split the types into VARCHAR and VARCHAR(n) - line 111: .toLowerCase(Locale.ENGLISH); // TODO: make this toUpperCase to match standard SQL semantics iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/TranslationMap.java (2 lines): - line 75: // TODO unused now - line 83: // TODO unused now iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/node/metadata/write/view/CreateLogicalViewNode.java (2 lines): - line 150: // TODO: CRTODO, complete this method - line 180: // TODO: CRTODO, complete this method iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/traverser/updater/Updater.java (2 lines): - line 24: // TODO: In schema file mode, since the updated node won't be cache evicted until it been flushed to - line 28: // TODO: rename to traverse() iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/LocalExecutionPlanner.java (2 lines): - line 172: // TODO Replace operator with operatorFactory to build multiple driver for one pipeline - line 266: // TODO @spricoder: consider a better way iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/sql/ast/Expression.java (2 lines): - line 54: // TODO make abstract later - line 57: // TODO make abstract later iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/memtable/TsFileProcessor.java (2 lines): - line 1325: * TODO if the flushing thread is too fast, the tmpMemTable.wait() may never wakeup Tips: I am - line 1971: // TODO Tien change the way iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/subscription/meta/topic/TopicMeta.java (2 lines): - line 46: // TODO: remove this variable later - line 191: // TODO: currently set skipif to no-privileges iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/compaction/selector/impl/RewriteCrossSpaceCompactionSelector.java (2 lines): - line 280: // TODO: (xingtanzjr) need to confirm whether we should strictly guarantee the conditions - line 360: // TODO: (xingtanzjr) need to confirm what this ttl is used for iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/persistence/partition/PartitionInfo.java (2 lines): - line 329: // TODO: Replace this map with new SchemaPartition - line 386: // TODO: Replace this map whit new DataPartition iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/SegmentedPage.java (2 lines): - line 44: // TODO offset bits of segment never removed since it is 'sequential-indexed' - line 576: // TODO: add to interface iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/receiver/SubscriptionReceiverV1.java (2 lines): - line 267: // TODO: do something - line 741: // TODO: broker TTL if no consumer in consumer group iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/schema/ISchemaAutoCreation.java (2 lines): - line 42: // TODO: Check necessity because all implementations return null - line 45: // TODO: Check necessity because all implementations return null iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/memory/MemoryManager.java (2 lines): - line 164: // TODO @spricoder: consider to find more memory in active way - line 221: // TODO @spricoder: consider to find more memory in active way iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/QueryPlanner.java (2 lines): - line 142: // TODO result is :input[0], :input[1], :input[2] - line 496: // TODO: for ORDER BY arguments, rewrite them such that they match the actual arguments to the iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/sql/util/SqlFormatter.java (2 lines): - line 1162: // TODO: consider pipeName and hasWhereClause in node - line 1495: // TODO: handle this properly iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/iterative/IterativeOptimizer.java (2 lines): - line 95: // TODO Use properties in session to specify whether to use the old optimizer - line 108: // TODO Use properties in session to specify, use default as Trino now iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/broker/SubscriptionBroker.java (2 lines): - line 80: // TODO: config - line 430: // TODO: consider more robust metadata semantics iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/fetcher/TableHeaderSchemaValidator.java (2 lines): - line 118: // TODO table metadata: authority check for table create - line 230: // TODO table metadata: authority check for table alter iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/distribution/DistributionPlanner.java (2 lines): - line 235: // TODO: (xingtanzjr) Maybe we should handle ResultNode in LogicalPlanner ? - line 281: // TODO: (xingtanzjr) we apply no action for IWritePlanNode currently iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/utils/WALEntryPosition.java (2 lines): - line 104: // TODO: Reuse the file stream - line 140: // TODO: Refactor this part of code iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/node/process/GroupByTagNode.java (1 line): - line 97: // TODO: better do deep copy iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/utils/matching/Pattern.java (1 line): - line 55: // FIXME make sure there's a proper toString, iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/load/balancer/region/GreedyRegionGroupAllocator.java (1 line): - line 93: // TODO: Implement this method iotdb-core/relational-grammar/src/main/antlr4/org/apache/iotdb/db/relational/grammar/type/TypeCalculation.g4 (1 line): - line 20: //TODO: consider using the SQL grammar for this iotdb-core/datanode/src/main/java/org/apache/iotdb/db/consensus/DataRegionConsensusImpl.java (1 line): - line 70: // TODO: This needs removal of statics ... iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/type/TypeSignature.java (1 line): - line 108: // TODO: this is somewhat of a hack. We need to evolve TypeSignature to be more "structural" for iotdb-core/datanode/src/main/java/org/apache/iotdb/db/service/RegionMigrateService.java (1 line): - line 73: // TODO: Due to the use of procedureId as taskId, it is currently unable to handle the situation iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/pipe/connector/protocol/IoTDBConnector.java (1 line): - line 495: // TODO: Not all the limiters should be closed here, but it's fine for now. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/node/load/LoadTsFilePieceNode.java (1 line): - line 135: ReadWriteIOUtils.write(tsFile.getPath(), stream); // TODO: can save this space iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/node/schema/AbstractTableSchemaQueryAttributeSecurityVisitor.java (1 line): - line 47: // TODO: apply multi regions? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/log/SchemaFileLogWriter.java (1 line): - line 35: // TODO: improve if the following considered as waste iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/consensus/response/partition/SchemaNodeManagementResp.java (1 line): - line 41: // TODO: Replace this map with new SchemaPartition iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/event/common/tsfile/PipeTsFileInsertionEvent.java (1 line): - line 157: // TODO: process the shared mod file iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/path/PartialPath.java (1 line): - line 413: // TODO change this way iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/pipe/agent/plugin/PipeConfigRegionProcessorConstructor.java (1 line): - line 37: // TODO: support constructing plugin by reflection iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/AbstractFragmentParallelPlanner.java (1 line): - line 115: // TODO: (Chen Rongzhao) need to make the values of ReadConsistencyLevel as static variable or iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/mem/mnode/info/DatabaseDeviceInfo.java (1 line): - line 29: * eventually deleted. TODO: database ttl is useless here, which can be removed. iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/pipe/agent/plugin/PipeConfigRegionConnectorConstructor.java (1 line): - line 71: // TODO: support constructing plugin by reflection iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/node/write/InsertRowNode.java (1 line): - line 432: // TODO: (xingtanzjr) remove placeholder iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/IrTypeAnalyzer.java (1 line): - line 203: // TODO: iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/memory/LocalMemoryManager.java (1 line): - line 33: // TODO @spricoder: why this pool is only used for query data exchange iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/consensus/request/write/partition/CreateSchemaPartitionPlan.java (1 line): - line 42: // TODO: Replace this field whit new SchemaPartition. iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/persistence/schema/ClusterSchemaInfo.java (1 line): - line 232: // TODO: Support alter other fields iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/subscription/subscription/CreateSubscriptionProcedure.java (1 line): - line 69: // TODO: remove this variable later iotdb-core/datanode/src/main/java/org/apache/iotdb/db/service/DataNode.java (1 line): - line 181: // TODO: This needs removal of statics ... iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/sql/ast/AbstractTraverseDevice.java (1 line): - line 45: // TODO table metadata: reuse query distinct logic iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/pagemgr/PagePool.java (1 line): - line 54: * cache size anymore. TODO A better guardian is based on constraint per thread. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/buffer/WALBuffer.java (1 line): - line 573: // TODO: Control the wal file by the number of WALEntry iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/mem/mnode/info/DatabaseInfo.java (1 line): - line 27: // TODO: Useless iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/conf/SystemPropertiesUtils.java (1 line): - line 66: // TODO: This needs removal of statics ... iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/trigger/DropTriggerProcedure.java (1 line): - line 84: // TODO consider using reference counts to determine whether to remove jar iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/utils/TypeUtil.java (1 line): - line 126: // TODO move these methods into each Type to avoid branch miss iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/pipe/agent/task/execution/PipeSubtaskExecutor.java (1 line): - line 169: // TODO: temporarily disable async receiver subtask execution iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/sql/ast/DeleteDevice.java (1 line): - line 75: // TODO: Fallback to precise devices if modEnries parsing failure encountered iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/client/ConfigNodeClientManager.java (1 line): - line 30: // TODO: This needs removal of statics ... iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/agent/plugin/dataregion/PipeDataRegionPluginAgent.java (1 line): - line 77: // TODO: validate visibility for schema region and config region iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/pagemgr/PageIOChannel.java (1 line): - line 89: // TODO check bytes semantic correctness with CRC32 or other way iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/AnalyzeUtils.java (1 line): - line 318: // TODO: may use time and db/table to filter iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/plan/node/BaseSourceRewriter.java (1 line): - line 30: // TODO: (xingtanzjr) we apply no action for IWritePlanNode currently iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/session/SessionManager.java (1 line): - line 178: // TODO we only need to do so when query is killed by time out close the socket. iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/consensus/response/partition/SchemaPartitionResp.java (1 line): - line 40: // TODO: Replace this map with new SchemaPartition iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/pipe/service/PipeConsensusRPCServiceProcessor.java (1 line): - line 72: // TODO: consider batch transfer iotdb-core/datanode/src/main/java/org/apache/iotdb/db/conf/IoTDBStartCheck.java (1 line): - line 111: // TODO: This needs removal of statics ... iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/traverser/collector/DatabaseCollector.java (1 line): - line 47: // TODO: make collectDatabase return R iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/optimizations/LogicalOptimizeFactory.java (1 line): - line 103: // TODO After ValuesNode introduced iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/fragment/DataNodeQueryContext.java (1 line): - line 41: // TODO consider more fine-grained locks, now the AtomicInteger in uncachedPathToSeriesScanInfo is iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/iot/IoTConsensusServerMetrics.java (1 line): - line 102: // TODO: Consider adding topological order to the traversal of metricEntry. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/mqtt/MPPPublishHandler.java (1 line): - line 321: // TODO: Implement something sensible here ... iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/pipe/PipeConsensus.java (1 line): - line 556: // TODO: check logical clock iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/traverser/collector/MeasurementCollector.java (1 line): - line 31: // TODO: set R is ITimeseriesInfo iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/operator/source/relational/aggregation/LastByAccumulator.java (1 line): - line 334: // TODO can add last position optimization if last position is null ? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/PipelineDriverFactory.java (1 line): - line 37: // TODO Use OperatorFactory to replace operator to generate multiple drivers for on pipeline iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/iot/logdispatcher/Batch.java (1 line): - line 63: // TODO Maybe we need to add in additional fields for more accurate calculations iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/buffer/ChunkCache.java (1 line): - line 80: // TODO @spricoder: find a way to get the size of the ChunkCache iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/ratis/utils/Utils.java (1 line): - line 276: // FIXME: retain 2 copies to avoid race conditions between (delete) and (transfer) iotdb-client/service-rpc/src/main/java/org/apache/iotdb/rpc/subscription/config/TopicConfig.java (1 line): - line 46: // TODO: hide from the client iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/pipe/extractor/IoTDBConfigRegionExtractor.java (1 line): - line 88: // TODO: Delete this iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/event/batch/SubscriptionPipeTabletIterationSnapshot.java (1 line): - line 59: // TODO: unify close interface iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/agent/plugin/schemaregion/PipeSchemaRegionProcessorConstructor.java (1 line): - line 37: // TODO: Support constructing plugin by reflection iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/load/balancer/region/PartiteGraphPlacementRegionGroupAllocator.java (1 line): - line 125: // TODO: Implement this method iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/predicate/schema/ExtractPredicateColumnNameVisitor.java (1 line): - line 43: // TODO: implement schema function filter and parse some function call and arithmetic filters iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/client/async/AsyncDataNodeHeartbeatClientPool.java (1 line): - line 55: // TODO: Is the AsyncDataNodeHeartbeatClientPool must be a singleton? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/io/WALByteBufReader.java (1 line): - line 77: // TODO: Reuse this buffer iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/exchange/MPPDataExchangeService.java (1 line): - line 62: // TODO: Use a priority queue. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/utils/matching/pattern/FilterPattern.java (1 line): - line 46: // TODO remove cast iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/event/common/tablet/PipeInsertNodeTabletInsertionEvent.java (1 line): - line 432: // TODO: for table model insertion, we need to get the database name iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/traverser/collector/MNodeCollector.java (1 line): - line 34: // TODO: set R to IMNodeInfo iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/conf/ConfigNodeConfig.java (1 line): - line 60: // TODO: Read from iotdb-confignode.properties. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/traverser/collector/EntityCollector.java (1 line): - line 31: // TODO: set R is IDeviceSchemaInfo iotdb-client/cli/src/main/java/org/apache/iotdb/cli/utils/JlineUtils.java (1 line): - line 106: // TODO: since the lexer doesn't produce tokens for quotation marks, disable the highlighter to iotdb-core/ainode/resources/syncPythonVersion.groovy (1 line): - line 189: // TODO: When releasing, we might need to manually add this file to the release preparation commit. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/consensus/SchemaRegionConsensusImpl.java (1 line): - line 53: // TODO: This needs removal of statics ... iotdb-client/session/src/main/java/org/apache/iotdb/session/subscription/consumer/base/SubscriptionExecutorServiceManager.java (1 line): - line 287: // TODO: temporarily disable multiple poll iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/RetryFailedTasksThread.java (1 line): - line 51: // TODO: Replace this class by cluster events iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/PredicateUtils.java (1 line): - line 48: * TODO consider more expression types iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/ir/ExtractCommonPredicatesExpressionRewriter.java (1 line): - line 145: // TODO: This can be optimized further if non-deterministic elements are not repeated iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/file/SystemPropertiesHandler.java (1 line): - line 143: // TODO: this line should be removed in 1.5 library-udf/src/main/java/org/apache/iotdb/library/match/PatternExecutor.java (1 line): - line 316: /* TODO if slow could be useful to have a cache (the key could be based on the sections id) to avoid those copies */ iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/mem/MTreeBelowSGMemoryImpl.java (1 line): - line 693: // TODO: seems useless iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/rest/v1/handler/StatementConstructionHandler.java (1 line): - line 48: // TODO: remove the check for table model iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/path/PatternTreeMap.java (1 line): - line 143: // TODO change this way iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/parser/ASTVisitor.java (1 line): - line 3578: // TODO: Maybe add a show ConfigNode region in the future iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/persistence/node/NodeInfo.java (1 line): - line 747: // TODO: Compatibility design. Should replace this function to actual deserialization method iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/event/SubscriptionEvent.java (1 line): - line 190: // TODO: clean more fields iotdb-client/cli/src/main/java/org/apache/iotdb/cli/Cli.java (1 line): - line 51: // TODO: Make non-static iotdb-client/service-rpc/src/main/java/org/apache/iotdb/rpc/BaseRpcTransportFactory.java (1 line): - line 32: // TODO: make it a config iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/event/common/row/PipeRowCollector.java (1 line): - line 125: // TODO: non-PipeInsertionEvent sourceEvent is not supported? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/TableLogicalPlanner.java (1 line): - line 243: // TODO perfect the logic of outputDescriptor iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/common/MPPQueryContext.java (1 line): - line 94: // TODO too many callers just pass a null SessionInfo which should be forbidden iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/metric/overview/PipeWALInsertNodeCacheMetrics.java (1 line): - line 130: // TODO: waiting called by WALInsertNodeCache iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/pipe/agent/plugin/PipeConfigRegionExtractorConstructor.java (1 line): - line 45: // TODO: support constructing plugin by reflection iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/pipe/receiver/protocol/IoTDBConfigNodeReceiver.java (1 line): - line 636: // TODO: Record complete message in trigger iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/pipe/datastructure/visibility/VisibilityTestUtils.java (1 line): - line 121: // TODO: We assume the first interface iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/CachedMTreeStore.java (1 line): - line 70: // TODO: delete it iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/schedule/task/DriverTaskId.java (1 line): - line 35: // TODO Create another field to store id of driver level iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/utils/matching/pattern/WithPattern.java (1 line): - line 52: // TODO remove cast iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/subscription/subscription/DropSubscriptionProcedure.java (1 line): - line 67: // TODO: remove this variable later iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/predicate/PredicateCombineIntoTableScanChecker.java (1 line): - line 126: // TODO After Constant-Folding introduced iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/agent/plugin/PipeDataNodePluginAgent.java (1 line): - line 206: // TODO: validate pipe plugin attributes for config node iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/ratis/metrics/IoTDBMetricRegistry.java (1 line): - line 139: // TODO (szywilliam) we can add an interface like removeTypeless(name) iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/operator/source/relational/aggregation/grouped/builder/InMemoryHashAggregationBuilder.java (1 line): - line 155: // TODO reset of GroupByHash iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/impl/SchemaRegionMemoryImpl.java (1 line): - line 1394: // TODO: We can consider implement this as a consumer passed to MTree which takes responsibility iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/subscription/SubscriptionMetaSyncer.java (1 line): - line 94: // TODO: consider drop the topic which is subscribed by consumers iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/client/ConfigNodeInfo.java (1 line): - line 60: // TODO: This needs removal of statics ... iotdb-client/jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBAbstractDatabaseMetadata.java (1 line): - line 540: // TODO: Return the URL for this DBMS or null if it cannot be generated iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/scheduler/FragmentInstanceDispatcherImpl.java (1 line): - line 129: // TODO: (xingtanzjr) currently we use a sequential dispatch policy for READ, which is iotdb-core/datanode/src/main/java/org/apache/iotdb/db/service/metrics/memory/QueryEngineMemoryMetrics.java (1 line): - line 203: // TODO @spricoder: CoordinatorMemoryManager are not used iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/iterative/rule/CanonicalizeExpressionRewriter.java (1 line): - line 164: // TODO: this should eventually be removed when IR includes types iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/agent/plugin/schemaregion/PipeSchemaRegionExtractorConstructor.java (1 line): - line 45: // TODO: support constructing plugin by reflection iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/schema/ClusterSchemaQuotaStatistics.java (1 line): - line 29: // TODO: it can be merged with statistics in ClusterQuotaManager iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/SchemaEngine.java (1 line): - line 286: // TODO: handle duplicated regionId across different database iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/compaction/execute/performer/impl/ReadChunkCompactionPerformer.java (1 line): - line 243: // TODO: we can provide a configuration item to enable concurrent between each series iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/sql/util/ExpressionFormatter.java (1 line): - line 227: // TODO return node value without "DECIMAL '..'" when iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/ScopeAware.java (1 line): - line 51: * because we currently don't assign identity to table references. (TODO: implement this) iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/ClusterQuotaManager.java (1 line): - line 81: // TODO: Datanode failed to receive rpc iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/task/subtask/SubscriptionConnectorSubtask.java (1 line): - line 76: // TODO: Futures.withTimeout iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/log/SchemaFileLogReader.java (1 line): - line 58: // TODO: better performance if not scan from head to tail iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/env/ConfigNodeProcedureEnv.java (1 line): - line 371: // TODO: invoke a force heartbeat to update new ConfigNode's status immediately iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/event/common/tablet/parser/TabletInsertionEventTablePatternParser.java (1 line): - line 91: // TODO: Remove it if we do not need it in the future. iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/region/AddRegionPeerProcedure.java (1 line): - line 223: // TODO: more precise iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/concurrent/ThreadName.java (1 line): - line 98: // TODO: Use Thread Pool to manage the procedure thread @Potato iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/FunctionNullability.java (1 line): - line 49: // TODO modify for each scalar function iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/env/RegionMaintainHandler.java (1 line): - line 315: // TODO: will use 'procedure yield' to refactor later iotdb-client/session/src/main/java/org/apache/iotdb/session/Session.java (1 line): - line 1347: // TODO https://issues.apache.org/jira/browse/IOTDB-1399 iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/client/async/CnToDnAsyncRequestType.java (1 line): - line 106: // TODO Need to migrate to Node Maintenance iotdb-core/datanode/src/main/java/org/apache/iotdb/db/utils/datastructure/BackwardSort.java (1 line): - line 171: * TODO: optional sort algorithms by inversion rates and block_size iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/executable/ExecutableManager.java (1 line): - line 84: // TODO: para download iotdb-client/session/src/main/java/org/apache/iotdb/session/subscription/consumer/base/AbstractSubscriptionProvider.java (1 line): - line 160: // TODO: pass the complete consumer parameter configuration to the server iotdb-core/datanode/src/main/java/org/apache/iotdb/db/conf/DataNodeMemoryConfig.java (1 line): - line 574: // TODO @spricoder: influence dynamic change of memory size iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/load/LoadTsFileAnalyzer.java (1 line): - line 526: // TODO: how to get the correct write point count when iotdb-core/datanode/src/main/java/org/apache/iotdb/db/utils/datastructure/QuickSort.java (1 line): - line 81: // TODO: use insertion sort in smaller array iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/operator/schema/source/DeviceSchemaSource.java (1 line): - line 105: // TODO: make it more readable, like "30 days" or "10 hours" iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/udf/builtin/BuiltinAggregationFunction.java (1 line): - line 106: // TODO Maybe we can merge this method with canUseStatistics(), iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/impl/pipe/AbstractOperatePipeProcedureV2.java (1 line): - line 93: // TODO: consider serializing this variable later iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/Field.java (1 line): - line 203: // TODO: need to know whether the qualified name and the name of this field were quoted iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/pipe/agent/task/PipeConfigNodeSubtask.java (1 line): - line 60: // TODO: currently unused iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/ir/GlobalTimePredicateExtractVisitor.java (1 line): - line 203: // TODO After Constant-Folding introduced iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/broker/SubscriptionPrefetchingQueueStates.java (1 line): - line 61: private final Counter disorderCauseCounter; // TODO: use meter iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/sql/parser/ErrorHandler.java (1 line): - line 296: // TODO expand ignored rules like we expand special rules iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/agent/plugin/schemaregion/PipeSchemaRegionConnectorConstructor.java (1 line): - line 71: // TODO: support constructing plugin by reflection iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/manager/ClusterManager.java (1 line): - line 110: // TODO: Parallel test ConfigNode and DataNode iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/load/converter/LoadTableStatementDataTypeConvertExecutionVisitor.java (1 line): - line 74: // TODO: Use batch insert after Table model supports insertMultiTablets iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/buffer/TimeSeriesMetadataCache.java (1 line): - line 86: // TODO @spricoder find a better way to get the size of cache iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/extractor/schemaregion/IoTDBSchemaRegionExtractor.java (1 line): - line 86: // TODO: Delete this iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/protocol/opcda/OpcDaConnector.java (1 line): - line 60: // TODO: upgrade this logic after "1 in 2" logic is supported iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/execution/schedule/queue/multilevelqueue/MultilevelPriorityQueue.java (1 line): - line 308: // TODO figure out why add newLevelMinScheduledTime iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/iterative/rule/RemoveTrivialFilters.java (1 line): - line 51: // TODO add it back after we support ValuesNode iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/load/LoadTsFileTableSchemaCache.java (1 line): - line 150: // TODO: add permission check and record auth cost iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/statement/metadata/region/MigrateRegionStatement.java (1 line): - line 40: // TODO: Whether to support more complex migration, such as, migrate all region from 1, 2 to 5, 6 iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/resource/memory/PipeMemoryManager.java (1 line): - line 48: // TODO @spricoder: consider combine memory block and used MemorySizeInBytes iotdb-core/datanode/src/main/java/org/apache/iotdb/db/tools/TsFileSplitTool.java (1 line): - line 85: // TODO maxPlanIndex and minPlanIndex should be modified after cluster is refactored iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/compaction/execute/utils/executor/batch/utils/AlignedSeriesBatchCompactionUtils.java (1 line): - line 225: // TODO: select batch by allocated memory and chunk size to perform more strict memory control iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/Analysis.java (1 line): - line 80: /** Analysis used for planning a query. TODO: This class may need to store more info for a query. */ iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/pipe/agent/task/progress/PipeEventCommitter.java (1 line): - line 120: // TODO: waiting called by PipeEventCommitMetrics iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/planner/distribution/ExchangeNodeAdder.java (1 line): - line 91: // TODO: (xingtanzjr) we apply no action for IWritePlanNode currently iotdb-core/datanode/src/main/java/org/apache/iotdb/db/schemaengine/schemaregion/mtree/impl/pbtree/schemafile/pagemgr/SchemaPageContext.java (1 line): - line 90: // FIXME rough resolve for reentrant write lock iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/planner/PlanNodeSearcher.java (1 line): - line 51: *

TODO: replace it with a support for plan (physical) properties in rules pattern matching library-udf/src/main/java/org/apache/iotdb/library/drepair/util/ARFill.java (1 line): - line 26: // TODO Higer order AR regression iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/analyze/PredicateUtils.java (1 line): - line 339: // TODO: consider other structures of tree iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/predicate/schema/ConvertSchemaPredicateToFilterVisitor.java (1 line): - line 114: // TODO: Support stringLiteral like id/attr? iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/iot/logdispatcher/IndexController.java (1 line): - line 204: // TODO: (xingtanzjr) we need to handle the situation that file creation failed. iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/rest/v2/impl/GrafanaApiServiceImpl.java (1 line): - line 232: // TODO: necessary to create a PartialPath iotdb-core/confignode/src/main/java/org/apache/iotdb/confignode/procedure/Procedure.java (1 line): - line 725: // TODO: can this be inferred from the stack? I think so... iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/analyzer/predicate/schema/CheckSchemaPredicateVisitor.java (1 line): - line 66: // TODO: improve the distinct result set detection logic iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/rest/v1/impl/GrafanaApiServiceImpl.java (1 line): - line 232: // TODO: necessary to create a partial path? iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/optimization/LimitOffsetPushDown.java (1 line): - line 185: // TODO we may need to push limit and offset to left child iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/transformation/dag/intermediate/MultiInputLayer.java (1 line): - line 178: // TODO: maybe one constant is enough, notice this 0 iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/compaction/selector/impl/SettleSelectorImpl.java (1 line): - line 230: // TODO: remove deviceId conversion iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/buffer/BloomFilterCache.java (1 line): - line 65: // TODO @spricoder: find a way to get the size of the BloomFilterCache iotdb-core/datanode/src/main/java/org/apache/iotdb/db/subscription/agent/SubscriptionConsumerAgent.java (1 line): - line 136: // TODO: Currently we fully replace the entire ConsumerGroupMeta without carefully checking the