Categories
DolphinDB's functions can be divided into the following categories according to their functionality:
Data Manipulation
-
Data Types and Conversion: array, arrayVector, bigarray, bool, blob, cast, ceil, char, complex, date, datehour, datetime, decimal32, decimal64, decimal128, decimalFormat, decimalMultiply, deg2rad, dict, double, duration, enlist, fixedLengthArrayVector, floor, form, format, fromJson, parseJsonTable, hex, highDouble, highLong, int, int128, ipaddr, isOrderedDict, long, lowDouble,lowLong, makeKey, makeSortedKey, matrix, minute, month, nanotime, nanotimestamp, pair, point, rad2deg, round, second, seq, set, short, string, subtuple, symbol, syncDict, temporalFormat, temporalParse, time, timestamp, toJson, toStdJson, type, typestr, uuid, indexedSeries, isIndexedSeries, isIndexedMatrix, setIndexedMatrix!, setIndexedSeries!, reverse, transpose/flip, symbolCode, parseInteger, fromStdJson, jsonExtract
-
Appending: append!/push!, appendTuple!, memberModify!
-
Deletion, Cleanup: removeHead!, removeTail!, pop!, drop, dropna, clear!, erase!
-
Finding: tail, head, subarray, first, firstNot, ifirstNot, firstNot, firstHit, ifirstNot, ifirstHit, last, lastNot, ilastNot, milastNot, lastNot, ilastNot, col, row, at, loc, eachAt(@), binsrch, find, searchK, slice, sliceByKey, cell, cells
-
Sorting: sort, sort!, sortBy!, isort, isort!, isortTop, rank, denseRank, isSorted
-
NULL Handling: hasNull, isNothing, isNull, isValid, isVoid, isNanInf, ifNull, ifValid, fill, bfill!, ffill, ffill!, interpolate, nullFill, nullFill!, fill!, lfill, lfill!, nanInfFill
-
Shifting: move, next, prev, prevState, nextState, lshift, rshift
-
Cutting: cut
-
Filtering: conditionalFilter
-
Alignment: align
-
Rearrangement: flatten, shuffle, shuffle!, reshape, regroup, ungroup
-
Grouping: bucket, groups, segment, cutPoints, bar, dailyAlignedBar, volumeBar, digitize
-
Loading: loadNpy, loadNpz, loadRecord, loadTable, loadText, loadTextEx, ploadText
-
Encoding: compress, decompress, oneHot, base64Decode, base64Encode, encodeShortGenomeSeq, decodeShortGenomeSeq, genShortGenomeSeq, pack, unpack, rdp
-
Cumulative Window: cumavg, cumbeta, cumcorr, cumcount, cumcovar, cummax, cummed, cummin, cumpercentile, cumPositiveStreak, cumprod, cumrank, cumstd, cumstdp, cumsum, cumsum2, cumsum3, cumsum4, cumvar, cumvarp, cumwavg, cumwsum, cumfirstNot, cumlastNot, cumnunique, dynamicGroupCumsum, dynamicGroupCumcount
-
Moving: mavg, mbeta, mcorr, mcount, mcovar, mfirst, mimax, mimin, mkurtosis, mlast, mmad, mmax, mmaxPositiveStreak, mmed, mmin, mmse, mpercentile, mprod, mrank, mskew, mslr, mstd, mstdp, msum, msum2, mvar, mvarp, mwavg, mwsum, mlastNot, mifirstNot, mifirstNot, milastNot, movingWindowIndex, movingTopNIndex, mfirstNot, mlastNot, mLowRange, mTopRange
-
Time-Based Moving: tmavg, tmbeta, tmcorr, tmcount, tmcovar, tmfirst, tmkurtosis, tmlast, tmmax, tmmed, tmmin, tmpercentile, tmprod, tmrank, tmskew, tmstd, tmstdp, tmsum, tmsum2, tmvar, tmvarp, tmwavg, tmwsum, tmTopRange, tmLowRange
-
mTopN: msumTopN, mavgTopN, mstdpTopN, mstdTopN, mvarTopN, mvarpTopN, mcorrTopN, mbetaTopN, mcovarTopN, mpercentileTopN,mwsumTopN,
-
Row-Based: rowSize, rowAnd, rowOr, rowXor, rowCount, rowMax, rowMin, rowSum, rowSum2, rowAvg, rowRank, rowDenseRank, rowProd, rowSkew, rowKurtosis, rowStd, rowStdp, rowVar, rowVarp, rowCorr, rowCovar, rowBeta, rowWsum, rowWavg, rowEuclidean, rowDot, rowTanimoto, rowImin, rowImax, rowAt, rowMove, rowNext, rowPrev, rowAlign
-
TA-Lib: ema, ma, wma, sma, trima, tema, dema, gema, kama, wilder, t3, linearTimeTrend
-
String: repeat, charAt, left, right, ilike, like, strpos, regexFind, regexFindStr, concat, lpad, rpad, trim, ltrim, rtrim, strip, substr, substru, split, toCharArray, strlen, strlenu, regexCount, regexReplace, strReplace, startsWith, endsWith, initcap, upper, lower, isLower, isUpper, isTitle, regexFind, isSpace, isAlNum, isAlpha, isNumeric, isDigit, toUTF8, fromUTF8, convertEncode, stringFormat, md5, crc32
-
Time: localtime, gmtime, convertTZ, now, today, daysInMonth, year, month, date, weekday, businessDay, hour, microsecond, millisecond, nanosecond, yearBegin, yearEnd, quarterBegin, quarterEnd, monthBegin, monthEnd, semiMonthBegin, semiMonthEnd, weekBegin, weekEnd, businessMonthBegin, businessMonthEnd, businessQuarterBegin, businessQuarterEnd, businessYearBegin, businessYearEnd, weekOfMonth, weekOfYear, monthOfYear, hourOfDay, minuteOfHour, secondOfMinute, lastWeekOfMonth, dayOfMonth, dayOfWeek, dayOfYear, fy5253, fy5253Quarter, concatDateTime, asFreq, transFreq, temporalSeq, temporalAdd, isLeapYear, isMonthStart, isMonthEnd, isQuarterStart, isQuarterEnd, isYearStart, isYearEnd, addMarketHoliday, updateMarketHoliday, getMarketCalendar
Database/Table
-
Database/Table Management: existsDatabase, existsPartition, existsTable, database, dropDatabase, saveDatabase, setAtomicLevel, setOLAPCacheEngineSize, getOLAPCacheEngineSize, setTSDBCacheEngineSize, getTSDBCacheEngineSize, setMaxMemSize, setReservedMemSize, setMaxBlockSizeForReservedMemory, setMemLimitOfTaskGroupResult, getMemLimitOfTaskGroupResult, setMemLimitOfQueryResult, getMemLimitOfQueryResult, resetRecoveryWorkerNum, getRecoveryWorkerNum, getRecoveryTaskStatus, enableActivePartition, disableActivePartition, enableTSDBAsyncSorting, disableTSDBAsyncSorting, enableQueryMonitor, disableQueryMonitor, setMaxConnections, columnNames, rowNames, table, cachedTable, createTable, createDimensionTable, createPartitionedTable, createDistributedInMemoryTable, createIPCInMemoryTable, indexedTable, keyedTable, latestIndexedTable, latestKeyedTable, mvccTable, dropTable, dropDistributedInMemoryTable, dropIPCInMemoryTable, loadDistributedInMemoryTable, loadIPCInMemoryTable, loadTableBySQL, loadMvccTable, saveTable, savePartition, saveDualPartition, rename!, renameTable, rowNo, setColumnComment, replay, schema, getConfigure/getConfig, getAllDBs, getTables, getTablet, getTabletsMeta, getTSDBMetaData, getDFSDatabases, getClusterDFSDatabases, getDFSTablesByDatabase, getClusterDFSTables, getChunkPath, getChunksMeta, getClusterChunksStatus, getFunctionViews, getTSDBCompactionTaskStatus, getOLAPCachedSymbolBaseMemSize, getTSDBCachedSymbolBaseMemSize, getTransactionStatus, getUnresolvedTxn, getAllDBGranularity, triggerTSDBCompaction, flushTSDBCache, purgeCacheEngine / flushOLAPCache, getLevelFileIndexCacheStatus, getOLAPCacheEngineStat, getTSDBCacheEngineSize, getRedoLogGCStat, addFunctionView, dropFunctionView, addRangePartitions, addValuePartitions, dropPartition, extractTextSchema, tableInsert, addColumn, update!, upsert!, tableUpsert, reorderColumns!, replaceColumn!, dropColumns!, truncate, imr, mr, tupleSum, cacheDS!, cacheDSNow, clearDSCache!, clearDSCacheNow, multiTableRepartitionDS, textChunkDS, repartitionDS, replayDS, sqlDS, transDS!, backup, backupDB, backupTable, migrate, restore, restoreDB, restoreTable, loadBackup, getBackupList, getBackupMeta, getBackupStatus, checkBackup, setMemLimitOfTempResult, , clearAllTSDBSymbolBaseCache, setTableComment, latestKeyedStreamTable, getPKEYMetaData, getPKEYCompactionTaskStatus
-
Catalog: createCatalog, createSchema, dropCatalog, dropSchema, existsCatalog, getCurrentCatalog, getAllCatalogs, getSchemaByCatalog, renameCatalog, renameSchema, setDefaultCatalog
-
Cluster Management: addNode, removeNode, addVolumes, startDataNode, stopDataNode, triggerNodeReport, suspendRecovery, resumeRecovery, cancelRecoveryTask, rebalanceChunksAmongDataNodes, ebalanceChunksWithinDataNode, restoreDislocatedTablet, copyReplicas, deleteReplicas, moveReplicas, startClusterReplication, stopClusterReplication, skipClusterReplicationTask, getMasterReplicationStatus, getSlaveReplicationStatus, getSlaveReplicationQueueStatus, setDatabaseForClusterReplication, getDatabaseClusterReplicationStatus, getRecentSlaveReplicationInfo, moveChunksAcrossVolume, resetDBDirMeta, pnodeRun, getActiveMaster, getConnections, getNodeAlias, getNodeHost, getNodePort, getNodeType, getActiveMaster, isControllerInitialized, isDataNodeInitialized, xdb, rpc, remoteRun, remoteRunCompatible, remoteRunWithCompression, setTimeoutTick
-
Compute Group: clearComputeNodeCache, getComputeNodeCachingDelay, clearComputeNodeDiskCache, flushComputeNodeMemCache, getComputeGroupChunksStatus, getComputeNodeCacheStat, getPrefetchComputeNodeData, setComputeNodeCachingDelay, setPrefetchComputeNodeData
SQL
-
Keywords: select, create, alter, any/all, case, exec, coalesce, where, having, nullIf, top, limit, sample, delete, distinct, insert into, update, drop, pivot by, context by, cgroup by, group by, order by, partition, unpivot, interval, map, union/union all, with, is null, between, exists, in, like, [HINT_EXPLAIN], SQL Trace
-
Table Joiners: cj, ej, sej, lj (left join), lsj (left semi join), fj (full join), right join, aj, wj, pwj, pj, inner join
-
Status View: setTraceMode, getTraces, viewTraceInfo, getCompletedQueries, getRunningQueries, getQueryStatus
Mathematics and Statistics
-
abs, neg, signum, add, div, mul, ratio, mod, square, pow, sqrt, cbrt, log, log2, log10, log1p, exp, exp2, expm1, reciprocal, derivative, integral, iterate, polynomial, cos, cosh, acos, acosh, sin, sinh, asin, asinh, tan, tanh, atan, atanh, linprog, qclp, scs, quadprog, solve, gramSchmidt, brentq, polyFit, poly1d, cubicSpline, cubicSplinePredict, osqp, socp, clip, clip!, signbit, kroghInterpolate
-
med, mmed, var, ewmVar, varp, covar, wcovar, ewmCov, covarMatrix, corrMatrix, std, ewmStd, stdp, percentChange, percentile, percentileRank, quantile, quantileSeries, max, maxIgnoreNull, imax, atImax, mimax, min, minIgnoreNull, imin, atImin, summary, isPeak, isValley, mean, ewmMean, demean, avg, wavg, dot, prod, sum, sum2, sum3, sum4, wsum, contextSum, contextSum2, corr, ewmCorr, acf, autocorr, sem, mad, kurtosis, skew, beta, mutualInfo, spearmanr, euclidean, rowEuclidean, tanimoto, rowTanimoto, cdfBeta, invBeta, randBeta, cdfBinomial, invBinomial, randBinomial, cdfChiSquare, invChiSquare, chiSquareTest, randChiSquare, cdfExp, invExp, randExp, cdfF, invF, fTest, randF, cdfGamma, invGamma, randGamma, cdfKolmogorov, cdfLogistic, invLogistic, randLogistic, norm/normal, cdfNormal, invNormal, zTest, randNormal, randMultivariateNormal, cdfPoisson, invPoisson, randPoisson, cdfStudent, invStudent, randStudent, tTest, cdfUniform, invUniform, rand, randDiscrete, randUniform, cdfWeibull, invWeibull, randWeibull, cdfZipf, mannWhitneyUTest, shapiroTest, ksTest, predict, adaBoostClassifier, adaBoostRegressor, randomForestClassifier, randomForestRegressor, gaussianNB, multinomialNB, logisticRegression, glm, gmm, kmeans, knn, elasticNet, lasso, lassoBasic, ridge, elasticNetCV, lassoCV, ridgeBasic, pca, ols, olsEx, wls, residual, mmse, msl, anova, manova, iterate, count, cols, rows, size, wc, nunique, cumnunique, shape, coevent, countNanInf, bucketCount, contextCount, topRange, lowRange, sumbars, stat, esd, seasonalEsd, dynamicGroupCumcount, dynamicGroupCumsum, lu, svd, qr, schur, imaxLast, iminLast, mimaxLast, miminLast, rowImaxLast, rowIminLast, kendall, lowerBound, vectorAR, piecewiseLinFit, pwlfPredict, gaussianKde, gaussianKdePredict, vectorNorm, fmin, fminLBFGSB, fminNCG, fminBFGS, fminSLSQP, garch, histogram2d, kroghInterpolateFit, linearInterpolateFit
-
distinct, distance, difference, valueChanged, maxPositiveStreak, cumPositiveStreak, mmaxPositiveStreak, det, diag, eig, tril, triu, inverse, cholesky, gram, repmat, sub, intersection, symmetricDifference, keys, values, dictUpdate!,winsorize, winsorize!, resample, spline, neville, dividedDifference, splrep, splev, loess, talibNull, copy, asis, stl, trueRange, zigzag, zscore, crossStat, linearTimeTrend, deltas, ratios, tmove, asof, mode, ilike , all, any, iif, isDuplicated, isMonotonicIncreasing/isMonotonic, isMonotonicDecreasing, mask, convertExcelFormula, hashBucket, objectChecksum, sessionWindow, differentialEvolution
-
bondAccrInt, bondCashflow, bondConvexity, bondDirtyPrice, bondYield, bondDuration, adfuller, coint, VaR, CVaR, nss, nssPredict, brute, varma, maxDrawdown, cds, vanillaOption, irs, cummdd
Operators
Streaming
-
streamTable, haStreamTable, keyedStreamTable, share, appendMsg, appendForJoin, subscribeTable, unsubscribeTable, existsSubscriptionTopic, addMetrics, dropStreamTable, clearTablePersistence, removeTopicOffset, enableTableShareAndPersistence, enableTablePersistence, disableTablePersistence, setStreamTableFilterColumn, getStreamTables, existsStreamTable, setStreamTableTimestamp, enableTableShareAndCachePurge, enableTableCachePurge
-
Streaming Engines: createTimeSeriesEngine, createAnomalyDetectionEngine, createAsofJoinEngine, createCrossSectionalEngine, createDailyTimeSeriesEngine, createEquiJoinEngine / createEqualJoinEngine, createLeftSemiJoinEngine, createReactiveStateEngine, createNarrowReactiveStateEngine, createDualOwnershipReactiveStateEngine, createSessionWindowEngine, createSnapshotJoinEngine, createRuleEngine, createWindowJoinEngine, createLookupJoinEngine, streamEngineParser, dropStreamEngine / dropAggregator, registerSnapshotEngine, unregisterSnapshotEngine, warmupStreamEngine, createTimeBucketEngine, createCEPEngine
-
stateIterate, conditionalIterate, getLeftStream/getRightStream, getStreamEngine/getAggregator, getStreamEngineStat/getAggregatorStat, getPersistenceMeta, getSnapshotMsgId, getStreamEngineList, getStreamingStat, getStreamingLeader, getStreamingRaftGroups, getStreamTableFilterColumn, getPersistenceMeta, getSnapshotMsgId, getSubscriptionTopic, getTopicProcessedOffset, addReactiveMetrics, getReactiveMetrics, getRules, getStreamTableCacheOffset
Metaprogramming
Higher-Order Functions
accumulate (:A), aggrTopN, all, any, byColumn (:V), byRow (:H), call, contextby (:X), cross (:C)/pcross, each (:E), eachLeft (:L), eachPre (:P), eachRight (:R), eachPost (:O), groupby (:G), loop (:U) / ploop, moving, nullCompare, pivot, pcall, reduce (:T), rolling, segmentby, talib, tmoving, twindow, window, withNullFill, unifiedCall, rowGroupby
Access Control
getGroupAccess, getGroupsByUserId, getUserAccess, getUserList, getUsersByGroupId, resetPwd, changePwd, login, logout, isLoggedIn, createGroup, deleteGroup, createUser, deleteUser, addGroupMember, deleteGroupMember, deny, grant, revoke, addAccessControl, getGroupAccess, getGroupsByUserId, getUserAccess, getUserList, getUsersByGroupId, getAuthenticatedUsers, getGroupList, backupSettings, restoreSettings, oauthLogin
File System
file, files, fflush, mkdir, rm, rmdir, close, cleanOutdateLogFiles, exists, seek, read!, readBytes, readLine, readLines, readLines!, readObject, readRecord!, write, writeBytes, writeLine, writeLines, writeRecord, saveText, saveTextFile, saveAsNpy, writeLog, writeLogLevel, writeObject, loadModel, saveModel
System Management
getSupportBundle, license, version, updateLicense, getLicenseExpiration, pipeline, setRandomSeed, setRetentionPolicy, setSystem, setLogLevel, syntax, partial, defined, defs, undef, refCount, member, objs, objByName, closeSessions, getSessionMemoryStat, getCurrentSessionAndUser, loadPlugin, module, use, loadModule, saveModule, loadModuleFromScript, listRemotePlugins, installPlugin, timer, evalTimer, scheduleJob, submitJob, submitJobEx2, submitJobEx, cancelJob, cancelConsoleJob, deleteScheduledJob, setMaxJobParallelism, setMaxJobPriority, getConsoleJobs, getJobMessage, getJobReturn, getJobStat, getJobStatus, getRecentJobs, getScheduledJobs, getPerf, getClusterPerf, getTSDBDataStat, enableResourceTracking, disableResourceTracking, getUserHardwareUsage, getUserTableAccessRecords, setDatanodeRestartInterval, getDatanodeRestartInterval, getDynamicConfig, setDynamicConfig, getTSDBTableIndexCacheStatus, SetMemLimitOfAllTempResults, getMemLimitOfAllTempResults, getLoadedPlugins, startHeapSample, dumpHeapSample, stopHeapSample