You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@skywalking.apache.org by wu...@apache.org on 2020/07/23 00:24:56 UTC

[skywalking] branch master updated: Add OAP configuration vocabulary documentation. (#5149)

This is an automated email from the ASF dual-hosted git repository.

wusheng pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/skywalking.git


The following commit(s) were added to refs/heads/master by this push:
     new 2c676ea  Add OAP configuration vocabulary documentation. (#5149)
2c676ea is described below

commit 2c676ead24e34e19d7e868e92936bde0ad3e180c
Author: 吴晟 Wu Sheng <wu...@foxmail.com>
AuthorDate: Thu Jul 23 08:24:40 2020 +0800

    Add OAP configuration vocabulary documentation. (#5149)
---
 docs/README.md                                     |   1 +
 docs/en/setup/backend/backend-setup.md             |   3 +
 docs/en/setup/backend/backend-storage.md           |  18 +-
 docs/en/setup/backend/configuration-vocabulary.md  | 210 +++++++++++++++++++++
 .../src/main/resources/application.yml             |  13 +-
 .../apollo/ApolloConfigurationCenterSettings.java  |  64 +------
 .../configuration/nacos/NacosServerSettings.java   |   1 -
 .../zookeeper/ZookeeperServerSettings.java         |   8 +-
 .../oap/server/library/server/grpc/GRPCServer.java |   2 +-
 .../receiver/jaeger/JaegerReceiverConfig.java      |   1 -
 .../receiver/zipkin/ZipkinReceiverConfig.java      |   1 -
 .../StorageModuleElasticsearchConfig.java          |   2 -
 .../storage/plugin/jdbc/h2/H2StorageConfig.java    |   2 +-
 13 files changed, 232 insertions(+), 94 deletions(-)

diff --git a/docs/README.md b/docs/README.md
index f464538..3a5a051 100644
--- a/docs/README.md
+++ b/docs/README.md
@@ -70,6 +70,7 @@ If you are already familiar with SkyWalking, you could use this catalog to find
     * Use [ALS (access log service)](https://www.envoyproxy.io/docs/envoy/latest/api-v2/service/accesslog/v2/als.proto) to observe service mesh, without Mixer. Follow [document](en/setup/envoy/als_setting.md) to open it.
   * [Backend, UI and CLI setup document](en/setup/backend/backend-ui-setup.md).
     * [Backend setup document](en/setup/backend/backend-setup.md).
+      * [Configuration Vocabulary](en/setup/backend/configuration-vocabulary.md). Configuration Vocabulary lists all available configurations provided by `application.yml`.
       * [Overriding settings](en/setup/backend/backend-setting-override.md) in application.yml is supported.
       * [IP and port setting](en/setup/backend/backend-ip-port.md). Introduces how IP and port set can be used.
       * [Backend init mode startup](en/setup/backend/backend-init-mode.md). How to init the environment and exit graciously. Read this before you try to start a new cluster.
diff --git a/docs/en/setup/backend/backend-setup.md b/docs/en/setup/backend/backend-setup.md
index 7cd97ba..e5c47a2 100755
--- a/docs/en/setup/backend/backend-setup.md
+++ b/docs/en/setup/backend/backend-setup.md
@@ -68,6 +68,9 @@ service by some network(RPC) protocol, such as gRPC, HTTPRestful.
 The receivers have many different module names, you could
 read **Set receivers** document in the [link list](#advanced-feature-document-link-list).
 
+## Configuration Vocabulary
+All available configurations in `application.yml` could be found in [Configuration Vocabulary](configuration-vocabulary.md). 
+
 ## Advanced feature document link list
 After understand the setting file structure, you could choose your interesting feature document.
 We recommend you to read the feature documents in our following order.
diff --git a/docs/en/setup/backend/backend-storage.md b/docs/en/setup/backend/backend-storage.md
index 2271289..e6dcd47 100644
--- a/docs/en/setup/backend/backend-storage.md
+++ b/docs/en/setup/backend/backend-storage.md
@@ -51,13 +51,14 @@ storage:
     nameSpace: ${SW_NAMESPACE:""}
     clusterNodes: ${SW_STORAGE_ES_CLUSTER_NODES:localhost:9200}
     protocol: ${SW_STORAGE_ES_HTTP_PROTOCOL:"http"}
-    trustStorePath: ${SW_SW_STORAGE_ES_SSL_JKS_PATH:""}
-    trustStorePass: ${SW_SW_STORAGE_ES_SSL_JKS_PASS:""}
+    trustStorePath: ${SW_STORAGE_ES_SSL_JKS_PATH:""}
+    trustStorePass: ${SW_STORAGE_ES_SSL_JKS_PASS:""}
+    dayStep: ${SW_STORAGE_DAY_STEP:1} # Represent the number of days in the one minute/hour/day index.
     user: ${SW_ES_USER:""}
     password: ${SW_ES_PASSWORD:""}
     secretsManagementFile: ${SW_ES_SECRETS_MANAGEMENT_FILE:""} # Secrets management file in the properties format includes the username, password, which are managed by 3rd party tool.
-    dayStep: ${SW_STORAGE_DAY_STEP:1} # Represent the number of days in the one minute/hour/day index.
-    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:2}
+    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:1} # Shard number of new indexes
+    superDatasetIndexShardsFactor: ${SW_STORAGE_ES_SUPER_DATASET_INDEX_SHARDS_FACTOR:5} # Super data set has been defined in the codes, such as trace segments. This factor provides more shards for the super data set, shards number = indexShardsNumber * superDatasetIndexShardsFactor. Also, this factor effects Zipkin and Jaeger traces.
     indexReplicasNumber: ${SW_STORAGE_ES_INDEX_REPLICAS_NUMBER:0}
     # Batch process setting, refer to https://www.elastic.co/guide/en/elasticsearch/client/java-api/5.5/java-docs-bulk-processor.html
     bulkActions: ${SW_STORAGE_ES_BULK_ACTIONS:1000} # Execute the bulk every 1000 requests
@@ -88,14 +89,7 @@ storage:
     trustStorePath: ${SW_SW_STORAGE_ES_SSL_JKS_PATH:"../es_keystore.jks"}
     trustStorePass: ${SW_SW_STORAGE_ES_SSL_JKS_PASS:""}
     protocol: ${SW_STORAGE_ES_HTTP_PROTOCOL:"https"}
-    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:2}
-    indexReplicasNumber: ${SW_STORAGE_ES_INDEX_REPLICAS_NUMBER:0}
-    # Batch process setting, refer to https://www.elastic.co/guide/en/elasticsearch/client/java-api/5.5/java-docs-bulk-processor.html
-    bulkActions: ${SW_STORAGE_ES_BULK_ACTIONS:2000} # Execute the bulk every 2000 requests
-    bulkSize: ${SW_STORAGE_ES_BULK_SIZE:20} # flush the bulk every 20mb
-    flushInterval: ${SW_STORAGE_ES_FLUSH_INTERVAL:10} # flush the bulk every 10 seconds whatever the number of requests
-    concurrentRequests: ${SW_STORAGE_ES_CONCURRENT_REQUESTS:2} # the number of concurrent requests
-    advanced: ${SW_STORAGE_ES_ADVANCED:""}
+    ...
 ```
 - File at `trustStorePath` is being monitored, once it is changed, the ElasticSearch client will do reconnecting.
 - `trustStorePass` could be changed on the runtime through [**Secrets Management File Of ElasticSearch Authentication**](#secrets-management-file-of-elasticsearch-authentication).
diff --git a/docs/en/setup/backend/configuration-vocabulary.md b/docs/en/setup/backend/configuration-vocabulary.md
new file mode 100644
index 0000000..e8b933a
--- /dev/null
+++ b/docs/en/setup/backend/configuration-vocabulary.md
@@ -0,0 +1,210 @@
+# Configuration Vocabulary
+Configuration Vocabulary lists all available configurations provided by `application.yml`.
+
+Module | Provider | Settings | Value(s) and Explanation | System Environment Variable¹ | Default |
+----------- | ---------- | --------- | --------- |--------- |--------- |
+core|default|role|Option values, `Mixed/Receiver/Aggregator`. **Receiver** mode OAP open the service to the agents, analysis and aggregate the results and forward the results for distributed aggregation. Aggregator mode OAP receives data from Mixer and Receiver role OAP nodes, and do 2nd level aggregation. **Mixer** means being Receiver and Aggregator both.|SW_CORE_ROLE|Mixed|
+| - | - | restHost| Binding IP of restful service. Services include GraphQL query and HTTP data report|SW_CORE_REST_HOST|0.0.0.0|
+| - | - | restPort | Binding port of restful service | SW_CORE_REST_PORT|12800|
+| - | - | restContextPath| Web context path of restful service| SW_CORE_REST_CONTEXT_PATH|/|
+| - | - | gRPCHost|Binding IP of gRPC service. Services include gRPC data report and internal communication among OAP nodes|SW_CORE_GRPC_HOST|0.0.0.0|
+| - | - | gRPCPort| Binding port of gRPC service | SW_CORE_GRPC_PORT|11800|
+| - | - | gRPCSslEnabled| Activate SSL for gRPC service | SW_CORE_GRPC_SSL_ENABLED|false|
+| - | - | gRPCSslKeyPath| The file path of gRPC SSL key| SW_CORE_GRPC_SSL_KEY_PATH| - |
+| - | - | gRPCSslCertChainPath| The file path of gRPC SSL cert chain| SW_CORE_GRPC_SSL_CERT_CHAIN_PATH| - |
+| - | - | gRPCSslTrustedCAPath| The file path of gRPC trusted CA| SW_CORE_GRPC_SSL_TRUSTED_CA_PATH| - |
+| - | - | downsampling| The activated level of down sampling aggregation | | Hour,Day|
+| - | - | enableDataKeeperExecutor|Controller of TTL scheduler. Once disabled, TTL wouldn't work.|SW_CORE_ENABLE_DATA_KEEPER_EXECUTOR|true|
+| - | - | dataKeeperExecutePeriod|The execution period of TTL scheduler, unit is minute. Execution doesn't mean deleting data. The storage provider could override this, such as ElasticSearch storage.|SW_CORE_DATA_KEEPER_EXECUTE_PERIOD|5|
+| - | - | recordDataTTL|The lifecycle of record data. Record data includes traces, top n sampled records, and logs. Unit is day. Minimal value is 2.|SW_CORE_RECORD_DATA_TTL|3|
+| - | - | metricsDataTTL|The lifecycle of metrics data, including the metadata. Unit is day. Recommend metricsDataTTL >= recordDataTTL. Minimal value is 2.| SW_CORE_METRICS_DATA_TTL|7|
+| - | - | enableDatabaseSession|Cache metrics data for 1 minute to reduce database queries, and if the OAP cluster changes within that minute.|SW_CORE_ENABLE_DATABASE_SESSION|true|
+| - | - | topNReportPeriod|The execution period of top N sampler, which saves sampled data into the storage. Unit is minute|SW_CORE_TOPN_REPORT_PERIOD|10|
+| - | - | activeExtraModelColumns|Append the names of entity, such as service name, into the metrics storage entities.|SW_CORE_ACTIVE_EXTRA_MODEL_COLUMNS|false|
+| - | - | serviceNameMaxLength| Max length limitation of service name.|SW_SERVICE_NAME_MAX_LENGTH|70|
+| - | - | instanceNameMaxLength| Max length limitation of service instance name. The max length of service + instance names should be less than 200.|SW_INSTANCE_NAME_MAX_LENGTH|70|
+| - | - | endpointNameMaxLength| Max length limitation of endpoint name. The max length of service + endpoint names should be less than 240.|SW_ENDPOINT_NAME_MAX_LENGTH|150|
+| - | - | gRPCThreadPoolSize|Pool size of gRPC server| - | CPU core * 4|
+| - | - | gRPCThreadPoolQueueSize| The queue size of gRPC server| - | 10000|
+| - | - | maxConcurrentCallsPerConnection | The maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit. | - | - |
+| - | - | maxMessageSize | Sets the maximum message size allowed to be received on the server. Empty means 4 MiB | - | 4M(based on Netty) |
+| - | - | remoteTimeout |Timeout for cluster internal communication, in seconds.| - |20|
+| - | - | maxSizeOfNetworkAddressAlias|Max size of network address detected in the be monitored system.| - | 1_000_000|
+| - | - | maxPageSizeOfQueryProfileSnapshot|The max size in every OAP query for snapshot analysis| - | 500 |
+| - | - | maxSizeOfAnalyzeProfileSnapshot|The max number of snapshots analyzed by OAP| - | 12000 |
+|cluster|standalone| - | standalone is not suitable for one node running, no available configuration.| - | - |
+| - | zookeeper|nameSpace|The namespace, represented by root path, isolates the configurations in the zookeeper.|SW_NAMESPACE| `/`, root path|
+| - | - | hostPort|hosts and ports of Zookeeper Cluster|SW_CLUSTER_ZK_HOST_PORT| localhost:2181|
+| - | - | baseSleepTimeMs|The period of Zookeeper client between two retries. Unit is ms.|SW_CLUSTER_ZK_SLEEP_TIME|1000|
+| - | - | maxRetries| The max retry time of re-trying.|SW_CLUSTER_ZK_MAX_RETRIES|3|
+| - | - | enableACL| Open ACL by using `schema` and `expression`|SW_ZK_ENABLE_ACL| false|
+| - | - | schema | schema for the authorization|SW_ZK_SCHEMA|digest|
+| - | - | expression | expression for the authorization|SW_ZK_EXPRESSION|skywalking:skywalking|
+| - | - | internalComHost| The hostname registered in the Zookeeper for the internal communication of OAP cluster.| - | -|
+| - | - | internalComPort| The port registered in the Zookeeper for the internal communication of OAP cluster.| - | -1|
+| - | kubernetes| namespace| Namespace SkyWalking deployed in the k8s|SW_CLUSTER_K8S_NAMESPACE|default|
+| - | - | labelSelector| Labels used for filtering the OAP deployment in the k8s|SW_CLUSTER_K8S_LABEL| app=collector,release=skywalking|
+| - | - | uidEnvName| Environment variable name for reading uid. | SW_CLUSTER_K8S_UID|SKYWALKING_COLLECTOR_UID|
+| - | consul| serviceName| Service name used for SkyWalking cluster. |SW_SERVICE_NAME|SkyWalking_OAP_Cluster|
+| - | - | hostPort| hosts and ports used of Consul cluster.| SW_CLUSTER_CONSUL_HOST_PORT|localhost:8500|
+| - | - | aclToken| ALC Token of Consul. Empty string means `without ALC token`.| SW_CLUSTER_CONSUL_ACLTOKEN | - |
+| - | - | internalComHost| The hostname registered in the Consul for the internal communication of OAP cluster.| - | -|
+| - | - | internalComPort| The port registered in the Consul for the internal communication of OAP cluster.| - | -1|
+| - | etcd| serviceName| Service name used for SkyWalking cluster. |SW_SERVICE_NAME|SkyWalking_OAP_Cluster|
+| - | - | hostPort| hosts and ports used of etcd cluster.| SW_CLUSTER_ETCD_HOST_PORT|localhost:2379|
+| - | - | isSSL| Open SSL for the connection between SkyWalking and etcd cluster.| - | - |
+| - | - | internalComHost| The hostname registered in the etcd for the internal communication of OAP cluster.| - | -|
+| - | - | internalComPort| The port registered in the etcd for the internal communication of OAP cluster.| - | -1|
+| - | Nacos| serviceName| Service name used for SkyWalking cluster. |SW_SERVICE_NAME|SkyWalking_OAP_Cluster|
+| - | - | hostPort| hosts and ports used of Nacos cluster.| SW_CLUSTER_NACOS_HOST_PORT|localhost:8848|
+| - | - | namespace| Namespace used by SkyWalking node coordination.| SW_CLUSTER_NACOS_NAMESPACE|public|
+| storage|elasticsearch| - | ElasticSearch 6 storage implementation | - | - |
+| - | - | nameSpace | Prefix of indexes created and used by SkyWalking. | SW_NAMESPACE | - |
+| - | - | clusterNodes | ElasticSearch cluster nodes for client connection.| SW_STORAGE_ES_CLUSTER_NODES |localhost|
+| - | - | protocol | HTTP or HTTPs. | SW_STORAGE_ES_HTTP_PROTOCOL | HTTP|
+| - | - | user| User name of ElasticSearch cluster| SW_ES_USER | - |
+| - | - | password | Password of ElasticSearch cluster | SW_ES_PASSWORD | - |
+| - | - | trustStorePath | Trust JKS file path. Only work when user name and password opened | SW_STORAGE_ES_SSL_JKS_PATH | - |
+| - | - | trustStorePass | Trust JKS file password. Only work when user name and password opened | SW_STORAGE_ES_SSL_JKS_PASS | - |
+| - | - | indexShardsNumber | Shard number of new indexes | SW_STORAGE_ES_INDEX_SHARDS_NUMBER | 1 |
+| - | - | secretsManagementFile| Secrets management file in the properties format includes the username, password, which are managed by 3rd party tool. Provide the capability to update them in the runtime.|SW_ES_SECRETS_MANAGEMENT_FILE | - |
+| - | - | dayStep| Represent the number of days in the one minute/hour/day index.| SW_STORAGE_DAY_STEP | 1|
+| - | - | indexShardsNumber | Shard number of new indexes | SW_STORAGE_ES_INDEX_SHARDS_NUMBER | 1 |
+| - | - | superDatasetIndexShardsFactor | Super data set has been defined in the codes, such as trace segments. This factor provides more shards for the super data set, shards number = indexShardsNumber * superDatasetIndexShardsFactor. Also, this factor effects Zipkin and Jaeger traces.|SW_STORAGE_ES_SUPER_DATASET_INDEX_SHARDS_FACTOR|5 |
+| - | - | indexReplicasNumber | Replicas number of new indexes | SW_STORAGE_ES_INDEX_REPLICAS_NUMBER | 0 |
+| - | - | bulkActions| Bulk size of the batch execution. | SW_STORAGE_ES_BULK_ACTIONS| 1000|
+| - | - | flushInterval| Period of flush, no matter `bulkActions` reached or not. Unit is second.| SW_STORAGE_ES_FLUSH_INTERVAL | 10|
+| - | - | concurrentRequests| The number of concurrent requests allowed to be executed. | SW_STORAGE_ES_CONCURRENT_REQUESTS| 2 |
+| - | - | resultWindowMaxSize | The max size of dataset when OAP loading cache, such as network alias. | SW_STORAGE_ES_QUERY_MAX_WINDOW_SIZE | 10000|
+| - | - | metadataQueryMaxSize | The max size of metadata per query. | SW_STORAGE_ES_QUERY_MAX_SIZE | 5000 |
+| - | - | segmentQueryMaxSize | The max size of trace segments per query. | SW_STORAGE_ES_QUERY_SEGMENT_SIZE | 200|
+| - | - | profileTaskQueryMaxSize | The max size of profile task per query. | SW_STORAGE_ES_QUERY_PROFILE_TASK_SIZE | 200|
+| - | - | advanced | All settings of ElasticSearch index creation. The value should be in JSON format | SW_STORAGE_ES_ADVANCED | - |
+| - |elasticsearch7| - | ElasticSearch 7 storage implementation | - | - |
+| - | - | nameSpace | Prefix of indexes created and used by SkyWalking. | SW_NAMESPACE | - |
+| - | - | clusterNodes | ElasticSearch cluster nodes for client connection.| SW_STORAGE_ES_CLUSTER_NODES |localhost|
+| - | - | protocol | HTTP or HTTPs. | SW_STORAGE_ES_HTTP_PROTOCOL | HTTP|
+| - | - | user| User name of ElasticSearch cluster| SW_ES_USER | - |
+| - | - | password | Password of ElasticSearch cluster | SW_ES_PASSWORD | - |
+| - | - | trustStorePath | Trust JKS file path. Only work when user name and password opened | SW_STORAGE_ES_SSL_JKS_PATH | - |
+| - | - | trustStorePass | Trust JKS file password. Only work when user name and password opened | SW_STORAGE_ES_SSL_JKS_PASS | - |
+| - | - | secretsManagementFile| Secrets management file in the properties format includes the username, password, which are managed by 3rd party tool. Provide the capability to update them in the runtime.|SW_ES_SECRETS_MANAGEMENT_FILE | - |
+| - | - | dayStep| Represent the number of days in the one minute/hour/day index.| SW_STORAGE_DAY_STEP | 1|
+| - | - | indexShardsNumber | Shard number of new indexes | SW_STORAGE_ES_INDEX_SHARDS_NUMBER | 1 |
+| - | - | superDatasetIndexShardsFactor | Super data set has been defined in the codes, such as trace segments. This factor provides more shards for the super data set, shards number = indexShardsNumber * superDatasetIndexShardsFactor. Also, this factor effects Zipkin and Jaeger traces.|SW_STORAGE_ES_SUPER_DATASET_INDEX_SHARDS_FACTOR|5 |
+| - | - | indexReplicasNumber | Replicas number of new indexes | SW_STORAGE_ES_INDEX_REPLICAS_NUMBER | 0 |
+| - | - | bulkActions| Bulk size of the batch execution. | SW_STORAGE_ES_BULK_ACTIONS| 1000|
+| - | - | flushInterval| Period of flush, no matter `bulkActions` reached or not. Unit is second.| SW_STORAGE_ES_FLUSH_INTERVAL | 10|
+| - | - | concurrentRequests| The number of concurrent requests allowed to be executed. |SW_STORAGE_ES_CONCURRENT_REQUESTS| 2 |
+| - | - | resultWindowMaxSize | The max size of dataset when OAP loading cache, such as network alias. | SW_STORAGE_ES_QUERY_MAX_WINDOW_SIZE | 10000|
+| - | - | metadataQueryMaxSize | The max size of metadata per query. | SW_STORAGE_ES_QUERY_MAX_SIZE | 5000 |
+| - | - | segmentQueryMaxSize | The max size of trace segments per query. | SW_STORAGE_ES_QUERY_SEGMENT_SIZE | 200|
+| - | - | profileTaskQueryMaxSize | The max size of profile task per query. | SW_STORAGE_ES_QUERY_PROFILE_TASK_SIZE | 200|
+| - | - | advanced | All 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(1-2 hours) only | - | - |
+| - | - | driver | H2 JDBC driver. | SW_STORAGE_H2_DRIVER | org.h2.jdbcx.JdbcDataSource|
+| - | - | url | H2 connection URL. Default is H2 memory mode | SW_STORAGE_H2_URL | jdbc:h2:mem:skywalking-oap-db |
+| - | - | user | User name of H2 database. | SW_STORAGE_H2_USER | sa |
+| - | - | password | Password of H2 database. | - | - | 
+| - | - | metadataQueryMaxSize | The max size of metadata per query. | - | 5000 |
+| - |mysql| - | MySQL Storage. The MySQL JDBC Driver is not in the dist, please copy it into oap-lib folder manually | - | - |
+| - | - | properties | Hikari connection pool configurations | - | Listed in the `application.yaml`. |
+| - | - | metadataQueryMaxSize | The max size of metadata per query. | - | 5000 |
+| - |influxdb| - | InfluxDB storage. |- | - |
+| - | - | url| InfluxDB connection URL. | SW_STORAGE_INFLUXDB_URL | http://localhost:8086|
+| - | - | user | User name of InfluxDB. | SW_STORAGE_INFLUXDB_USER | root|
+| - | - | password | Password of InfluxDB. | SW_STORAGE_INFLUXDB_PASSWORD | -|
+| - | - | database | Database of InfluxDB. | SW_STORAGE_INFLUXDB_DATABASE | skywalking |
+| - | - | actions | The number of actions to collect. | SW_STORAGE_INFLUXDB_ACTIONS | 1000 |
+| - | - | duration | The time to wait at most (milliseconds). | SW_STORAGE_INFLUXDB_DURATION | 1000|
+| - | - | fetchTaskLogMaxSize | The max number of fetch task log in a request. | SW_STORAGE_INFLUXDB_FETCH_TASK_LOG_MAX_SIZE | 5000|
+| receiver-sharing-server|default| Sharing server provides new gRPC and restful servers for data collection. Ana make the servers in the core module working for internal communication only.| - | - |
+| - | - | restHost| Binding IP of restful service. Services include GraphQL query and HTTP data report| - | - |
+| - | - | restPort | Binding port of restful service |  - | - |
+| - | - | restContextPath| Web context path of restful service| - | - |
+| - | - | gRPCHost|Binding IP of gRPC service. Services include gRPC data report and internal communication among OAP nodes| - | - |
+| - | - | gRPCPort| Binding port of gRPC service | - | - |
+| - | - | gRPCThreadPoolSize|Pool size of gRPC server| - | CPU core * 4|
+| - | - | gRPCThreadPoolQueueSize| The queue size of gRPC server| - | 10000|
+| - | - | gRPCSslEnabled| Activate SSL for gRPC service | - | - |
+| - | - | gRPCSslKeyPath| The file path of gRPC SSL key| - | - |
+| - | - | gRPCSslCertChainPath| The file path of gRPC SSL cert chain| - | - |
+| - | - | maxConcurrentCallsPerConnection | The maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit. | - | - |
+| receiver-register|default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| receiver-trace|default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| - | - |sampleRate|Sampling rate for receiving trace. The precision is 1/10000. 10000 means 100% sample in default.|SW_TRACE_SAMPLE_RATE|10000|
+| - | - |slowDBAccessThreshold|The slow database access thresholds. Unit ms.|SW_SLOW_DB_THRESHOLD|default:200,mongodb:100|
+| receiver-jvm| default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| receiver-clr| default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| receiver-profile| default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| service-mesh| default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| istio-telemetry| default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| envoy-metric| default| Read [receiver doc](backend-receivers.md) for more details | - | - |
+| - | - | acceptMetricsService | Open Envoy Metrics Service analysis | SW_ENVOY_METRIC_SERVICE | true|
+| - | - | alsHTTPAnalysis | Open Envoy Access Log Service analysis. Value = `k8s-mesh` means open the analysis | SW_ENVOY_METRIC_ALS_HTTP_ANALYSIS | - |
+| receiver-oc | default | Read [receiver doc](backend-receivers.md) for more details | - | - |
+| - | - | gRPCHost|Binding IP of gRPC service. Services include gRPC data report and internal communication among OAP nodes| SW_OC_RECEIVER_GRPC_HOST | - |
+| - | - | gRPCPort| Binding port of gRPC service | SW_OC_RECEIVER_GRPC_PORT | - |
+| - | - | gRPCThreadPoolSize|Pool size of gRPC server| - | CPU core * 4|
+| - | - | gRPCThreadPoolQueueSize| The queue size of gRPC server| - | 10000|
+| - | - | maxConcurrentCallsPerConnection | The maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit. | - | - |
+| - | - | maxMessageSize | Sets the maximum message size allowed to be received on the server. Empty means 4 MiB | - | 4M(based on Netty) |
+| receiver_zipkin |default| Read [receiver doc](backend-receivers.md) | - | - |
+| - | - | restHost| Binding IP of restful service. |SW_RECEIVER_ZIPKIN_HOST|0.0.0.0|
+| - | - | restPort | Binding port of restful service | SW_RECEIVER_ZIPKIN_PORT|9411|
+| - | - | restContextPath| Web context path of restful service| SW_RECEIVER_ZIPKIN_CONTEXT_PATH|/|
+| - | - | needAnalysis|Analysis zipkin span to generate metrics| - | false|
+| - | - | maxCacheSize| Max cache size for span analysis | - | 1_000_000 |
+| - | - | expireTime| The expire time of analysis cache, unit is second. | - | 20|
+| receiver_jaeger | default| Read [receiver doc](backend-receivers.md) | - | - |
+| - | - | gRPCHost|Binding IP of gRPC service. Services include gRPC data report and internal communication among OAP nodes| SW_RECEIVER_JAEGER_HOST | - |
+| - | - | gRPCPort| Binding port of gRPC service | SW_RECEIVER_JAEGER_PORT | - |
+| - | - | gRPCThreadPoolSize|Pool size of gRPC server| - | CPU core * 4|
+| - | - | gRPCThreadPoolQueueSize| The queue size of gRPC server| - | 10000|
+| - | - | maxConcurrentCallsPerConnection | The maximum number of concurrent calls permitted for each incoming connection. Defaults to no limit. | - | - |
+| - | - | maxMessageSize | Sets the maximum message size allowed to be received on the server. Empty means 4 MiB | - | 4M(based on Netty) |
+| prometheus-fetcher | default | Read [fetcher doc](backend-fetcher.md) for more details | - | - |
+| - | - | active | Activate the Prometheus fetcher. | SW_PROMETHEUS_FETCHER_ACTIVE | false |
+| query | graphql | - | GraphQL query implementation | - |
+| - | - | path | Root path of GraphQL query and mutation. | SW_QUERY_GRAPHQL_PATH | /graphql|
+| alarm | default | - | Read [alarm doc](backend-alarm.md) for more details. | - |
+| telemetry | - | - | Read [telemetry doc](backend-telemetry.md) for more details. | - | 
+| - | none| - | No op implementation | - |
+| - | prometheus| host | Binding host for Prometheus server fetching data| SW_TELEMETRY_PROMETHEUS_HOST|0.0.0.0|
+| - | - | port|  Binding port for Prometheus server fetching data|SW_TELEMETRY_PROMETHEUS_PORT|1234|
+| configuration | - | - | Read [dynamic configuration doc](dynamic-config.md) for more details. | - |
+| - | grpc| host | DCS server binding hostname | SW_DCS_SERVER_HOST | - |
+| - | - | port | DCS server binding port | SW_DCS_SERVER_PORT | 80 |
+| - | - | clusterName | Cluster name when reading latest configuration from DSC server. | SW_DCS_CLUSTER_NAME | SkyWalking|
+| - | - | period | The period of OAP reading data from DSC server. Unit is second. | SW_DCS_PERIOD | 20 |
+| - | apollo| apolloMeta| `apollo.meta` in Apollo | SW_CONFIG_APOLLO | http://106.12.25.204:8080 | 
+| - | - | apolloCluster | `apollo.cluster` in Apollo | SW_CONFIG_APOLLO_CLUSTER | default|
+| - | - | apolloEnv | `env` in Apollo | SW_CONFIG_APOLLO_ENV | - |
+| - | - | appId | `app.id` in Apollo | SW_CONFIG_APOLLO_APP_ID | skywalking |
+| - | - | period | The period of data sync. Unit is second. | SW_CONFIG_APOLLO_PERIOD | 60 |
+| - | zookeeper|nameSpace|The namespace, represented by root path, isolates the configurations in the zookeeper.|SW_CONFIG_ZK_NAMESPACE| `/`, root path|
+| - | - | hostPort|hosts and ports of Zookeeper Cluster|SW_CONFIG_ZK_HOST_PORT| localhost:2181|
+| - | - | baseSleepTimeMs|The period of Zookeeper client between two retries. Unit is ms.|SW_CONFIG_ZK_BASE_SLEEP_TIME_MS|1000|
+| - | - | maxRetries| The max retry time of re-trying.|SW_CONFIG_ZK_MAX_RETRIES|3|
+| - | - | period | The period of data sync. Unit is second. | SW_CONFIG_ZK_PERIOD | 60 |
+| - | etcd| clusterName| Service name used for SkyWalking cluster. |SW_CONFIG_ETCD_CLUSTER_NAME|default|
+| - | - | serverAddr| hosts and ports used of etcd cluster.| SW_CONFIG_ETCD_SERVER_ADDR|localhost:2379|
+| - | - | group |Additional prefix of the configuration key| SW_CONFIG_ETCD_GROUP | skywalking|
+| - | - | period | The period of data sync. Unit is second. | SW_CONFIG_ZK_PERIOD | 60 
+| - | consul | hostPort| hosts and ports used of Consul cluster.| SW_CONFIG_CONSUL_HOST_AND_PORTS|localhost:8500|
+| - | - | aclToken| ALC Token of Consul. Empty string means `without ALC token`.| SW_CONFIG_CONSUL_ACL_TOKEN | - |
+| - | - | period | The period of data sync. Unit is second. | SW_CONFIG_CONSUL_PERIOD | 60 |
+| - | k8s-configmap | namespace | Deployment namespace of the config map. |SW_CLUSTER_K8S_NAMESPACE|default|
+| - | - | labelSelector| Labels used for locating configmap. |SW_CLUSTER_K8S_LABEL|app=collector,release=skywalking|
+| - | - | period | The period of data sync. Unit is second. | SW_CONFIG_ZK_PERIOD | 60 |
+| - | nacos | serverAddr | Nacos Server Host | SW_CONFIG_NACOS_SERVER_ADDR | 127.0.0.1|
+| - | - | port | Nacos Server Port | SW_CONFIG_NACOS_SERVER_PORT | 8848 |
+| - | - | group | Nacos Configuration namespace | SW_CONFIG_NACOS_SERVER_NAMESPACE | - |
+| - | - | period | The period of data sync. Unit is second. | SW_CONFIG_ZK_PERIOD | 60 |
+| exporter | grpc | targetHost | The host of target grpc server for receiving export data. | SW_EXPORTER_GRPC_HOST | 127.0.0.1 |
+| - | - | targetPort | The port of target grpc server for receiving export data. | SW_EXPORTER_GRPC_PORT | 9870 |
+| health-checker | default | checkIntervalSeconds | The period of check OAP internal health status. Unit is second. | SW_HEALTH_CHECKER_INTERVAL_SECONDS | 5 |
+
+## Notice
+¹ System Environment Variable name could be declared and changed in the application.yml. The names listed here,
+are just provided in the default `application.yml` file.
diff --git a/oap-server/server-bootstrap/src/main/resources/application.yml b/oap-server/server-bootstrap/src/main/resources/application.yml
index 352fbd7..3298303 100755
--- a/oap-server/server-bootstrap/src/main/resources/application.yml
+++ b/oap-server/server-bootstrap/src/main/resources/application.yml
@@ -66,13 +66,12 @@ core:
     downsampling:
       - Hour
       - Day
-      - Month
     # Set a timeout on metrics data. After the timeout has expired, the metrics data will automatically be deleted.
     enableDataKeeperExecutor: ${SW_CORE_ENABLE_DATA_KEEPER_EXECUTOR:true} # Turn it off then automatically metrics data delete will be close.
     dataKeeperExecutePeriod: ${SW_CORE_DATA_KEEPER_EXECUTE_PERIOD:5} # How often the data keeper executor runs periodically, unit is minute
     recordDataTTL: ${SW_CORE_RECORD_DATA_TTL:3} # Unit is day
     metricsDataTTL: ${SW_CORE_METRICS_DATA_TTL:7} # Unit is day
-    # Cache metric data for 1 minute to reduce database queries, and if the OAP cluster changes within that minute,
+    # Cache metrics data for 1 minute to reduce database queries, and if the OAP cluster changes within that minute,
     # the metrics may not be accurate within that minute.
     enableDatabaseSession: ${SW_CORE_ENABLE_DATABASE_SESSION:true}
     topNReportPeriod: ${SW_CORE_TOPN_REPORT_PERIOD:10} # top_n record worker report cycle, unit is minute
@@ -97,10 +96,9 @@ storage:
     password: ${SW_ES_PASSWORD:""}
     secretsManagementFile: ${SW_ES_SECRETS_MANAGEMENT_FILE:""} # Secrets management file in the properties format includes the username, password, which are managed by 3rd party tool.
     dayStep: ${SW_STORAGE_DAY_STEP:1} # Represent the number of days in the one minute/hour/day index.
-    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:1} # The index shards number is for store metrics data rather than basic segment record
+    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:1} # Shard number of new indexes
     superDatasetIndexShardsFactor: ${SW_STORAGE_ES_SUPER_DATASET_INDEX_SHARDS_FACTOR:5} # Super data set has been defined in the codes, such as trace segments. This factor provides more shards for the super data set, shards number = indexShardsNumber * superDatasetIndexShardsFactor. Also, this factor effects Zipkin and Jaeger traces.
     indexReplicasNumber: ${SW_STORAGE_ES_INDEX_REPLICAS_NUMBER:0}
-    # Batch process setting, refer to https://www.elastic.co/guide/en/elasticsearch/client/java-api/5.5/java-docs-bulk-processor.html
     bulkActions: ${SW_STORAGE_ES_BULK_ACTIONS:1000} # Execute the bulk every 1000 requests
     flushInterval: ${SW_STORAGE_ES_FLUSH_INTERVAL:10} # flush the bulk every 10 seconds whatever the number of requests
     concurrentRequests: ${SW_STORAGE_ES_CONCURRENT_REQUESTS:2} # the number of concurrent requests
@@ -119,10 +117,9 @@ storage:
     user: ${SW_ES_USER:""}
     password: ${SW_ES_PASSWORD:""}
     secretsManagementFile: ${SW_ES_SECRETS_MANAGEMENT_FILE:""} # Secrets management file in the properties format includes the username, password, which are managed by 3rd party tool.
-    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:1} # The index shards number is for store metrics data rather than basic segment record
+    indexShardsNumber: ${SW_STORAGE_ES_INDEX_SHARDS_NUMBER:1} # Shard number of new indexes
     superDatasetIndexShardsFactor: ${SW_STORAGE_ES_SUPER_DATASET_INDEX_SHARDS_FACTOR:5} # Super data set has been defined in the codes, such as trace segments. This factor provides more shards for the super data set, shards number = indexShardsNumber * superDatasetIndexShardsFactor. Also, this factor effects Zipkin and Jaeger traces.
     indexReplicasNumber: ${SW_STORAGE_ES_INDEX_REPLICAS_NUMBER:0}
-    # Batch process setting, refer to https://www.elastic.co/guide/en/elasticsearch/client/java-api/5.5/java-docs-bulk-processor.html
     bulkActions: ${SW_STORAGE_ES_BULK_ACTIONS:1000} # Execute the bulk every 1000 requests
     flushInterval: ${SW_STORAGE_ES_FLUSH_INTERVAL:10} # flush the bulk every 10 seconds whatever the number of requests
     concurrentRequests: ${SW_STORAGE_ES_CONCURRENT_REQUESTS:2} # the number of concurrent requests
@@ -266,7 +263,7 @@ configuration:
     # Consul host and ports, separated by comma, e.g. 1.2.3.4:8500,2.3.4.5:8500
     hostAndPorts: ${SW_CONFIG_CONSUL_HOST_AND_PORTS:1.2.3.4:8500}
     # Sync period in seconds. Defaults to 60 seconds.
-    period: ${SW_CONFIG_CONSUL_PERIOD:1}
+    period: ${SW_CONFIG_CONSUL_PERIOD:60}
     # Consul aclToken
     aclToken: ${SW_CONFIG_CONSUL_ACL_TOKEN:""}
   k8s-configmap:
@@ -284,8 +281,6 @@ configuration:
     namespace: ${SW_CONFIG_NACOS_SERVER_NAMESPACE:}
     # Unit seconds, sync period. Default fetch every 60 seconds.
     period: ${SW_CONFIG_NACOS_PERIOD:60}
-    # the name of current cluster, set the name if you want to upstream system known.
-    clusterName: ${SW_CONFIG_NACOS_CLUSTER_NAME:default}
 
 exporter:
   selector: ${SW_EXPORTER:-}
diff --git a/oap-server/server-configuration/configuration-apollo/src/main/java/org/apache/skywalking/oap/server/configuration/apollo/ApolloConfigurationCenterSettings.java b/oap-server/server-configuration/configuration-apollo/src/main/java/org/apache/skywalking/oap/server/configuration/apollo/ApolloConfigurationCenterSettings.java
index 2ba13a0..13f1eab 100644
--- a/oap-server/server-configuration/configuration-apollo/src/main/java/org/apache/skywalking/oap/server/configuration/apollo/ApolloConfigurationCenterSettings.java
+++ b/oap-server/server-configuration/configuration-apollo/src/main/java/org/apache/skywalking/oap/server/configuration/apollo/ApolloConfigurationCenterSettings.java
@@ -18,8 +18,12 @@
 
 package org.apache.skywalking.oap.server.configuration.apollo;
 
+import lombok.Getter;
+import lombok.ToString;
 import org.apache.skywalking.oap.server.library.module.ModuleConfig;
 
+@Getter
+@ToString
 public class ApolloConfigurationCenterSettings extends ModuleConfig {
     private String apolloCluster = "default";
     private String apolloMeta;
@@ -29,64 +33,4 @@ public class ApolloConfigurationCenterSettings extends ModuleConfig {
     private String clusterName = "default";
     private int period = 60;
 
-    public String getApolloCluster() {
-        return this.apolloCluster;
-    }
-
-    public String getClusterName() {
-        return this.clusterName;
-    }
-
-    public String getApolloMeta() {
-        return apolloMeta;
-    }
-
-    public void setApolloMeta(String apolloMeta) {
-        this.apolloMeta = apolloMeta;
-    }
-
-    public String getApolloEnv() {
-        return apolloEnv;
-    }
-
-    public void setApolloEnv(String apolloEnv) {
-        this.apolloEnv = apolloEnv;
-    }
-
-    public String getAppId() {
-        return appId;
-    }
-
-    public void setAppId(String appId) {
-        this.appId = appId;
-    }
-
-    public String getNamespace() {
-        return namespace;
-    }
-
-    public void setNamespace(String namespace) {
-        this.namespace = namespace;
-    }
-
-    public int getPeriod() {
-        return this.period;
-    }
-
-    public void setApolloCluster(String apolloCluster) {
-        this.apolloCluster = apolloCluster;
-    }
-
-    public void setClusterName(String clusterName) {
-        this.clusterName = clusterName;
-    }
-
-    public void setPeriod(int period) {
-        this.period = period;
-    }
-
-    public String toString() {
-        return "ApolloConfigurationCenterSettings(" + "apolloCluster=" + this.getApolloCluster() + ", clusterName=" + this
-            .getClusterName() + ", period=" + this.getPeriod() + ")";
-    }
 }
diff --git a/oap-server/server-configuration/configuration-nacos/src/main/java/org/apache/skywalking/oap/server/configuration/nacos/NacosServerSettings.java b/oap-server/server-configuration/configuration-nacos/src/main/java/org/apache/skywalking/oap/server/configuration/nacos/NacosServerSettings.java
index cbe4af1..6af5517 100644
--- a/oap-server/server-configuration/configuration-nacos/src/main/java/org/apache/skywalking/oap/server/configuration/nacos/NacosServerSettings.java
+++ b/oap-server/server-configuration/configuration-nacos/src/main/java/org/apache/skywalking/oap/server/configuration/nacos/NacosServerSettings.java
@@ -27,7 +27,6 @@ import org.apache.skywalking.oap.server.library.module.ModuleConfig;
 @Setter
 @ToString
 public class NacosServerSettings extends ModuleConfig {
-    private String clusterName = "default";
     private String namespace = "";
     private String serverAddr;
     private int port = 8848;
diff --git a/oap-server/server-configuration/configuration-zookeeper/src/main/java/org/apache/skywalking/oap/server/configuration/zookeeper/ZookeeperServerSettings.java b/oap-server/server-configuration/configuration-zookeeper/src/main/java/org/apache/skywalking/oap/server/configuration/zookeeper/ZookeeperServerSettings.java
index d54bb36..43603a4 100644
--- a/oap-server/server-configuration/configuration-zookeeper/src/main/java/org/apache/skywalking/oap/server/configuration/zookeeper/ZookeeperServerSettings.java
+++ b/oap-server/server-configuration/configuration-zookeeper/src/main/java/org/apache/skywalking/oap/server/configuration/zookeeper/ZookeeperServerSettings.java
@@ -20,20 +20,16 @@ package org.apache.skywalking.oap.server.configuration.zookeeper;
 
 import lombok.Getter;
 import lombok.Setter;
+import lombok.ToString;
 import org.apache.skywalking.oap.server.library.module.ModuleConfig;
 
 @Getter
 @Setter
+@ToString
 public class ZookeeperServerSettings extends ModuleConfig {
     private String nameSpace = "/default";
     private String hostPort;
     private int baseSleepTimeMs = 1000;
     private int maxRetries = 3;
     private int period = 60;
-
-    @Override
-    public String toString() {
-        return "ZookeeperServerSettings(nameSpace=" + this.getNameSpace() + ", hostPort=" + this.getHostPort() + ", baseSleepTimeMs=" + this
-            .getBaseSleepTimeMs() + ", maxRetries=" + this.getMaxRetries() + ", period=" + this.getPeriod() + ")";
-    }
 }
diff --git a/oap-server/server-library/library-server/src/main/java/org/apache/skywalking/oap/server/library/server/grpc/GRPCServer.java b/oap-server/server-library/library-server/src/main/java/org/apache/skywalking/oap/server/library/server/grpc/GRPCServer.java
index 452484f..e952b21 100644
--- a/oap-server/server-library/library-server/src/main/java/org/apache/skywalking/oap/server/library/server/grpc/GRPCServer.java
+++ b/oap-server/server-library/library-server/src/main/java/org/apache/skywalking/oap/server/library/server/grpc/GRPCServer.java
@@ -107,7 +107,7 @@ public class GRPCServer implements Server {
         ExecutorService executor = new ThreadPoolExecutor(threadPoolSize, threadPoolSize, 60, TimeUnit.SECONDS, blockingQueue, new CustomThreadFactory("grpcServerPool"), new CustomRejectedExecutionHandler());
         nettyServerBuilder = NettyServerBuilder.forAddress(address);
         nettyServerBuilder = nettyServerBuilder.maxConcurrentCallsPerConnection(maxConcurrentCallsPerConnection)
-                                               .maxMessageSize(maxMessageSize)
+                                               .maxInboundMessageSize(maxMessageSize)
                                                .executor(executor);
         logger.info("Server started, host {} listening on {}", host, port);
     }
diff --git a/oap-server/server-receiver-plugin/jaeger-receiver-plugin/src/main/java/org/apache/skywalking/aop/server/receiver/jaeger/JaegerReceiverConfig.java b/oap-server/server-receiver-plugin/jaeger-receiver-plugin/src/main/java/org/apache/skywalking/aop/server/receiver/jaeger/JaegerReceiverConfig.java
index 75fe473..55d8f67 100644
--- a/oap-server/server-receiver-plugin/jaeger-receiver-plugin/src/main/java/org/apache/skywalking/aop/server/receiver/jaeger/JaegerReceiverConfig.java
+++ b/oap-server/server-receiver-plugin/jaeger-receiver-plugin/src/main/java/org/apache/skywalking/aop/server/receiver/jaeger/JaegerReceiverConfig.java
@@ -29,7 +29,6 @@ public class JaegerReceiverConfig extends ModuleConfig {
     private int gRPCPort = -1;
     private int maxConcurrentCallsPerConnection;
     private int maxMessageSize;
-    private boolean registerJaegerEndpoint = true;
     private int gRPCThreadPoolSize;
     private int gRPCThreadPoolQueueSize;
 }
diff --git a/oap-server/server-receiver-plugin/zipkin-receiver-plugin/src/main/java/org/apache/skywalking/oap/server/receiver/zipkin/ZipkinReceiverConfig.java b/oap-server/server-receiver-plugin/zipkin-receiver-plugin/src/main/java/org/apache/skywalking/oap/server/receiver/zipkin/ZipkinReceiverConfig.java
index 1b49e55..0595303 100644
--- a/oap-server/server-receiver-plugin/zipkin-receiver-plugin/src/main/java/org/apache/skywalking/oap/server/receiver/zipkin/ZipkinReceiverConfig.java
+++ b/oap-server/server-receiver-plugin/zipkin-receiver-plugin/src/main/java/org/apache/skywalking/oap/server/receiver/zipkin/ZipkinReceiverConfig.java
@@ -31,5 +31,4 @@ public class ZipkinReceiverConfig extends ModuleConfig {
     private int expireTime = 20;
     private int maxCacheSize = 1_000_000;
     private boolean needAnalysis = false;
-    private boolean registerZipkinEndpoint = true;
 }
diff --git a/oap-server/server-storage-plugin/storage-elasticsearch-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/elasticsearch/StorageModuleElasticsearchConfig.java b/oap-server/server-storage-plugin/storage-elasticsearch-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/elasticsearch/StorageModuleElasticsearchConfig.java
index a33e992..6bcb653 100644
--- a/oap-server/server-storage-plugin/storage-elasticsearch-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/elasticsearch/StorageModuleElasticsearchConfig.java
+++ b/oap-server/server-storage-plugin/storage-elasticsearch-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/elasticsearch/StorageModuleElasticsearchConfig.java
@@ -46,8 +46,6 @@ public class StorageModuleElasticsearchConfig extends ModuleConfig {
     private int flushInterval = 10;
     @Setter
     private int concurrentRequests = 2;
-    @Setter
-    private int syncBulkActions = 3;
     /**
      * @since 7.0.0 This could be managed inside {@link #secretsManagementFile}
      */
diff --git a/oap-server/server-storage-plugin/storage-jdbc-hikaricp-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/jdbc/h2/H2StorageConfig.java b/oap-server/server-storage-plugin/storage-jdbc-hikaricp-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/jdbc/h2/H2StorageConfig.java
index 372af12..b39c2f2 100644
--- a/oap-server/server-storage-plugin/storage-jdbc-hikaricp-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/jdbc/h2/H2StorageConfig.java
+++ b/oap-server/server-storage-plugin/storage-jdbc-hikaricp-plugin/src/main/java/org/apache/skywalking/oap/server/storage/plugin/jdbc/h2/H2StorageConfig.java
@@ -26,7 +26,7 @@ import org.apache.skywalking.oap.server.library.module.ModuleConfig;
 @Getter
 public class H2StorageConfig extends ModuleConfig {
     private String driver = "org.h2.jdbcx.JdbcDataSource";
-    private String url = "jdbc:h2:mem:collector";
+    private String url = "jdbc:h2:mem:skywalking-oap-db";
     private String user = "";
     private String password = "";
     private int metadataQueryMaxSize = 5000;