Configuration Vocabulary

The Configuration Vocabulary lists all available configurations provided by application.yml.

Main Configuration

The main configuration is provided by application.yml. It divided into several modules, each of which has its own settings. The following table lists the modules and their settings.

ModuleProviderSettingsValue(s) and ExplanationSystem Environment Variable¹Default
coredefaultroleOption values: Mixed/Receiver/Aggregator. Receiver mode OAP opens the service to the agents, then analyzes and aggregates the results, and forwards the results for distributed aggregation. Aggregator mode OAP receives data from Mixer and Receiver role OAP nodes, and performs 2nd level aggregation. Mixer means both Receiver and Aggregator.SW_CORE_ROLEMixed
--restHostBinding IP of RESTful services. Services include GraphQL query and HTTP data report.SW_CORE_REST_HOST0.0.0.0
--restPortBinding port of RESTful services.SW_CORE_REST_PORT12800
--restContextPathWeb context path of RESTful services.SW_CORE_REST_CONTEXT_PATH/
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_CORE_REST_IDLE_TIMEOUT30000
--restAcceptQueueSizeServerSocketChannel Backlog of RESTful services.SW_CORE_REST_QUEUE_SIZE0
--httpMaxRequestHeaderSizeMaximum request header size accepted.SW_CORE_HTTP_MAX_REQUEST_HEADER_SIZE8192
--gRPCHostBinding IP of gRPC services, including gRPC data report and internal communication among OAP nodes.SW_CORE_GRPC_HOST0.0.0.0
--gRPCPortBinding port of gRPC services.SW_CORE_GRPC_PORT11800
--gRPCSslEnabledActivates SSL for gRPC services.SW_CORE_GRPC_SSL_ENABLEDfalse
--gRPCSslKeyPathFile path of gRPC SSL key.SW_CORE_GRPC_SSL_KEY_PATH-
--gRPCSslCertChainPathFile path of gRPC SSL cert chain.SW_CORE_GRPC_SSL_CERT_CHAIN_PATH-
--gRPCSslTrustedCAPathFile path of gRPC trusted CA.SW_CORE_GRPC_SSL_TRUSTED_CA_PATH-
--downsamplingActivated level of down sampling aggregation.Hour,Day
--enableDataKeeperExecutorController of TTL scheduler. Once disabled, TTL wouldn't work.SW_CORE_ENABLE_DATA_KEEPER_EXECUTORtrue
--dataKeeperExecutePeriodExecution period of TTL scheduler (in minutes). Execution doesn't mean deleting data. The storage provider (e.g. ElasticSearch storage) could override this.SW_CORE_DATA_KEEPER_EXECUTE_PERIOD5
--recordDataTTLThe lifecycle of record data (in days). Record data includes traces, top N sample records, and logs. Minimum value is 2.SW_CORE_RECORD_DATA_TTL3
--metricsDataTTLThe lifecycle of metrics data (in days), including metadata. We recommend setting metricsDataTTL >= recordDataTTL. Minimum value is 2.SW_CORE_METRICS_DATA_TTL7
--l1FlushPeriodThe period of L1 aggregation flush to L2 aggregation (in milliseconds).SW_CORE_L1_AGGREGATION_FLUSH_PERIOD500
--storageSessionTimeoutThe threshold of session time (in milliseconds). Default value is 70000.SW_CORE_STORAGE_SESSION_TIMEOUT70000
--persistentPeriodThe period of doing data persistence. Unit is second.Default value is 25sSW_CORE_PERSISTENT_PERIOD25
--topNReportPeriodThe execution period (in minutes) of top N sampler, which saves sampled data into the storage.SW_CORE_TOPN_REPORT_PERIOD10
--activeExtraModelColumnsAppends entity names (e.g. service names) into metrics storage entities.SW_CORE_ACTIVE_EXTRA_MODEL_COLUMNSfalse
--serviceNameMaxLengthMaximum length limit of service names.SW_SERVICE_NAME_MAX_LENGTH70
--instanceNameMaxLengthMaximum length limit of service instance names. The maximum length of service + instance names should be less than 200.SW_INSTANCE_NAME_MAX_LENGTH70
--endpointNameMaxLengthMaximum length limit of endpoint names. The maximum length of service + endpoint names should be less than 240.SW_ENDPOINT_NAME_MAX_LENGTH150
--searchableTracesTagsDefines a set of span tag keys which are searchable through GraphQL. Multiple values are separated by commas. The max length of key=value should be less than 256 or will be dropped.SW_SEARCHABLE_TAG_KEYShttp.method,http.status_code,rpc.status_code,db.type,db.instance,mq.queue,mq.topic,mq.broker
--searchableLogsTagsDefines a set of log tag keys which are searchable through GraphQL. Multiple values are separated by commas. The max length of key=value should be less than 256 or will be dropped.SW_SEARCHABLE_LOGS_TAG_KEYSlevel
--searchableAlarmTagsDefines a set of alarm tag keys which are searchable through GraphQL. Multiple values are separated by commas. The max length of key=value should be less than 256 or will be dropped.SW_SEARCHABLE_ALARM_TAG_KEYSlevel
--autocompleteTagKeysQueryMaxSizeThe max size of tags keys for autocomplete select.SW_AUTOCOMPLETE_TAG_KEYS_QUERY_MAX_SIZE100
--autocompleteTagValuesQueryMaxSizeThe max size of tags values for autocomplete select.SW_AUTOCOMPLETE_TAG_VALUES_QUERY_MAX_SIZE100
--gRPCThreadPoolSizePool size of gRPC server.SW_CORE_GRPC_THREAD_POOL_SIZEDefault to gRPC's implementation, which is a cached thread pool that can grow infinitely.
--maxConcurrentCallsPerConnectionThe maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit.SW_CORE_GRPC_MAX_CONCURRENT_CALL-
--maxMessageSizeSets the maximum message size allowed to be received on the server. Empty means 4 MiB.SW_CORE_GRPC_MAX_MESSAGE_SIZE52428800 (50MB)
--remoteTimeoutTimeout for cluster internal communication (in seconds).-20
--maxSizeOfNetworkAddressAliasThe maximum size of network address detected in the system being monitored.-1_000_000
--maxPageSizeOfQueryProfileSnapshotThe maximum size for snapshot analysis in an OAP query.-500
--maxSizeOfAnalyzeProfileSnapshotThe maximum number of snapshots analyzed by the OAP.-12000
--prepareThreadsThe number of threads used to prepare metrics data to the storage.SW_CORE_PREPARE_THREADS2
--enableEndpointNameGroupingByOpenapiAutomatically groups endpoints by the given OpenAPI definitions.SW_CORE_ENABLE_ENDPOINT_NAME_GROUPING_BY_OPENAPItrue
--maxDurationOfQueryEBPFProfilingDataThe maximum duration(in second) of query the eBPF profiling data from database.-30
--maxThreadCountOfQueryEBPFProfilingDataThe maximum thread count of query the eBPF profiling data from database.-System CPU core size
--uiMenuRefreshIntervalThe period(in seconds) of refreshing the status of all UI menu items.-20
--serviceCacheRefreshIntervalThe period(in seconds) of refreshing the service cache.SW_SERVICE_CACHE_REFRESH_INTERVAL10
--enableHierarchyIf disable the hierarchy, the service and instance hierarchy relation will not be built. And the query of hierarchy will return empty result. All the hierarchy relations are defined in the hierarchy-definition.yml. Notice: some of the configurations only available for kubernetes environments.SW_CORE_ENABLE_HIERARCHYtrue
--maxHeapMemoryUsagePercentThe int value of the max heap memory usage percent.SW_CORE_MAX_HEAP_MEMORY_USAGE_PERCENT96 (96%)
--maxDirectMemoryUsageThe long value of the max direct memory usage. The default max value is -1, representing no limit. The unit is in bytes.SW_CORE_MAX_DIRECT_MEMORY_USAGE-1
clusterstandalone-Standalone is not suitable for running on a single node running. No configuration available.--
-zookeepernamespaceThe namespace, represented by root path, isolates the configurations in Zookeeper.SW_NAMESPACE/, root path
--hostPortHosts and ports of Zookeeper Cluster.SW_CLUSTER_ZK_HOST_PORTlocalhost:2181
--baseSleepTimeMsThe period of Zookeeper client between two retries (in milliseconds).SW_CLUSTER_ZK_SLEEP_TIME1000
--maxRetriesThe maximum retry time.SW_CLUSTER_ZK_MAX_RETRIES3
--enableACLOpens ACL using schema and expression.SW_ZK_ENABLE_ACLfalse
--schemaSchema for the authorization.SW_ZK_SCHEMAdigest
--expressionExpression for the authorization.SW_ZK_EXPRESSIONskywalking:skywalking
--internalComHostThe hostname registered in Zookeeper for the internal communication of OAP cluster.SW_CLUSTER_INTERNAL_COM_HOST-
--internalComPortThe port registered in Zookeeper for the internal communication of OAP cluster.SW_CLUSTER_INTERNAL_COM_PORT-1
-kubernetesnamespaceNamespace deployed by SkyWalking in k8s.SW_CLUSTER_K8S_NAMESPACEdefault
--labelSelectorLabels used for filtering OAP deployment in k8s.SW_CLUSTER_K8S_LABELapp=collector,release=skywalking
--uidEnvNameEnvironment variable name for reading uid.SW_CLUSTER_K8S_UIDSKYWALKING_COLLECTOR_UID
-consulserviceNameService name for SkyWalking cluster.SW_SERVICE_NAMESkyWalking_OAP_Cluster
--hostPortHosts and ports for Consul cluster.SW_CLUSTER_CONSUL_HOST_PORTlocalhost:8500
--aclTokenACL Token of Consul. Empty string means without ALC token.SW_CLUSTER_CONSUL_ACLTOKEN-
--internalComHostThe hostname registered in Consul for internal communications of the OAP cluster.SW_CLUSTER_INTERNAL_COM_HOST-
--internalComPortThe port registered in Consul for internal communications of the OAP cluster.SW_CLUSTER_INTERNAL_COM_PORT-1
-etcdserviceNameService name for SkyWalking cluster.SW_CLUSTER_ETCD_SERVICE_NAMESkyWalking_OAP_Cluster
--endpointsHosts and ports for etcd cluster.SW_CLUSTER_ETCD_ENDPOINTSlocalhost:2379
--namespaceNamespace for SkyWalking cluster.SW_CLUSTER_ETCD_NAMESPACE/skywalking
--authenticationIndicates whether there is authentication.SW_CLUSTER_ETCD_AUTHENTICATIONfalse
--userEtcd auth username.SW_CLUSTER_ETCD_USER
--passwordEtcd auth password.SW_CLUSTER_ETCD_PASSWORD
--internalComHostThe hostname registered in etcd for internal communications of the OAP cluster.SW_CLUSTER_INTERNAL_COM_HOST-
--internalComPortThe port registered in etcd for internal communications of the OAP cluster.SW_CLUSTER_INTERNAL_COM_PORT-1
-NacosserviceNameService name for SkyWalking cluster.SW_SERVICE_NAMESkyWalking_OAP_Cluster
--hostPortHosts and ports for Nacos cluster.SW_CLUSTER_NACOS_HOST_PORTlocalhost:8848
--namespaceNamespace used by SkyWalking node coordination.SW_CLUSTER_NACOS_NAMESPACEpublic
--internalComHostThe hostname registered in Nacos for internal communications of the OAP cluster.SW_CLUSTER_INTERNAL_COM_HOST-
--internalComPortThe port registered in Nacos for internal communications of the OAP cluster.SW_CLUSTER_INTERNAL_COM_PORT-1
--contextPathNacos set contextPath.SW_CLUSTER_NACOS_CONTEXT_PATH-
--usernameNacos Auth username.SW_CLUSTER_NACOS_USERNAME-
--passwordNacos Auth password.SW_CLUSTER_NACOS_PASSWORD-
--accessKeyNacos Auth accessKey.SW_CLUSTER_NACOS_ACCESSKEY-
--secretKeyNacos Auth secretKey.SW_CLUSTER_NACOS_SECRETKEY-
--syncPeriodHttpUriRecognitionPatternThe period of HTTP URI recognition pattern synchronization (in seconds).SW_CORE_SYNC_PERIOD_HTTP_URI_RECOGNITION_PATTERN10
--trainingPeriodHttpUriRecognitionPatternThe period of HTTP URI recognition pattern training (in seconds).SW_CORE_TRAINING_PERIOD_HTTP_URI_RECOGNITION_PATTERN60
--maxHttpUrisNumberPerServiceThe maximum number of HTTP URIs per service.SW_MAX_HTTP_URIS_NUMBER_PER_SERVICE3000
storageelasticsearch-ElasticSearch (and OpenSearch) storage implementation.--
--namespacePrefix of indexes created and used by SkyWalking.SW_NAMESPACE-
--clusterNodesElasticSearch cluster nodes for client connection.SW_STORAGE_ES_CLUSTER_NODESlocalhost
--protocolHTTP or HTTPs.SW_STORAGE_ES_HTTP_PROTOCOLHTTP
--connectTimeoutConnect timeout of ElasticSearch client (in milliseconds).SW_STORAGE_ES_CONNECT_TIMEOUT3000
--socketTimeoutSocket timeout of ElasticSearch client (in milliseconds).SW_STORAGE_ES_SOCKET_TIMEOUT30000
--responseTimeoutResponse timeout of ElasticSearch client (in milliseconds), 0 disables the timeout.SW_STORAGE_ES_RESPONSE_TIMEOUT15000
--numHttpClientThreadThe number of threads for the underlying HTTP client to perform socket I/O. If the value is <= 0, the number of available processors will be used.SW_STORAGE_ES_NUM_HTTP_CLIENT_THREAD0
--userUsername of ElasticSearch cluster.SW_ES_USER-
--passwordPassword of ElasticSearch cluster.SW_ES_PASSWORD-
--trustStorePathTrust JKS file path. Only works when username and password are enabled.SW_STORAGE_ES_SSL_JKS_PATH-
--trustStorePassTrust JKS file password. Only works when username and password are enabled.SW_STORAGE_ES_SSL_JKS_PASS-
--secretsManagementFileSecrets management file in the properties format, including username and password, which are managed by a 3rd party tool. Capable of being updated them at runtime.SW_ES_SECRETS_MANAGEMENT_FILE-
--dayStepRepresents the number of days in the one-minute/hour/day index.SW_STORAGE_DAY_STEP1
--indexShardsNumberShard number of new indexes.SW_STORAGE_ES_INDEX_SHARDS_NUMBER1
--indexReplicasNumberReplicas number of new indexes.SW_STORAGE_ES_INDEX_REPLICAS_NUMBER0
--specificIndexSettingsSpecify the settings for each index individually. If configured, this setting has the highest priority and overrides the generic settings.SW_STORAGE_ES_SPECIFIC_INDEX_SETTINGS-
--superDatasetDayStepRepresents the number of days in the super size dataset record index. Default value is the same as dayStep when the value is less than 0.SW_STORAGE_ES_SUPER_DATASET_DAY_STEP-1
--superDatasetIndexShardsFactorSuper dataset is defined in the code (e.g. trace segments). This factor provides more shards for the super dataset: shards number = indexShardsNumber * superDatasetIndexShardsFactor. This factor also affects Zipkin and Jaeger traces.SW_STORAGE_ES_SUPER_DATASET_INDEX_SHARDS_FACTOR5
--superDatasetIndexReplicasNumberRepresents the replicas number in the super size dataset record index.SW_STORAGE_ES_SUPER_DATASET_INDEX_REPLICAS_NUMBER0
--indexTemplateOrderThe order of index template.SW_STORAGE_ES_INDEX_TEMPLATE_ORDER0
--bulkActionsAsync bulk size of the record data batch execution.SW_STORAGE_ES_BULK_ACTIONS5000
--batchOfBytesA threshold to control the max body size of ElasticSearch Bulk flush.SW_STORAGE_ES_BATCH_OF_BYTES10485760 (10m)
--flushIntervalPeriod of flush (in seconds). Does not matter whether bulkActions is reached or not.SW_STORAGE_ES_FLUSH_INTERVAL5
--concurrentRequestsThe number of concurrent requests allowed to be executed.SW_STORAGE_ES_CONCURRENT_REQUESTS2
--resultWindowMaxSizeThe maximum size of dataset when the OAP loads cache, such as network aliases.SW_STORAGE_ES_QUERY_MAX_WINDOW_SIZE10000
--metadataQueryMaxSizeThe maximum size of metadata per query.SW_STORAGE_ES_QUERY_MAX_SIZE10000
--scrollingBatchSizeThe batch size of metadata per iteration when metadataQueryMaxSize or resultWindowMaxSize is too large to be retrieved in a single query.SW_STORAGE_ES_SCROLLING_BATCH_SIZE5000
--segmentQueryMaxSizeThe maximum size of trace segments per query.SW_STORAGE_ES_QUERY_SEGMENT_SIZE200
--profileTaskQueryMaxSizeThe maximum size of profile task per query.SW_STORAGE_ES_QUERY_PROFILE_TASK_SIZE200
--asyncProfilerTaskQueryMaxSizeThe maximum size of async-profiler task per query.SW_STORAGE_ES_QUERY_ASYNC_PROFILER_TASK_SIZE200
--profileDataQueryScrollBatchSizeThe batch size of query profiling data.SW_STORAGE_ES_QUERY_PROFILE_DATA_BATCH_SIZE100
--advancedAll settings of ElasticSearch index creation. The value should be in JSON format.SW_STORAGE_ES_ADVANCED-
--logicShardingShard metrics and records indices into multi-physical indices, one index template per metric/meter aggregation function or record.SW_STORAGE_ES_LOGIC_SHARDINGfalse
-mysql-MySQL Storage. The MySQL JDBC Driver is not in the dist. Please copy it into the oap-lib folder manually.--
--propertiesHikari connection pool configurations.-Listed in the application.yaml.
--metadataQueryMaxSizeThe maximum size of metadata per query.SW_STORAGE_MYSQL_QUERY_MAX_SIZE5000
--maxSizeOfBatchSqlThe maximum size of batch size of SQL executionSW_STORAGE_MAX_SIZE_OF_BATCH_SQL2000
--asyncBatchPersistentPoolSizeasync flush data into database thread sizeSW_STORAGE_ASYNC_BATCH_PERSISTENT_POOL_SIZE4
-postgresql-PostgreSQL storage.--
--propertiesHikari connection pool configurations.-Listed in the application.yaml.
--metadataQueryMaxSizeThe maximum size of metadata per query.SW_STORAGE_MYSQL_QUERY_MAX_SIZE5000
--maxSizeOfBatchSqlThe maximum size of batch size of SQL executionSW_STORAGE_MAX_SIZE_OF_BATCH_SQL2000
--asyncBatchPersistentPoolSizeasync flush data into database thread sizeSW_STORAGE_ASYNC_BATCH_PERSISTENT_POOL_SIZE4
-banyandb-BanyanDB storage, since 10.2.0, the banyandb configuration is separated to an independent configuration file: bydb.yaml.--
agent-analyzerdefaultAgent Analyzer.SW_AGENT_ANALYZERdefault
--traceSamplingPolicySettingsFileThe sampling policy including sampling rate and the threshold of trace segment latency can be configured by the traceSamplingPolicySettingsFile file.SW_TRACE_SAMPLING_POLICY_SETTINGS_FILEtrace-sampling-policy-settings.yml
--slowDBAccessThresholdThe slow database access threshold (in milliseconds).SW_SLOW_DB_THRESHOLDdefault:200,mongodb:100
--forceSampleErrorSegmentWhen sampling mechanism is activated, this config samples the error status segment and ignores the sampling rate.SW_FORCE_SAMPLE_ERROR_SEGMENTtrue
--segmentStatusAnalysisStrategyDetermines the final segment status from span status. Available values are FROM_SPAN_STATUS , FROM_ENTRY_SPAN, and FROM_FIRST_SPAN. FROM_SPAN_STATUS indicates that the segment status would be error if any span has an error status. FROM_ENTRY_SPAN means that the segment status would only be determined by the status of entry spans. FROM_FIRST_SPAN means that the segment status would only be determined by the status of the first span.SW_SEGMENT_STATUS_ANALYSIS_STRATEGYFROM_SPAN_STATUS
--noUpstreamRealAddressAgentsExit spans with the component in the list would not generate client-side instance relation metrics, since some tracing plugins (e.g. Nginx-LUA and Envoy) can't collect the real peer IP address.SW_NO_UPSTREAM_REAL_ADDRESS6000,9000
--meterAnalyzerActiveFilesIndicates which files could be instrumented and analyzed. Multiple files are split by “,”.SW_METER_ANALYZER_ACTIVE_FILES
--slowCacheWriteThresholdThe threshold of slow command which is used for writing operation (in milliseconds).SW_SLOW_CACHE_WRITE_THRESHOLDdefault:20,redis:10
--slowCacheReadThresholdThe threshold of slow command which is used for reading (getting) operation (in milliseconds).SW_SLOW_CACHE_READ_THRESHOLDdefault:20,redis:10
receiver-sharing-serverdefaultSharing server provides new gRPC and restful servers for data collection. Ana designates that servers in the core module are to be used for internal communication only.--
--restHostBinding IP of RESTful services. Services include GraphQL query and HTTP data report.SW_RECEIVER_SHARING_REST_HOST-
--restPortBinding port of RESTful services.SW_RECEIVER_SHARING_REST_PORT-
--restContextPathWeb context path of RESTful services.SW_RECEIVER_SHARING_REST_CONTEXT_PATH-
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_RECEIVER_SHARING_REST_IDLE_TIMEOUT30000
--restAcceptQueueSizeServerSocketChannel backlog of RESTful services.SW_RECEIVER_SHARING_REST_QUEUE_SIZE0
--httpMaxRequestHeaderSizeMaximum request header size accepted.SW_RECEIVER_SHARING_HTTP_MAX_REQUEST_HEADER_SIZE8192
--gRPCHostBinding IP of gRPC services. Services include gRPC data report and internal communication among OAP nodes.SW_RECEIVER_GRPC_HOST0.0.0.0. Not Activated
--gRPCPortBinding port of gRPC services.SW_RECEIVER_GRPC_PORTNot Activated
--gRPCThreadPoolSizePool size of gRPC server.SW_RECEIVER_GRPC_THREAD_POOL_SIZEDefault to gRPC's implementation, which is a cached thread pool that can grow infinitely.
--gRPCSslEnabledActivates SSL for gRPC services.SW_RECEIVER_GRPC_SSL_ENABLEDfalse
--gRPCSslKeyPathFile path of gRPC SSL key.SW_RECEIVER_GRPC_SSL_KEY_PATH-
--gRPCSslCertChainPathFile path of gRPC SSL cert chain.SW_RECEIVER_GRPC_SSL_CERT_CHAIN_PATH-
--maxConcurrentCallsPerConnectionThe maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit.SW_RECEIVER_GRPC_MAX_CONCURRENT_CALL-
--maxMessageSizeSets the maximum message size allowed to be received on the server. Empty means 4 MiB.SW_RECEIVER_GRPC_MAX_MESSAGE_SIZE52428800 (50MB)
--authenticationThe token text for authentication. Works for gRPC connection only. Once this is set, the client is required to use the same token.SW_AUTHENTICATION-
log-analyzerdefaultLog Analyzer.SW_LOG_ANALYZERdefault
--lalFilesThe LAL configuration file names (without file extension) to be activated. Read LAL for more details.SW_LOG_LAL_FILESdefault
--malFilesThe MAL configuration file names (without file extension) to be activated. Read LAL for more details.SW_LOG_MAL_FILES""
event-analyzerdefaultEvent Analyzer.SW_EVENT_ANALYZERdefault
receiver-registerdefaultgRPC and HTTPRestful services that provide service, service instance and endpoint register.--
receiver-tracedefaultgRPC and HTTPRestful services that accept SkyWalking format traces.--
receiver-jvmdefaultgRPC services that accept JVM metrics data.--
receiver-clrdefaultgRPC services that accept .Net CLR metrics data.--
receiver-profiledefaultgRPC services that accept profile task status and snapshot reporter.--
receiver-zabbixdefaultTCP receiver accepts Zabbix format metrics.--
--portExported TCP port. Zabbix agent could connect and transport data.SW_RECEIVER_ZABBIX_PORT10051
--hostBinds to host.SW_RECEIVER_ZABBIX_HOST0.0.0.0
--activeFilesEnables config when agent request is received.SW_RECEIVER_ZABBIX_ACTIVE_FILESagent
service-meshdefaultgRPC services that accept data from inbound mesh probes.--
envoy-metricdefaultEnvoy metrics_service and ALS(access log service) are supported by this receiver. The OAL script supports all GAUGE type metrics.--
--acceptMetricsServiceStarts Envoy Metrics Service analysis.SW_ENVOY_METRIC_SERVICEtrue
--alsHTTPAnalysisStarts Envoy HTTP Access Log Service analysis. Value = k8s-mesh means starting the analysis.SW_ENVOY_METRIC_ALS_HTTP_ANALYSIS-
--alsTCPAnalysisStarts Envoy TCP Access Log Service analysis. Value = k8s-mesh means starting the analysis.SW_ENVOY_METRIC_ALS_TCP_ANALYSIS-
--k8sServiceNameRulek8sServiceNameRule allows you to customize the service name in ALS via Kubernetes metadata. The available variables are pod and service. E.g. you can use ${service.metadata.name}-${pod.metadata.labels.version} to append the version number to the service name. Note that when using environment variables to pass this configuration, use single quotes('') to avoid being evaluated by the shell.K8S_SERVICE_NAME_RULE${pod.metadata.labels.(service.istio.io/canonical-name)}.${pod.metadata.namespace}
--istioServiceNameRuleistioServiceNameRule allows you to customize the service name in ALS via Kubernetes metadata. The available variables are serviceEntry. E.g. you can use ${serviceEntry.metadata.name}-${serviceEntry.metadata.labels.version} to append the version number to the service name. Note that when using environment variables to pass this configuration, use single quotes('') to avoid being evaluated by the shell.ISTIO_SERVICE_NAME_RULE${serviceEntry.metadata.name}.${serviceEntry.metadata.namespace}
--istioServiceEntryIgnoredNamespacesWhen looking up service informations from the Istio ServiceEntries, some of the ServiceEntries might be created in several namespaces automatically by some components, and OAP will randomly pick one of them to build the service name, users can use this config to exclude ServiceEntries that they don't want to be used. Comma separated.SW_ISTIO_SERVICE_ENTRY_IGNORED_NAMESPACES-
--gRPCHostBinding IP of gRPC service for Envoy access log service.SW_ALS_GRPC_HOST0.0.0.0. Not Activated
--gRPCPortBinding port of gRPC service for Envoy access log service.SW_ALS_GRPC_PORTNot Activated
--gRPCThreadPoolSizePool size of gRPC server.SW_ALS_GRPC_THREAD_POOL_SIZEDefault to gRPC's implementation, which is a cached thread pool that can grow infinitely.
--gRPCSslEnabledActivates SSL for gRPC services.SW_ALS_GRPC_SSL_ENABLEDfalse
--gRPCSslKeyPathFile path of gRPC SSL key.SW_ALS_GRPC_SSL_KEY_PATH-
--gRPCSslCertChainPathFile path of gRPC SSL cert chain.SW_ALS_GRPC_SSL_CERT_CHAIN_PATH-
--maxConcurrentCallsPerConnectionThe maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit.SW_ALS_GRPC_MAX_CONCURRENT_CALL-
--maxMessageSizeSets the maximum message size allowed to be received on the server. Empty means 4 MiB.SW_ALS_GRPC_MAX_MESSAGE_SIZE4M(based on Netty)
receiver-oteldefaultA receiver for analyzing metrics data from OpenTelemetry.--
--enabledHandlersEnabled handlers for otel.SW_OTEL_RECEIVER_ENABLED_HANDLERS-
--enabledOtelMetricsRulesEnabled metric rules for OTLP handler.SW_OTEL_RECEIVER_ENABLED_OTEL_METRICS_RULES-
receiver-zipkindefaultA receiver for Zipkin traces.--
--sampleRateThe sample rate precision is 1/10000, should be between 0 and 10000SW_ZIPKIN_SAMPLE_RATE10000
--maxSpansPerSecondThe maximum spans to be collected per second. 0 means no limit. Spans exceeding this threshold will be dropped.SW_ZIPKIN_MAX_SPANS_PER_SECOND0
--searchableTracesTagsDefines a set of span tag keys which are searchable. Multiple values are separated by commas. The max length of key=value should be less than 256 or will be dropped.SW_ZIPKIN_SEARCHABLE_TAG_KEYShttp.method
--enableHttpCollectorEnable Http Collector.SW_ZIPKIN_HTTP_COLLECTOR_ENABLEDtrue
--restHostBinding IP of RESTful services.SW_RECEIVER_ZIPKIN_REST_HOST0.0.0.0
--restPortBinding port of RESTful services.SW_RECEIVER_ZIPKIN_REST_PORT9411
--restContextPathWeb context path of RESTful services.SW_RECEIVER_ZIPKIN_REST_CONTEXT_PATH/
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_RECEIVER_ZIPKIN_REST_IDLE_TIMEOUT30000
--restAcceptQueueSizeMaximum request header size accepted.SW_RECEIVER_ZIPKIN_REST_QUEUE_SIZE0
--enableKafkaCollectorEnable Kafka Collector.SW_ZIPKIN_KAFKA_COLLECTOR_ENABLEDfalse
--kafkaBootstrapServersKafka ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG.SW_ZIPKIN_KAFKA_SERVERSlocalhost:9092
--kafkaGroupIdKafka ConsumerConfig.GROUP_ID_CONFIG.SW_ZIPKIN_KAFKA_GROUP_IDzipkin
--kafkaTopicKafka Topics.SW_ZIPKIN_KAFKA_TOPICzipkin
--kafkaConsumerConfigKafka consumer config, JSON format as Properties. If it contains the same key with above, would override.SW_ZIPKIN_KAFKA_CONSUMER_CONFIG“{"auto.offset.reset":"earliest","enable.auto.commit":true}”
--kafkaConsumersThe number of consumers to create.SW_ZIPKIN_KAFKA_CONSUMERS1
--kafkaHandlerThreadPoolSizePool size of Kafka message handler executor.SW_ZIPKIN_KAFKA_HANDLER_THREAD_POOL_SIZECPU core * 2
--kafkaHandlerThreadPoolQueueSizeQueue size of Kafka message handler executor.SW_ZIPKIN_KAFKA_HANDLER_THREAD_POOL_QUEUE_SIZE10000
kafka-fetcherdefaultRead SkyWalking's native metrics/logs/traces through Kafka server.--
--bootstrapServersA list of host/port pairs to use for establishing the initial connection to the Kafka cluster.SW_KAFKA_FETCHER_SERVERSlocalhost:9092
--namespaceNamespace aims to isolate multi OAP cluster when using the same Kafka cluster. If you set a namespace for Kafka fetcher, OAP will add a prefix to topic name. You should also set namespace in agent.config. The property is named plugin.kafka.namespace.SW_NAMESPACE-
--groupIdA unique string that identifies the consumer group to which this consumer belongs.-skywalking-consumer
--partitionsThe number of partitions for the topic being created.SW_KAFKA_FETCHER_PARTITIONS3
--consumersThe number of consumers to create.SW_KAFKA_FETCHER_CONSUMERS1
--enableNativeProtoLogEnables fetching and handling native proto log data.SW_KAFKA_FETCHER_ENABLE_NATIVE_PROTO_LOGtrue
--enableNativeJsonLogEnables fetching and handling native json log data.SW_KAFKA_FETCHER_ENABLE_NATIVE_JSON_LOGtrue
--replicationFactorThe replication factor for each partition in the topic being created.SW_KAFKA_FETCHER_PARTITIONS_FACTOR2
--kafkaHandlerThreadPoolSizePool size of Kafka message handler executor.SW_KAFKA_HANDLER_THREAD_POOL_SIZECPU core * 2
--kafkaHandlerThreadPoolQueueSizeQueue size of Kafka message handler executor.SW_KAFKA_HANDLER_THREAD_POOL_QUEUE_SIZE10000
--topicNameOfMetersKafka topic name for meter system data.-skywalking-meters
--topicNameOfMetricsKafka topic name for JVM metrics data.-skywalking-metrics
--topicNameOfProfilingKafka topic name for profiling data.-skywalking-profilings
--topicNameOfTracingSegmentsKafka topic name for tracing data.-skywalking-segments
--topicNameOfManagementsKafka topic name for service instance reporting and registration.-skywalking-managements
--topicNameOfLogsKafka topic name for native proto log data.-skywalking-logs
--topicNameOfJsonLogsKafka topic name for native json log data.-skywalking-logs-json
cilium-fetcherdefaultRead Cilium Observe protocol data to collect Cilium Service status.--
--peerHostThe Cilium Peer Service Host.SW_CILIUM_FETCHER_PEER_HOSThubble-peer.kube-system.svc.cluster.local
--peerPortThe Cilium Peer Service Port.SW_CILIUM_FETCHER_PEER_PORT80
--fetchFailureRetrySecondThe Cilium fetch observe data failure retry interval(second).SW_CILIUM_FETCHER_FETCH_FAILURE_RETRY_SECOND10
--sslConnectionThe Cilium fetch protocol is TLS enabled or not.eSW_CILIUM_FETCHER_SSL_CONNECTIONfalse
--sslPrivateKeyFileThe Cilium TLS fetch private key file path.SW_CILIUM_FETCHER_PRIVATE_KEY_FILE_PATH""
--sslCertChainFileThe Cilium TLS fetch cert chain file path.SW_CILIUM_FETCHER_CERT_CHAIN_FILE_PATH""
--sslCaFileThe Cilium TLS fetch rot CA Certification file path.SW_CILIUM_FETCHER_CA_FILE_PATH""
--convertClientAsServerTrafficThe Cilium flow data should convert client to the server side not. If convert, then the server side flow would be ignored.SW_CILIUM_FETCHER_CONVERT_CLIENT_AS_SERVER_TRAFFICtrue
receiver-browserdefaultgRPC services that accept browser performance data and error log.---
--sampleRateSampling rate for receiving trace. Precise to 1/10000. 10000 means sampling rate of 100% by default.SW_RECEIVER_BROWSER_SAMPLE_RATE10000
querygraphql-GraphQL query implementation.-
--enableLogTestToolEnable the log testing API to test the LAL. NOTE: This API evaluates untrusted code on the OAP server. A malicious script can do significant damage (steal keys and secrets, remove files and directories, install malware, etc). As such, please enable this API only when you completely trust your users.SW_QUERY_GRAPHQL_ENABLE_LOG_TEST_TOOLfalse
--maxQueryComplexityMaximum complexity allowed for the GraphQL query that can be used to abort a query if the total number of data fields queried exceeds the defined threshold.SW_QUERY_MAX_QUERY_COMPLEXITY3000
--enableUpdateUITemplateAllow user add,disable and update UI template.SW_ENABLE_UPDATE_UI_TEMPLATEfalse
--enableOnDemandPodLogOndemand Pod log: fetch the Pod logs on users' demand, the logs are fetched and displayed in real time, and are not persisted in any kind. This is helpful when users want to do some experiments and monitor the logs and see what's happing inside the service. Note: if you print secrets in the logs, they are also visible to the UI, so for the sake of security, this feature is disabled by default, please set this configuration to enable the feature manually.SW_ENABLE_ON_DEMAND_POD_LOGfalse
query-zipkindefault-This module is for Zipkin query API and support zipkin-lens UI-
--restHostBinding IP of RESTful services.SW_QUERY_ZIPKIN_REST_HOST0.0.0.0
--restPortBinding port of RESTful services.SW_QUERY_ZIPKIN_REST_PORT9412
--restContextPathWeb context path of RESTful services.SW_QUERY_ZIPKIN_REST_CONTEXT_PATHzipkin
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_QUERY_ZIPKIN_REST_IDLE_TIMEOUT30000
--restAcceptQueueSizeMaximum request header size accepted.SW_QUERY_ZIPKIN_REST_QUEUE_SIZE0
--lookbackDefault look back for traces and autocompleteTags, 1 day in millisSW_QUERY_ZIPKIN_LOOKBACK86400000
--namesMaxAgeThe Cache-Control max-age (seconds) for serviceNames, remoteServiceNames and spanNamesSW_QUERY_ZIPKIN_NAMES_MAX_AGE300
--uiQueryLimitDefault traces query max sizeSW_QUERY_ZIPKIN_UI_QUERY_LIMIT10
--uiDefaultLookbackDefault look back on the UI for search traces, 15 minutes in millisSW_QUERY_ZIPKIN_UI_DEFAULT_LOOKBACK900000
promqldefault-This module is for PromQL API.-
--restHostBinding IP of RESTful services.SW_PROMQL_REST_HOST0.0.0.0
--restPortBinding port of RESTful services.SW_PROMQL_REST_PORT9090
--restContextPathWeb context path of RESTful services.SW_PROMQL_REST_CONTEXT_PATH/
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_PROMQL_REST_IDLE_TIMEOUT30000
--restAcceptQueueSizeMaximum request header size accepted.SW_PROMQL_REST_QUEUE_SIZE0
--buildInfoVersionMock version for API buildInfoSW_PROMQL_BUILD_INFO_VERSION2.45.0
--buildInfoRevisionMock revision for API buildInfoSW_PROMQL_BUILD_INFO_REVISION
--buildInfoBranchMock branch for API buildInfoSW_PROMQL_BUILD_INFO_BRANCH
--buildInfoBuildUserMock build user for API buildInfoSW_PROMQL_BUILD_INFO_BUILD_USER
--buildInfoBuildDateMock build date for API buildInfoSW_PROMQL_BUILD_INFO_BUILD_DATE
--buildInfoGoVersionMock go version for API buildInfoSW_PROMQL_BUILD_INFO_GO_VERSION
alarmdefault-Read alarm doc for more details.-
telemetry--Read telemetry doc for more details.-
-none-No op implementation.-
-prometheushostBinding host for Prometheus server fetching data.SW_TELEMETRY_PROMETHEUS_HOST0.0.0.0
--portBinding port for Prometheus server fetching data.SW_TELEMETRY_PROMETHEUS_PORT1234
configuration--Read dynamic configuration doc for more details.-
-grpchostDCS server binding hostname.SW_DCS_SERVER_HOST-
--portDCS server binding port.SW_DCS_SERVER_PORT80
--clusterNameCluster name when reading the latest configuration from DSC server.SW_DCS_CLUSTER_NAMESkyWalking
--periodThe period of reading data from DSC server by the OAP (in seconds).SW_DCS_PERIOD20
--maxInboundMessageSizeThe max inbound message size of gRPC.SW_DCS_MAX_INBOUND_MESSAGE_SIZE4194304
-apolloapolloMetaapollo.meta in Apollo.SW_CONFIG_APOLLOhttp://localhost:8080
--apolloClusterapollo.cluster in Apollo.SW_CONFIG_APOLLO_CLUSTERdefault
--apolloEnvenv in Apollo.SW_CONFIG_APOLLO_ENV-
--appIdapp.id in Apollo.SW_CONFIG_APOLLO_APP_IDskywalking
-zookeepernamespaceThe namespace (represented by root path) that isolates the configurations in the Zookeeper.SW_CONFIG_ZK_NAMESPACE/, root path
--hostPortHosts and ports of Zookeeper Cluster.SW_CONFIG_ZK_HOST_PORTlocalhost:2181
--baseSleepTimeMsThe period of Zookeeper client between two retries (in milliseconds).SW_CONFIG_ZK_BASE_SLEEP_TIME_MS1000
--maxRetriesThe maximum retry time.SW_CONFIG_ZK_MAX_RETRIES3
--periodThe period of data sync (in seconds).SW_CONFIG_ZK_PERIOD60
-etcdendpointsHosts and ports for etcd cluster (separated by commas if multiple).SW_CONFIG_ETCD_ENDPOINTShttp://localhost:2379
--namespaceNamespace for SkyWalking cluster.SW_CONFIG_ETCD_NAMESPACE/skywalking
--authenticationIndicates whether there is authentication.SW_CONFIG_ETCD_AUTHENTICATIONfalse
--userEtcd auth username.SW_CONFIG_ETCD_USER
--passwordEtcd auth password.SW_CONFIG_ETCD_PASSWORD
--periodThe period of data sync (in seconds).SW_CONFIG_ZK_PERIOD60
-consulhostPortHosts and ports for Consul cluster.SW_CONFIG_CONSUL_HOST_AND_PORTSlocalhost:8500
--aclTokenACL Token of Consul. Empty string means without ACL token.SW_CONFIG_CONSUL_ACL_TOKEN-
--periodThe period of data sync (in seconds).SW_CONFIG_CONSUL_PERIOD60
-k8s-configmapnamespaceDeployment namespace of the config map.SW_CLUSTER_K8S_NAMESPACEdefault
--labelSelectorLabels for locating configmap.SW_CLUSTER_K8S_LABELapp=collector,release=skywalking
--periodThe period of data sync (in seconds).SW_CONFIG_ZK_PERIOD60
-nacosserverAddrNacos Server Host.SW_CONFIG_NACOS_SERVER_ADDR127.0.0.1
--portNacos Server Port.SW_CONFIG_NACOS_SERVER_PORT8848
--groupNacos Configuration namespace.SW_CONFIG_NACOS_SERVER_NAMESPACE-
--periodThe period of data sync (in seconds).SW_CONFIG_CONFIG_NACOS_PERIOD60
--usernameNacos Auth username.SW_CONFIG_NACOS_USERNAME-
--passwordNacos Auth password.SW_CONFIG_NACOS_PASSWORD-
--accessKeyNacos Auth accessKey.SW_CONFIG_NACOS_ACCESSKEY-
--secretKeyNacos Auth secretKey.SW_CONFIG_NACOS_SECRETKEY-
exporterdefaultenableGRPCMetricsEnable gRPC metrics exporter.SW_EXPORTER_ENABLE_GRPC_METRICSfalse
--gRPCTargetHostThe host of target gRPC server for receiving export dataSW_EXPORTER_GRPC_HOST127.0.0.1
--gRPCTargetPortThe port of target gRPC server for receiving export data.SW_EXPORTER_GRPC_PORT9870
--enableKafkaTraceEnable Kafka trace exporter.SW_EXPORTER_ENABLE_KAFKA_TRACEfalse
--enableKafkaLogEnable Kafka log exporter.SW_EXPORTER_ENABLE_KAFKA_LOGfalse
--kafkaBootstrapServersA list of host/port pairs to use for establishing the initial connection to the Kafka cluster.SW_EXPORTER_KAFKA_SERVERSlocalhost:9092
--kafkaProducerConfigKafka producer config, JSON format as Properties.SW_EXPORTER_KAFKA_PRODUCER_CONFIG-
--kafkaTopicTraceKafka topic name for trace.SW_EXPORTER_KAFKA_TOPIC_TRACEskywalking-export-trace
--kafkaTopicLogKafka topic name for log.SW_EXPORTER_KAFKA_TOPIC_LOGskywalking-export-log
--exportErrorStatusTraceOnlyExport error status trace segments through the Kafka channel.SW_EXPORTER_KAFKA_TRACE_FILTER_ERRORfalse
health-checkerdefaultcheckIntervalSecondsThe period of checking OAP internal health status (in seconds).SW_HEALTH_CHECKER_INTERVAL_SECONDS5
status-querydefault
--keywords4MaskingSecretsOfConfigInclude the list of keywords to filter configurations including secrets. Separate keywords by a comma.SW_DEBUGGING_QUERY_KEYWORDS_FOR_MASKING_SECRETSuser,password,token,accessKey,secretKey,authentication
configuration-discoverydefaultdisableMessageDigestIf true, agent receives the latest configuration every time, even without making any changes. By default, OAP uses the SHA512 message digest mechanism to detect changes in configuration.SW_DISABLE_MESSAGE_DIGESTfalse
receiver-eventdefaultgRPC services that handle events data.--
aws-firehose-receiverdefaulthostBinding IP of HTTP serverSW_RECEIVER_AWS_FIREHOSE_HTTP_HOST0.0.0.0
--portBinding port of HTTP serverSW_RECEIVER_AWS_FIREHOSE_HTTP_PORT12801
--contextPathContext path of HTTP serverSW_RECEIVER_AWS_FIREHOSE_HTTP_CONTEXT_PATH/
--idleTimeOutIdle timeout of a connection for keep-alive.SW_RECEIVER_AWS_FIREHOSE_HTTP_IDLE_TIME_OUT30000
--acceptQueueSizeMaximum allowed number of open connectionsSW_RECEIVER_AWS_FIREHOSE_HTTP_ACCEPT_QUEUE_SIZE0
--maxRequestHeaderSizeMaximum length of all headers in an HTTP/1 responseSW_RECEIVER_AWS_FIREHOSE_HTTP_MAX_REQUEST_HEADER_SIZE8192
--firehoseAccessKeyThe AccessKey of AWS firhoseSW_RECEIVER_AWS_FIREHOSE_ACCESS_KEY
--enableTLSIndicate if enable HTTPS for the serverSW_RECEIVER_AWS_FIREHOSE_HTTP_ENABLE_TLSfalse
--tlsKeyPathTLS key pathSW_RECEIVER_AWS_FIREHOSE_HTTP_TLS_KEY_PATH
--tlsCertChainPathTLS certificate chain pathSW_RECEIVER_AWS_FIREHOSE_HTTP_TLS_CERT_CHAIN_PATH
ai-pipelinedefault
--uriRecognitionServerAddrThe address of the URI recognition server.SW_AI_PIPELINE_URI_RECOGNITION_SERVER_ADDR-
--uriRecognitionServerPortThe port of the URI recognition server.SW_AI_PIPELINE_URI_RECOGNITION_SERVER_PORT17128
--baselineServerAddrThe address of the Baseline server.SW_API_PIPELINE_BASELINE_SERVICE_HOST-
--baselineServerPortThe port of the Baseline server.SW_API_PIPELINE_BASELINE_SERVICE_PORT17128
receiver-async-profilerdefaultgRPC services that accept async-profiler task status and data reporter.--
--jfrMaxSizeUsed to manage the maximum size of the jfr file that can be received, the unit is Byte, default is 30M.SW_RECEIVER_ASYNC_PROFILER_JFR_MAX_SIZE31457280
--memoryParserEnabledUsed to determine whether to receive jfr in memory file or physical file mode.SW_RECEIVER_ASYNC_PROFILER_MEMORY_PARSER_ENABLEDtrue

BanyanDB Configuration

Since 10.2.0, the banyandb configuration is separated to an independent configuration file: bydb.yaml. The following table lists the configuration items:

Global Configuration

The global settings for the whole BanyanDB:

SettingsValue(s) and ExplanationSystem Environment Variable¹Default
targetsHosts with ports of the BanyanDB.SW_STORAGE_BANYANDB_TARGETS127.0.0.1:17912
maxBulkSizeThe maximum size of write entities in a single batch write call.SW_STORAGE_BANYANDB_MAX_BULK_SIZE10000
flushIntervalPeriod of flush interval. In the timeunit of seconds.SW_STORAGE_BANYANDB_FLUSH_INTERVAL15
flushTimeoutThe timeout seconds of a bulk flush.SW_STORAGE_BANYANDB_FLUSH_TIMEOUT10
concurrentWriteThreadsConcurrent consumer threads for batch writing.SW_STORAGE_BANYANDB_CONCURRENT_WRITE_THREADS15
profileTaskQueryMaxSizeMax size of ProfileTask to be fetched.SW_STORAGE_BANYANDB_PROFILE_TASK_QUERY_MAX_SIZE200
resultWindowMaxSizeThe maximum size of dataset when the OAP loads cache, such as network aliases.SW_STORAGE_BANYAND_QUERY_MAX_WINDOW_SIZE10000
metadataQueryMaxSizeThe maximum size of metadata per query.SW_STORAGE_BANYAND_QUERY_MAX_SIZE10000
segmentQueryMaxSizeThe maximum size of trace segments per query.SW_STORAGE_BANYAND_QUERY_SEGMENT_SIZE200
asyncProfilerTaskQueryMaxSizeMax size of AsyncProfilerTask to be fetched.SW_STORAGE_BANYANDB_ASYNC_PROFILER_TASK_QUERY_MAX_SIZE200
profileDataQueryScrollBatchSizeThe batch size of query profiling data.SW_STORAGE_BANYAND_QUERY_PROFILE_DATA_BATCH_SIZE100
userThe username for BanyanDB authentication.SW_STORAGE_BANYANDB_USER-
passwordThe password for BanyanDB authentication.SW_STORAGE_BANYANDB_PASSWORD-
sslTrustCAPathIf the BanyanDB server is configured with TLS, config the TLS cert file path and open tls connection.SW_STORAGE_BANYANDB_SSL_TRUST_CA_PATH-
cleanupUnusedTopNRulesCleanup TopN rules in BanyanDB server that are not configured in the bydb-topn.yml config.SW_STORAGE_BANYANDB_CLEANUP_UNUSED_TOPN_RULEStrue

Group Configuration

The settings for each group: The hot stage is enabled by default for all groups. If the warm stage is enabled, the data will be moved to the warm stage after the TTL of the hot stage. If the cold stage is enabled and warm stage is disabled, the data will be moved to the cold stage after the TTL of the hot stage. If both warm and cold stages are enabled, the data will be moved to the warm stage after the TTL of the hot stage, and then to the cold stage after the TTL of the warm stage. OAP will query the data from the “hot and warm” stage by default if the “warm” stage is enabled.

GroupSettingsStage SettingsValue(s) and ExplanationSystem Environment Variable¹Default
records--The group for records not specified. Each normal dataset will be grouped under a single group named records.--
-shardNum-Shards Number for normal records group.SW_STORAGE_BANYANDB_RECORDS_SHARD_NUM1
-segmentInterval-Segment Interval Days for normal records group.SW_STORAGE_BANYANDB_RECORDS_SI_DAYS1
-ttl-TTL Days for normal records group.SW_STORAGE_BANYANDB_RECORDS_TTL_DAYS3
-replicas-Replicas for normal records group.SW_STORAGE_BANYANDB_RECORDS_REPLICAS0
-enableWarmStage-Activate warm stage for normal records group.SW_STORAGE_BANYANDB_RECORDS_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage for normal records group.SW_STORAGE_BANYANDB_RECORDS_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_RECORDS_WARM_SHARD_NUM1
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_RECORDS_WARM_SI_DAYS2
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_RECORDS_WARM_TTL_DAYS7
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_RECORDS_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_RECORDS_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_RECORDS_COLD_SHARD_NUM1
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_RECORDS_COLD_SI_DAYS3
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_RECORDS_COLD_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_RECORDS_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_RECORDS_COLD_NODE_SELECTORtype=cold
recordsTrace----
-shardNum-Shards Number for SkyWalking trace records group.SW_STORAGE_BANYANDB_TRACE_SHARD_NUM2
-segmentInterval-Segment Interval Days.SW_STORAGE_BANYANDB_TRACE_SI_DAYS1
-ttl-TTL Days.SW_STORAGE_BANYANDB_TRACE_TTL_DAYS3
-replicas-Replicas for SkyWalking trace records group.SW_STORAGE_BANYANDB_TRACE_REPLICAS0
-enableWarmStage-Activate warm stage.SW_STORAGE_BANYANDB_TRACE_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage.SW_STORAGE_BANYANDB_TRACE_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_TRACE_WARM_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_TRACE_WARM_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_TRACE_WARM_TTL_DAYS7
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_TRACE_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_TRACE_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_TRACE_COLD_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_TRACE_COLD_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_TRACE_COLD_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_TRACE_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_TRACE_COLD_NODE_SELECTORtype=cold
recordsZipkinTrace----
-shardNum-Shards Number for Zipkin trace records group.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_SHARD_NUM2
-segmentInterval-Segment Interval Days.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_SI_DAYS1
-ttl-TTL Days.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_TTL_DAYS3
-replicas-Replicas for Zipkin trace records group.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_REPLICAS0
-enableWarmStage-Activate warm stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_WARM_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_WARM_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_WARM_TTL_DAYS7
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_COLD_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_COLD_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_COLD_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_ZIPKIN_TRACE_COLD_NODE_SELECTORtype=cold
recordsLog----
-shardNum-Shards Number.SW_STORAGE_BANYANDB_LOG_SHARD_NUM2
-segmentInterval-Segment Interval Days.SW_STORAGE_BANYANDB_LOG_SI_DAYS1
-ttl-TTL Days.SW_STORAGE_BANYANDB_LOG_TTL_DAYS3
-replicas-Replicas for Log records group.SW_STORAGE_BANYANDB_LOG_REPLICAS0
-enableWarmStage-Activate warm stage.SW_STORAGE_BANYANDB_LOG_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage.SW_STORAGE_BANYANDB_LOG_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_LOG_WARM_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_LOG_WARM_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_LOG_WARM_TTL_DAYS7
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_LOG_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_LOG_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_LOG_COLD_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_LOG_COLD_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_LOG_COLD_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_LOG_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_LOG_COLD_NODE_SELECTORtype=cold
recordsBrowserErrorLog----
-shardNum-Shards Number.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_SHARD_NUM2
-segmentInterval-Segment Interval Days.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_SI_DAYS1
-ttl-TTL Days.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_TTL_DAYS3
-replicas-Replicas for Browser Error Log records group.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_REPLICAS0
-enableWarmStage-Activate warm stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_WARM_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_WARM_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_WARM_TTL_DAYS7
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_COLD_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_COLD_SI_DAYS1
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_COLD_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_BROWSER_ERROR_LOG_COLD_NODE_SELECTORtype=cold
metricsMinute--The group for minute granularity metrics group.--
-shardNum-Shards Number for minute granularity metrics group.SW_STORAGE_BANYANDB_METRICS_MINUTE_SHARD_NUM2
-segmentInterval-Segment Interval Days for minute granularity metrics group.SW_STORAGE_BANYANDB_METRICS_MINUTE_SI_DAYS1
-ttl-TTL Days for minute granularity metrics group.SW_STORAGE_BANYANDB_METRICS_MINUTE_TTL_DAYS7
-replicas-Replicas for minute granularity metrics group.SW_STORAGE_BANYANDB_METRICS_MINUTE_REPLICAS0
-enableWarmStage-Activate warm stage for minute granularity metrics group.SW_STORAGE_BANYANDB_METRICS_MINUTE_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage for minute granularity metrics group.SW_STORAGE_BANYANDB_METRICS_MINUTE_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_WARM_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_WARM_SI_DAYS3
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_WARM_TTL_DAYS15
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_COLD_SHARD_NUM2
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_COLD_SI_DAYS5
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_COLD_TTL_DAYS60
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_METRICS_MINUTE_COLD_NODE_SELECTORtype=cold
metricsHour--The group for hour granularity metrics.--
-shardNum-Shards Number for hour granularity metrics group.SW_STORAGE_BANYANDB_METRICS_HOUR_SHARD_NUM1
-segmentInterval-Segment Interval Days for hour granularity metrics group.SW_STORAGE_BANYANDB_METRICS_HOUR_SI_DAYS5
-ttl-TTL Days for hour granularity metrics group.SW_STORAGE_BANYANDB_METRICS_HOUR_TTL_DAYS15
-enableWarmStage-Activate warm stage for hour granularity metrics group.SW_STORAGE_BANYANDB_METRICS_HOUR_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage for hour granularity metrics group.SW_STORAGE_BANYANDB_METRICS_HOUR_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_WARM_SHARD_NUM1
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_WARM_SI_DAYS7
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_WARM_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_COLD_SHARD_NUM1
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_COLD_SI_DAYS15
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_COLD_TTL_DAYS120
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_METRICS_HOUR_COLD_NODE_SELECTORtype=cold
metricsDay--The group for day granularity metrics.--
-shardNum-Shards Number for day granularity metrics group.SW_STORAGE_BANYANDB_METRICS_DAY_SHARD_NUM1
-segmentInterval-Segment Interval Days for day granularity metrics group.SW_STORAGE_BANYANDB_METRICS_DAY_SI_DAYS15
-ttl-TTL Days for day granularity metrics group.SW_STORAGE_BANYANDB_METRICS_DAY_TTL_DAYS15
-replicas-Replicas for day granularity metrics group.SW_STORAGE_BANYANDB_METRICS_DAY_REPLICAS0
-enableWarmStage-Activate warm stage for day granularity metrics group.SW_STORAGE_BANYANDB_METRICS_DAY_ENABLE_WARM_STAGEfalse
-enableColdStage-Activate cold stage for day granularity metrics group.SW_STORAGE_BANYANDB_METRICS_DAY_ENABLE_COLD_STAGEfalse
-warm-The warm stage settings.--
--shardNumShards Number for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_WARM_SHARD_NUM1
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_WARM_SI_DAYS15
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_WARM_TTL_DAYS30
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_WARM_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_WARM_NODE_SELECTORtype=warm
-cold-The cold stage settings.--
--shardNumShards Number for for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_COLD_SHARD_NUM1
--segmentIntervalSegment Interval Days for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_COLD_SI_DAYS15
--ttlTTL Days for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_COLD_TTL_DAYS120
--replicasReplicas for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_COLD_REPLICAS0
--nodeSelectorSpecifying target nodes for this stage.SW_STORAGE_BANYANDB_METRICS_DAY_COLD_NODE_SELECTORtype=cold
metadata--The metadata group is designed to store metrics that are used for indexing without value columns. Such as service_traffic, network_address_alias, etc. Since BanyanDB 0.8.0.--
-shardNum-Shards Number for metadata index group.SW_STORAGE_BANYANDB_METADATA_SHARD_NUM2
-segmentInterval-Segment Interval Days for metadata index group.SW_STORAGE_BANYANDB_METADATA_SI_DAYS15
-ttl-TTL Days for metadata index group.SW_STORAGE_BANYANDB_METADATA_TTL_DAYS15
-replicas-Replicas for metadata index group.SW_STORAGE_BANYANDB_METADATA_REPLICAS0
property--The group settings of property, such as UI and profiling.--
-shardNum-Shards Number for property group.SW_STORAGE_BANYANDB_PROPERTY_SHARD_NUM1
-replicas-Replicas for property group.SW_STORAGE_BANYANDB_PROPERTY_REPLICAS0

Note

¹ System Environment Variable name could be declared and changed in application.yml/bydb.yaml. The names listed here are simply provided in the default application.yml/bydb.yaml file.