You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@skywalking.apache.org by GitBox <gi...@apache.org> on 2020/08/26 09:43:14 UTC

[GitHub] [skywalking] linliaoy opened a new issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

linliaoy opened a new issue #5391:
URL: https://github.com/apache/skywalking/issues/5391


   Please answer these questions before submitting your issue.
   
   - Why do you submit this issue?
   - [ ] Question or discussion
   - [ ] Bug
   - [ ] Requirement
   - [ ] Feature or performance improvement
   
   ___
   ### Question
   - What do you want to know?
   SW_TRACE_SAMPLE_RATE is configured as 1, but the segment data in ES is reduced
   ___
   ### Bug
   - Which version of SkyWalking, OS and JRE?
   
   - Which company or project?
   
   - What happened?
   If possible, provide a way to reproduce the error. e.g. demo application, component version.
   
   ___
   ### Requirement or improvement
   - Please describe your requirements or improvement suggestions.
   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [skywalking] MichaelWangHong commented on issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

Posted by GitBox <gi...@apache.org>.
MichaelWangHong commented on issue #5391:
URL: https://github.com/apache/skywalking/issues/5391#issuecomment-1085495040


   skywalking版本:v6.0.0-GA
   参考文档:https://github.com/apache/skywalking/blob/6.x/docs/en/setup/backend/trace-sampling.md
   按照官方设置的服务端trace信息的采样率为5000,数据量未降下来
   修改的配置文件名:apache-skywalking-apm-incubating-bin/config/application.yml
   配置信息如下:
   ```
   # Licensed to the Apache Software Foundation (ASF) under one
   # or more contributor license agreements.  See the NOTICE file
   # distributed with this work for additional information
   # regarding copyright ownership.  The ASF licenses this file
   # to you under the Apache License, Version 2.0 (the
   # "License"); you may not use this file except in compliance
   # with the License.  You may obtain a copy of the License at
   #
   #     http://www.apache.org/licenses/LICENSE-2.0
   #
   # Unless required by applicable law or agreed to in writing, software
   # distributed under the License is distributed on an "AS IS" BASIS,
   # WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
   # See the License for the specific language governing permissions and
   # limitations under the License.
   
   cluster:
     standalone:
     # Please check your ZooKeeper is 3.5+, However, it is also compatible with ZooKeeper 3.4.x. Replace the ZooKeeper 3.5+
     # library the oap-libs folder with your ZooKeeper 3.4.x library.
   #  zookeeper:
   #    nameSpace: ${SW_NAMESPACE:""}
   #    hostPort: ${SW_CLUSTER_ZK_HOST_PORT:localhost:2181}
   #    #Retry Policy
   #    baseSleepTimeMs: ${SW_CLUSTER_ZK_SLEEP_TIME:1000} # initial amount of time to wait between retries
   #    maxRetries: ${SW_CLUSTER_ZK_MAX_RETRIES:3} # max number of times to retry
   #  kubernetes:
   #    watchTimeoutSeconds: ${SW_CLUSTER_K8S_WATCH_TIMEOUT:60}
   #    namespace: ${SW_CLUSTER_K8S_NAMESPACE:default}
   #    labelSelector: ${SW_CLUSTER_K8S_LABEL:app=collector,release=skywalking}
   #    uidEnvName: ${SW_CLUSTER_K8S_UID:SKYWALKING_COLLECTOR_UID}
   #  consul:
   #    serviceName: ${SW_SERVICE_NAME:"SkyWalking_OAP_Cluster"}
   #     Consul cluster nodes, example: 10.0.0.1:8500,10.0.0.2:8500,10.0.0.3:8500
   #    hostPort: ${SW_CLUSTER_CONSUL_HOST_PORT:localhost:8500}
   core:
     default:
       # Mixed: Receive agent data, Level 1 aggregate, Level 2 aggregate
       # Receiver: Receive agent data, Level 1 aggregate
       # Aggregator: Level 2 aggregate
       role: ${SW_CORE_ROLE:Mixed} # Mixed/Receiver/Aggregator
       restHost: ${SW_CORE_REST_HOST:0.0.0.0}
       restPort: ${SW_CORE_REST_PORT:12800}
       restContextPath: ${SW_CORE_REST_CONTEXT_PATH:/}
       gRPCHost: ${SW_CORE_GRPC_HOST:0.0.0.0}
       gRPCPort: ${SW_CORE_GRPC_PORT:11800}
       downsampling:
       - Hour
       - Day
       - Month
       # Set a timeout on metric data. After the timeout has expired, the metric data will automatically be deleted.
       recordDataTTL: ${SW_CORE_RECORD_DATA_TTL:90} # Unit is minute
       minuteMetricsDataTTL: ${SW_CORE_MINUTE_METRIC_DATA_TTL:90} # Unit is minute
       hourMetricsDataTTL: ${SW_CORE_HOUR_METRIC_DATA_TTL:36} # Unit is hour
       dayMetricsDataTTL: ${SW_CORE_DAY_METRIC_DATA_TTL:45} # Unit is day
       monthMetricsDataTTL: ${SW_CORE_MONTH_METRIC_DATA_TTL:18} # Unit is month
   storage:
     h2:
       driver: ${SW_STORAGE_H2_DRIVER:org.h2.jdbcx.JdbcDataSource}
       url: ${SW_STORAGE_H2_URL:jdbc:h2:mem:skywalking-oap-db}
       user: ${SW_STORAGE_H2_USER:sa}
   #  elasticsearch:
   #    # nameSpace: ${SW_NAMESPACE:""}
   #    clusterNodes: ${SW_STORAGE_ES_CLUSTER_NODES:localhost:9200}
   #    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
   #  mysql:
   receiver-sharing-server:
     default:
   receiver-register:
     default:
   receiver-trace:
     default:
       bufferPath: ${SW_RECEIVER_BUFFER_PATH:../trace-buffer/}  # Path to trace buffer files, suggest to use absolute path
       bufferOffsetMaxFileSize: ${SW_RECEIVER_BUFFER_OFFSET_MAX_FILE_SIZE:100} # Unit is MB
       bufferDataMaxFileSize: ${SW_RECEIVER_BUFFER_DATA_MAX_FILE_SIZE:500} # Unit is MB
       bufferFileCleanWhenRestart: ${SW_RECEIVER_BUFFER_FILE_CLEAN_WHEN_RESTART:false}
       sampleRate: ${SW_TRACE_SAMPLE_RATE:5000} # The sample rate precision is 1/10000. 10000 means 100% sample in default.
       slowDBAccessThreshold: ${SW_SLOW_DB_THRESHOLD:default:200,mongodb:100} # The slow database access thresholds. Unit ms.
   receiver-jvm:
     default:
   service-mesh:
     default:
       bufferPath: ${SW_SERVICE_MESH_BUFFER_PATH:../mesh-buffer/}  # Path to trace buffer files, suggest to use absolute path
       bufferOffsetMaxFileSize: ${SW_SERVICE_MESH_OFFSET_MAX_FILE_SIZE:100} # Unit is MB
       bufferDataMaxFileSize: ${SW_SERVICE_MESH_BUFFER_DATA_MAX_FILE_SIZE:500} # Unit is MB
       bufferFileCleanWhenRestart: ${SW_SERVICE_MESH_BUFFER_FILE_CLEAN_WHEN_RESTART:false}
   istio-telemetry:
     default:
   envoy-metric:
     default:
   #receiver_zipkin:
   #  default:
   #    host: ${SW_RECEIVER_ZIPKIN_HOST:0.0.0.0}
   #    port: ${SW_RECEIVER_ZIPKIN_PORT:9411}
   #    contextPath: ${SW_RECEIVER_ZIPKIN_CONTEXT_PATH:/}
   query:
     graphql:
       path: ${SW_QUERY_GRAPHQL_PATH:/graphql}
   alarm:
     default:
   telemetry:
     none:
   ```


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@skywalking.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [skywalking] linliaoy commented on issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

Posted by GitBox <gi...@apache.org>.
linliaoy commented on issue #5391:
URL: https://github.com/apache/skywalking/issues/5391#issuecomment-680779291


   It's true, it's not the same as when I used 6.6. There is also a way to dynamically configure the sampling rate, I can't find the documentation.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [skywalking] wu-sheng commented on issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

Posted by GitBox <gi...@apache.org>.
wu-sheng commented on issue #5391:
URL: https://github.com/apache/skywalking/issues/5391#issuecomment-680776996


   Why shouldn't? We never said 1 == 100% sampling.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [skywalking] wu-sheng commented on issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

Posted by GitBox <gi...@apache.org>.
wu-sheng commented on issue #5391:
URL: https://github.com/apache/skywalking/issues/5391#issuecomment-680780164


   I don't know what is the difference, I don't remember anyone changed this. The dynamic configuration document is in the backend setup. If I remember correctly, the sampling rate could be changed in the next release or master.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [skywalking] wu-sheng closed issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

Posted by GitBox <gi...@apache.org>.
wu-sheng closed issue #5391:
URL: https://github.com/apache/skywalking/issues/5391


   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [skywalking] wu-sheng commented on issue #5391: The OAP8.1 configuration SW_TRACE_SAMPLE_RATE does not take effect

Posted by GitBox <gi...@apache.org>.
wu-sheng commented on issue #5391:
URL: https://github.com/apache/skywalking/issues/5391#issuecomment-1085497506


   @MichaelWangHong All GitHub discussions must be in English. And your description doesn't match this issue at all, and your version is years ago, the community doesn't take care of it anymore.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@skywalking.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org