Configuration Vocabulary

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

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/
--restMinThreadsMinimum thread number of RESTful services.SW_CORE_REST_JETTY_MIN_THREADS1
--restMaxThreadsMaximum thread number of RESTful services.SW_CORE_REST_JETTY_MAX_THREADS200
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_CORE_REST_JETTY_IDLE_TIMEOUT30000
--restAcceptorPriorityDeltaThread priority delta to give to acceptor threads of RESTful services.SW_CORE_REST_JETTY_DELTA0
--restAcceptQueueSizeServerSocketChannel Backlog of RESTful services.SW_CORE_REST_JETTY_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
--persistentPeriodExecution period of the persistent timer (in seconds).25
--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
--enableDatabaseSessionCache metrics data for 1 minute to reduce database queries, and if the OAP cluster changes within that minute.SW_CORE_ENABLE_DATABASE_SESSIONtrue
--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.SW_SEARCHABLE_TAG_KEYShttp.method,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.SW_SEARCHABLE_LOGS_TAG_KEYSlevel
--searchableAlarmTagsDefines a set of alarm tag keys which are searchable through GraphQL. Multiple values are separated by commas.SW_SEARCHABLE_ALARM_TAG_KEYSlevel
--gRPCThreadPoolSizePool size of gRPC server.SW_CORE_GRPC_THREAD_POOL_SIZECPU core * 4
--gRPCThreadPoolQueueSizeQueue size of gRPC server.SW_CORE_GRPC_POOL_QUEUE_SIZE10000
--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_SIZE4M(based on Netty)
--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_OPAENAPItrue
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.--
--internalComPortThe port registered in Zookeeper for the internal communication of OAP cluster.--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.--
--internalComPortThe port registered in Consul for internal communications of the OAP cluster.--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
-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.--
--internalComPortThe port registered in Nacos for internal communications of the OAP cluster.--1
--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-
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_TIMEOUT500
--socketTimeoutSocket timeout of ElasticSearch client (in milliseconds).SW_STORAGE_ES_SOCKET_TIMEOUT30000
--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
--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_SUPERDATASET_STORAGE_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
--flushIntervalPeriod of flush (in seconds). Does not matter whether bulkActions is reached or not. INT(flushInterval * 2/3) is used for index refresh period.SW_STORAGE_ES_FLUSH_INTERVAL15 (index refresh period = 10)
--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_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
--advancedAll settings of ElasticSearch index creation. The value should be in JSON format.SW_STORAGE_ES_ADVANCED-
-h2-H2 storage is designed for demonstration and running in short term (i.e. 1-2 hours) only.--
--driverH2 JDBC driver.SW_STORAGE_H2_DRIVERorg.h2.jdbcx.JdbcDataSource
--urlH2 connection URL. Defaults to H2 memory mode.SW_STORAGE_H2_URLjdbc:h2:mem:skywalking-oap-db
--userUsername of H2 database.SW_STORAGE_H2_USERsa
--passwordPassword of H2 database.--
--metadataQueryMaxSizeThe maximum size of metadata per query.SW_STORAGE_H2_QUERY_MAX_SIZE5000
--maxSizeOfArrayColumnSome entities (e.g. trace segments) include the logic column with multiple values. In H2, we use multiple physical columns to host the values: e.g. change column_a with values [1,2,3,4,5] to column_a_0 = 1, column_a_1 = 2, column_a_2 = 3 , column_a_3 = 4, column_a_4 = 5.SW_STORAGE_MAX_SIZE_OF_ARRAY_COLUMN20
--numOfSearchableValuesPerTagIn a trace segment, this includes multiple spans with multiple tags. Different spans may have the same tag key, e.g. multiple HTTP exit spans all have their own http.method tags. This configuration sets the limit on the maximum number of values for the same tag key.SW_STORAGE_NUM_OF_SEARCHABLE_VALUES_PER_TAG2
--maxSizeOfBatchSqlThe maximum size of batch size of SQL executionSW_STORAGE_MAX_SIZE_OF_BATCH_SQL100
--asyncBatchPersistentPoolSizeasync flush data into database thread sizeSW_STORAGE_ASYNC_BATCH_PERSISTENT_POOL_SIZE1
-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
--maxSizeOfArrayColumnSome entities (e.g. trace segments) include the logic column with multiple values. In MySQL, we use multiple physical columns to host the values, e.g. change column_a with values [1,2,3,4,5] to column_a_0 = 1, column_a_1 = 2, column_a_2 = 3 , column_a_3 = 4, column_a_4 = 5.SW_STORAGE_MAX_SIZE_OF_ARRAY_COLUMN20
--numOfSearchableValuesPerTagIn a trace segment, this includes multiple spans with multiple tags. Different spans may have same tag key, e.g. multiple HTTP exit spans all have their own http.method tags. This configuration sets the limit on the maximum number of values for the same tag key.SW_STORAGE_NUM_OF_SEARCHABLE_VALUES_PER_TAG2
--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
--maxSizeOfArrayColumnSome entities (e.g. trace segments) include the logic column with multiple values. In PostgreSQL, we use multiple physical columns to host the values, e.g. change column_a with values [1,2,3,4,5] to column_a_0 = 1, column_a_1 = 2, column_a_2 = 3 , column_a_3 = 4, column_a_4 = 5SW_STORAGE_MAX_SIZE_OF_ARRAY_COLUMN20
--numOfSearchableValuesPerTagIn a trace segment, this includes multiple spans with multiple tags. Different spans may have same tag key, e.g. multiple HTTP exit spans all have their own http.method tags. This configuration sets the limit on the maximum number of values for the same tag key.SW_STORAGE_NUM_OF_SEARCHABLE_VALUES_PER_TAG2
--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
-influxdb-InfluxDB storage.--
--urlInfluxDB connection URL.SW_STORAGE_INFLUXDB_URLhttp://localhost:8086
--userUser name of InfluxDB.SW_STORAGE_INFLUXDB_USERroot
--passwordPassword of InfluxDB.SW_STORAGE_INFLUXDB_PASSWORD-
--databaseDatabase of InfluxDB.SW_STORAGE_INFLUXDB_DATABASEskywalking
--actionsThe number of actions to collect.SW_STORAGE_INFLUXDB_ACTIONS1000
--durationThe maximum waiting time (in milliseconds).SW_STORAGE_INFLUXDB_DURATION1000
--batchEnabledIf true, write points with batch API.SW_STORAGE_INFLUXDB_BATCH_ENABLEDtrue
--fetchTaskLogMaxSizeThe maximum number of fetch task log in a request.SW_STORAGE_INFLUXDB_FETCH_TASK_LOG_MAX_SIZE5000
--connectionResponseFormatThe response format of connection to influxDB. It can only be MSGPACK or JSON.SW_STORAGE_INFLUXDB_CONNECTION_RESPONSE_FORMATMSGPACK
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
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-
--restMinThreadsMinimum thread number of RESTful services.SW_RECEIVER_SHARING_JETTY_MIN_THREADS1
--restMaxThreadsMaximum thread number of RESTful services.SW_RECEIVER_SHARING_JETTY_MAX_THREADS200
--restIdleTimeOutConnector idle timeout of RESTful services (in milliseconds).SW_RECEIVER_SHARING_JETTY_IDLE_TIMEOUT30000
--restAcceptorPriorityDeltaThread priority delta to give to acceptor threads of RESTful services.SW_RECEIVER_SHARING_JETTY_DELTA0
--restAcceptQueueSizeServerSocketChannel backlog of RESTful services.SW_RECEIVER_SHARING_JETTY_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_SIZECPU core * 4
--gRPCThreadPoolQueueSizeQueue size of gRPC server.SW_RECEIVER_GRPC_POOL_QUEUE_SIZE10000
--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-
--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-registerdefaultRead receiver doc for more details.--
receiver-tracedefaultRead receiver doc for more details.--
receiver-jvmdefaultRead receiver doc for more details.--
receiver-clrdefaultRead receiver doc for more details.--
receiver-profiledefaultRead receiver doc for more details.--
receiver-zabbixdefaultRead receiver doc for more details.--
--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-meshdefaultRead receiver doc for more details.--
envoy-metricdefaultRead receiver doc for more details.--
--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.-
receiver-oteldefaultRead receiver doc for more details.--
--enabledHandlersEnabled handlers for otel.SW_OTEL_RECEIVER_ENABLED_HANDLERS-
--enabledOcRulesEnabled metric rules for OC handler.SW_OTEL_RECEIVER_ENABLED_OC_RULES-
receiver_zipkindefaultRead receiver doc.--
--restHostBinding IP of RESTful services.SW_RECEIVER_ZIPKIN_HOST0.0.0.0
--restPortBinding port of RESTful services.SW_RECEIVER_ZIPKIN_PORT9411
--restContextPathWeb context path of RESTful services.SW_RECEIVER_ZIPKIN_CONTEXT_PATH/
receiver_jaegerdefaultRead receiver doc.--
--gRPCHostBinding IP of gRPC services. Services include gRPC data report and internal communication among OAP nodes.SW_RECEIVER_JAEGER_HOST-
--gRPCPortBinding port of gRPC services.SW_RECEIVER_JAEGER_PORT-
--gRPCThreadPoolSizePool size of gRPC server.-CPU core * 4
--gRPCThreadPoolQueueSizeQueue size of gRPC server.-10000
--maxConcurrentCallsPerConnectionThe maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit.--
--maxMessageSizeSets the maximum message size allowed to be received on the server. Empty means 4 MiB.-4M(based on Netty)
prometheus-fetcherdefaultRead fetcher doc for more details.--
--enabledRulesEnabled rules.SW_PROMETHEUS_FETCHER_ENABLED_RULESself
--maxConvertWorkerThe maximize meter convert worker.SW_PROMETHEUS_FETCHER_NUM_CONVERT_WORKER-1(by default, half the number of CPU core(s))
kafka-fetcherdefaultRead fetcher doc for more details.--
--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
--consumePartitionsIndicates which PartitionId(s) of the topics is/are assigned to the OAP server. Separated by commas if multiple.SW_KAFKA_FETCHER_CONSUME_PARTITIONS-
--isShardingTrue when OAP Server is in cluster.SW_KAFKA_FETCHER_IS_SHARDINGfalse
--createTopicIfNotExistIf true, this creates Kafka topic (if it does not already exist).-true
--partitionsThe number of partitions for the topic being created.SW_KAFKA_FETCHER_PARTITIONS3
--enableNativeProtoLogEnables fetching and handling native proto log data.SW_KAFKA_FETCHER_ENABLE_NATIVE_PROTO_LOGfalse
--enableNativeJsonLogEnables fetching and handling native json log data.SW_KAFKA_FETCHER_ENABLE_NATIVE_JSON_LOGfalse
--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
receiver-browserdefaultRead receiver doc for more details.---
--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.-
--pathRoot path of GraphQL query and mutation.SW_QUERY_GRAPHQL_PATH/graphql
--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
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
-apolloapolloMetaapollo.meta in Apollo.SW_CONFIG_APOLLOhttp://106.12.25.204: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
--periodThe period of data sync (in seconds).SW_CONFIG_APOLLO_PERIOD60
-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-
exportergrpctargetHostThe host of target gRPC server for receiving export data.SW_EXPORTER_GRPC_HOST127.0.0.1
--targetPortThe port of target gRPC server for receiving export data.SW_EXPORTER_GRPC_PORT9870
health-checkerdefaultcheckIntervalSecondsThe period of checking OAP internal health status (in seconds).SW_HEALTH_CHECKER_INTERVAL_SECONDS5
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-eventdefaultRead receiver doc for more details.--

Note

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