返回介绍

Metrics Reference

发布于 2024-07-15 23:51:41 字数 40406 浏览 0 评论 0 收藏 0

Orderer Metrics

Prometheus

The following orderer metrics are exported for consumption by Prometheus.

NameTypeDescriptionLabels
blockcutter_block_fill_durationhistogramThe time from first transaction enqueing to the block being cut in seconds.channel 
broadcast_enqueue_durationhistogramThe time to enqueue a transaction in seconds.channel 
type 
status 
broadcast_processed_countcounterThe number of transactions processed.channel 
type 
status 
broadcast_validate_durationhistogramThe time to validate a transaction in seconds.channel 
type 
status 
cluster_comm_egress_queue_capacitygaugeCapacity of the egress queue.host 
msg_type 
channel 
cluster_comm_egress_queue_lengthgaugeLength of the egress queue.host 
msg_type 
channel 
cluster_comm_egress_queue_workersgaugeCount of egress queue workers.channel 
cluster_comm_egress_stream_countgaugeCount of streams to other nodes.channel 
cluster_comm_egress_tls_connection_countgaugeCount of TLS connections to other nodes.  
cluster_comm_ingress_stream_countgaugeCount of streams from other nodes.  
cluster_comm_msg_dropped_countcounterCount of messages dropped.host 
channel 
cluster_comm_msg_send_timehistogramThe time it takes to send a message in seconds.host 
channel 
consensus_etcdraft_active_nodesgaugeNumber of active nodes in this channel.channel 
consensus_etcdraft_cluster_sizegaugeNumber of nodes in this channel.channel 
consensus_etcdraft_committed_block_numbergaugeThe block number of the latest block committed.channel 
consensus_etcdraft_config_proposals_receivedcounterThe total number of proposals received for config type transactions.channel 
consensus_etcdraft_data_persist_durationhistogramThe time taken for etcd/raft data to be persisted in storage (in seconds).channel 
consensus_etcdraft_is_leadergaugeThe leadership status of the current node: 1 if it is the leader else 0.channel 
consensus_etcdraft_leader_changescounterThe number of leader changes since process start.channel 
consensus_etcdraft_normal_proposals_receivedcounterThe total number of proposals received for normal type transactions.channel 
consensus_etcdraft_proposal_failurescounterThe number of proposal failures.channel 
consensus_etcdraft_snapshot_block_numbergaugeThe block number of the latest snapshot.channel 
consensus_kafka_batch_sizegaugeThe mean batch size in bytes sent to topics.topic 
consensus_kafka_compression_ratiogaugeThe mean compression ratio (as percentage) for topics.topic 
consensus_kafka_incoming_byte_rategaugeBytes/second read off brokers.broker_id 
consensus_kafka_last_offset_persistedgaugeThe offset specified in the block metadata of the most recently committed block.channel 
consensus_kafka_outgoing_byte_rategaugeBytes/second written to brokers.broker_id 
consensus_kafka_record_send_rategaugeThe number of records per second sent to topics.topic 
consensus_kafka_records_per_requestgaugeThe mean number of records sent per request to topics.topic 
consensus_kafka_request_latencygaugeThe mean request latency in ms to brokers.broker_id 
consensus_kafka_request_rategaugeRequests/second sent to brokers.broker_id 
consensus_kafka_request_sizegaugeThe mean request size in bytes to brokers.broker_id 
consensus_kafka_response_rategaugeRequests/second sent to brokers.broker_id 
consensus_kafka_response_sizegaugeThe mean response size in bytes from brokers.broker_id 
deliver_blocks_sentcounterThe number of blocks sent by the deliver service.channel 
filtered 
data_type 
deliver_requests_completedcounterThe number of deliver requests that have been completed.channel 
filtered 
data_type 
success 
deliver_requests_receivedcounterThe number of deliver requests that have been received.channel 
filtered 
data_type 
deliver_streams_closedcounterThe number of GRPC streams that have been closed for the deliver service.  
deliver_streams_openedcounterThe number of GRPC streams that have been opened for the deliver service.  
fabric_versiongaugeThe active version of Fabric.version 
grpc_comm_conn_closedcountergRPC connections closed. Open minus closed is the active number of connections.  
grpc_comm_conn_openedcountergRPC connections opened. Open minus closed is the active number of connections.  
grpc_server_stream_messages_receivedcounterThe number of stream messages received.service 
method 
grpc_server_stream_messages_sentcounterThe number of stream messages sent.service 
method 
grpc_server_stream_request_durationhistogramThe time to complete a stream request.service 
method 
code 
grpc_server_stream_requests_completedcounterThe number of stream requests completed.service 
method 
code 
grpc_server_stream_requests_receivedcounterThe number of stream requests received.service 
method 
grpc_server_unary_request_durationhistogramThe time to complete a unary request.service 
method 
code 
grpc_server_unary_requests_completedcounterThe number of unary requests completed.service 
method 
code 
grpc_server_unary_requests_receivedcounterThe number of unary requests received.service 
method 
ledger_blockchain_heightgaugeHeight of the chain in blocks.channel 
ledger_blockstorage_commit_timehistogramTime taken in seconds for committing the block to storage.channel 
logging_entries_checkedcounterNumber of log entries checked against the active logging levellevel 
logging_entries_writtencounterNumber of log entries that are writtenlevel 

StatsD

The following orderer metrics are emitted for consumption by StatsD. The %{variable_name} nomenclature represents segments that vary based on context.

For example, %{channel} will be replaced with the name of the channel associated with the metric.

BucketTypeDescription
blockcutter.block_fill_duration.%{channel}histogramThe time from first transaction enqueing to the block being cut in seconds.
broadcast.enqueue_duration.%{channel}.%{type}.%{status}histogramThe time to enqueue a transaction in seconds.
broadcast.processed_count.%{channel}.%{type}.%{status}counterThe number of transactions processed.
broadcast.validate_duration.%{channel}.%{type}.%{status}histogramThe time to validate a transaction in seconds.
cluster.comm.egress_queue_capacity.%{host}.%{msg_type}.%{channel}gaugeCapacity of the egress queue.
cluster.comm.egress_queue_length.%{host}.%{msg_type}.%{channel}gaugeLength of the egress queue.
cluster.comm.egress_queue_workers.%{channel}gaugeCount of egress queue workers.
cluster.comm.egress_stream_count.%{channel}gaugeCount of streams to other nodes.
cluster.comm.egress_tls_connection_countgaugeCount of TLS connections to other nodes.
cluster.comm.ingress_stream_countgaugeCount of streams from other nodes.
cluster.comm.msg_dropped_count.%{host}.%{channel}counterCount of messages dropped.
cluster.comm.msg_send_time.%{host}.%{channel}histogramThe time it takes to send a message in seconds.
consensus.etcdraft.active_nodes.%{channel}gaugeNumber of active nodes in this channel.
consensus.etcdraft.cluster_size.%{channel}gaugeNumber of nodes in this channel.
consensus.etcdraft.committed_block_number.%{channel}gaugeThe block number of the latest block committed.
consensus.etcdraft.config_proposals_received.%{channel}counterThe total number of proposals received for config type transactions.
consensus.etcdraft.data_persist_duration.%{channel}histogramThe time taken for etcd/raft data to be persisted in storage (in seconds).
consensus.etcdraft.is_leader.%{channel}gaugeThe leadership status of the current node: 1 if it is the leader else 0.
consensus.etcdraft.leader_changes.%{channel}counterThe number of leader changes since process start.
consensus.etcdraft.normal_proposals_received.%{channel}counterThe total number of proposals received for normal type transactions.
consensus.etcdraft.proposal_failures.%{channel}counterThe number of proposal failures.
consensus.etcdraft.snapshot_block_number.%{channel}gaugeThe block number of the latest snapshot.
consensus.kafka.batch_size.%{topic}gaugeThe mean batch size in bytes sent to topics.
consensus.kafka.compression_ratio.%{topic}gaugeThe mean compression ratio (as percentage) for topics.
consensus.kafka.incoming_byte_rate.%{broker_id}gaugeBytes/second read off brokers.
consensus.kafka.last_offset_persisted.%{channel}gaugeThe offset specified in the block metadata of the most recently committed block.
consensus.kafka.outgoing_byte_rate.%{broker_id}gaugeBytes/second written to brokers.
consensus.kafka.record_send_rate.%{topic}gaugeThe number of records per second sent to topics.
consensus.kafka.records_per_request.%{topic}gaugeThe mean number of records sent per request to topics.
consensus.kafka.request_latency.%{broker_id}gaugeThe mean request latency in ms to brokers.
consensus.kafka.request_rate.%{broker_id}gaugeRequests/second sent to brokers.
consensus.kafka.request_size.%{broker_id}gaugeThe mean request size in bytes to brokers.
consensus.kafka.response_rate.%{broker_id}gaugeRequests/second sent to brokers.
consensus.kafka.response_size.%{broker_id}gaugeThe mean response size in bytes from brokers.
deliver.blocks_sent.%{channel}.%{filtered}.%{data_type}counterThe number of blocks sent by the deliver service.
deliver.requests_completed.%{channel}.%{filtered}.%{data_type}.%{success}counterThe number of deliver requests that have been completed.
deliver.requests_received.%{channel}.%{filtered}.%{data_type}counterThe number of deliver requests that have been received.
deliver.streams_closedcounterThe number of GRPC streams that have been closed for the deliver service.
deliver.streams_openedcounterThe number of GRPC streams that have been opened for the deliver service.
fabric_version.%{version}gaugeThe active version of Fabric.
grpc.comm.conn_closedcountergRPC connections closed. Open minus closed is the active number of connections.
grpc.comm.conn_openedcountergRPC connections opened. Open minus closed is the active number of connections.
grpc.server.stream_messages_received.%{service}.%{method}counterThe number of stream messages received.
grpc.server.stream_messages_sent.%{service}.%{method}counterThe number of stream messages sent.
grpc.server.stream_request_duration.%{service}.%{method}.%{code}histogramThe time to complete a stream request.
grpc.server.stream_requests_completed.%{service}.%{method}.%{code}counterThe number of stream requests completed.
grpc.server.stream_requests_received.%{service}.%{method}counterThe number of stream requests received.
grpc.server.unary_request_duration.%{service}.%{method}.%{code}histogramThe time to complete a unary request.
grpc.server.unary_requests_completed.%{service}.%{method}.%{code}counterThe number of unary requests completed.
grpc.server.unary_requests_received.%{service}.%{method}counterThe number of unary requests received.
ledger.blockchain_height.%{channel}gaugeHeight of the chain in blocks.
ledger.blockstorage_commit_time.%{channel}histogramTime taken in seconds for committing the block to storage.
logging.entries_checked.%{level}counterNumber of log entries checked against the active logging level
logging.entries_written.%{level}counterNumber of log entries that are written

Peer Metrics

Prometheus

The following peer metrics are exported for consumption by Prometheus.

NameTypeDescriptionLabels
chaincode_execute_timeoutscounterThe number of chaincode executions (Init or Invoke) that have timed out.chaincode 
chaincode_launch_durationhistogramThe time to launch a chaincode.chaincode 
success 
chaincode_launch_failurescounterThe number of chaincode launches that have failed.chaincode 
chaincode_launch_timeoutscounterThe number of chaincode launches that have timed out.chaincode 
chaincode_shim_request_durationhistogramThe time to complete chaincode shim requests.type 
channel 
chaincode 
success 
chaincode_shim_requests_completedcounterThe number of chaincode shim requests completed.type 
channel 
chaincode 
success 
chaincode_shim_requests_receivedcounterThe number of chaincode shim requests received.type 
channel 
chaincode 
couchdb_processing_timehistogramTime taken in seconds for the function to complete request to CouchDBdatabase 
function_name 
result 
deliver_blocks_sentcounterThe number of blocks sent by the deliver service.channel 
filtered 
data_type 
deliver_requests_completedcounterThe number of deliver requests that have been completed.channel 
filtered 
data_type 
success 
deliver_requests_receivedcounterThe number of deliver requests that have been received.channel 
filtered 
data_type 
deliver_streams_closedcounterThe number of GRPC streams that have been closed for the deliver service.  
deliver_streams_openedcounterThe number of GRPC streams that have been opened for the deliver service.  
dockercontroller_chaincode_container_build_durationhistogramThe time to build a chaincode image in seconds.chaincode 
success 
endorser_chaincode_instantiation_failurescounterThe number of chaincode instantiations or upgrade that have failed.channel 
chaincode 
endorser_duplicate_transaction_failurescounterThe number of failed proposals due to duplicate transaction ID.channel 
chaincode 
endorser_endorsement_failurescounterThe number of failed endorsements.channel 
chaincode 
chaincodeerror 
endorser_proposal_acl_failurescounterThe number of proposals that failed ACL checks.channel 
chaincode 
endorser_proposal_durationhistogramThe time to complete a proposal.channel 
chaincode 
success 
endorser_proposal_simulation_failurescounterThe number of failed proposal simulationschannel 
chaincode 
endorser_proposal_validation_failurescounterThe number of proposals that have failed initial validation.  
endorser_proposals_receivedcounterThe number of proposals received.  
endorser_successful_proposalscounterThe number of successful proposals.  
fabric_versiongaugeThe active version of Fabric.version 
gossip_comm_messages_receivedcounterNumber of messages received  
gossip_comm_messages_sentcounterNumber of messages sent  
gossip_comm_overflow_countcounterNumber of outgoing queue buffer overflows  
gossip_leader_election_leadergaugePeer is leader (1) or follower (0)channel 
gossip_membership_total_peers_knowngaugeTotal known peerschannel 
gossip_payload_buffer_sizegaugeSize of the payload bufferchannel 
gossip_privdata_commit_block_durationhistogramTime it takes to commit private data and the corresponding block (in seconds)channel 
gossip_privdata_fetch_durationhistogramTime it takes to fetch missing private data from peers (in seconds)channel 
gossip_privdata_list_missing_durationhistogramTime it takes to list the missing private data (in seconds)channel 
gossip_privdata_pull_durationhistogramTime it takes to pull a missing private data element (in seconds)channel 
gossip_privdata_purge_durationhistogramTime it takes to purge private data (in seconds)channel 
gossip_privdata_reconciliation_durationhistogramTime it takes for reconciliation to complete (in seconds)channel 
gossip_privdata_retrieve_durationhistogramTime it takes to retrieve missing private data elements from the ledger (in seconds)channel 
gossip_privdata_send_durationhistogramTime it takes to send a missing private data element (in seconds)channel 
gossip_privdata_validation_durationhistogramTime it takes to validate a block (in seconds)channel 
gossip_state_commit_durationhistogramTime it takes to commit a block in secondschannel 
gossip_state_heightgaugeCurrent ledger heightchannel 
grpc_comm_conn_closedcountergRPC connections closed. Open minus closed is the active number of connections.  
grpc_comm_conn_openedcountergRPC connections opened. Open minus closed is the active number of connections.  
grpc_server_stream_messages_receivedcounterThe number of stream messages received.service 
method 
grpc_server_stream_messages_sentcounterThe number of stream messages sent.service 
method 
grpc_server_stream_request_durationhistogramThe time to complete a stream request.service 
method 
code 
grpc_server_stream_requests_completedcounterThe number of stream requests completed.service 
method 
code 
grpc_server_stream_requests_receivedcounterThe number of stream requests received.service 
method 
grpc_server_unary_request_durationhistogramThe time to complete a unary request.service 
method 
code 
grpc_server_unary_requests_completedcounterThe number of unary requests completed.service 
method 
code 
grpc_server_unary_requests_receivedcounterThe number of unary requests received.service 
method 
ledger_block_processing_timehistogramTime taken in seconds for ledger block processing.channel 
ledger_blockchain_heightgaugeHeight of the chain in blocks.channel 
ledger_blockstorage_and_pvtdata_commit_timehistogramTime taken in seconds for committing the block and private data to storage.channel 
ledger_blockstorage_commit_timehistogramTime taken in seconds for committing the block to storage.channel 
ledger_statedb_commit_timehistogramTime taken in seconds for committing block changes to state db.channel 
ledger_transaction_countcounterNumber of transactions processed.channel 
transaction_type 
chaincode 
validation_code 
logging_entries_checkedcounterNumber of log entries checked against the active logging levellevel 
logging_entries_writtencounterNumber of log entries that are writtenlevel 

StatsD

The following peer metrics are emitted for consumption by StatsD. The %{variable_name} nomenclature represents segments that vary based on context.

For example, %{channel} will be replaced with the name of the channel associated with the metric.

BucketTypeDescription
chaincode.execute_timeouts.%{chaincode}counterThe number of chaincode executions (Init or Invoke) that have timed out.
chaincode.launch_duration.%{chaincode}.%{success}histogramThe time to launch a chaincode.
chaincode.launch_failures.%{chaincode}counterThe number of chaincode launches that have failed.
chaincode.launch_timeouts.%{chaincode}counterThe number of chaincode launches that have timed out.
chaincode.shim_request_duration.%{type}.%{channel}.%{chaincode}.%{success}histogramThe time to complete chaincode shim requests.
chaincode.shim_requests_completed.%{type}.%{channel}.%{chaincode}.%{success}counterThe number of chaincode shim requests completed.
chaincode.shim_requests_received.%{type}.%{channel}.%{chaincode}counterThe number of chaincode shim requests received.
couchdb.processing_time.%{database}.%{function_name}.%{result}histogramTime taken in seconds for the function to complete request to CouchDB
deliver.blocks_sent.%{channel}.%{filtered}.%{data_type}counterThe number of blocks sent by the deliver service.
deliver.requests_completed.%{channel}.%{filtered}.%{data_type}.%{success}counterThe number of deliver requests that have been completed.
deliver.requests_received.%{channel}.%{filtered}.%{data_type}counterThe number of deliver requests that have been received.
deliver.streams_closedcounterThe number of GRPC streams that have been closed for the deliver service.
deliver.streams_openedcounterThe number of GRPC streams that have been opened for the deliver service.
dockercontroller.chaincode_container_build_duration.%{chaincode}.%{success}histogramThe time to build a chaincode image in seconds.
endorser.chaincode_instantiation_failures.%{channel}.%{chaincode}counterThe number of chaincode instantiations or upgrade that have failed.
endorser.duplicate_transaction_failures.%{channel}.%{chaincode}counterThe number of failed proposals due to duplicate transaction ID.
endorser.endorsement_failures.%{channel}.%{chaincode}.%{chaincodeerror}counterThe number of failed endorsements.
endorser.proposal_acl_failures.%{channel}.%{chaincode}counterThe number of proposals that failed ACL checks.
endorser.proposal_duration.%{channel}.%{chaincode}.%{success}histogramThe time to complete a proposal.
endorser.proposal_simulation_failures.%{channel}.%{chaincode}counterThe number of failed proposal simulations
endorser.proposal_validation_failurescounterThe number of proposals that have failed initial validation.
endorser.proposals_receivedcounterThe number of proposals received.
endorser.successful_proposalscounterThe number of successful proposals.
fabric_version.%{version}gaugeThe active version of Fabric.
gossip.comm.messages_receivedcounterNumber of messages received
gossip.comm.messages_sentcounterNumber of messages sent
gossip.comm.overflow_countcounterNumber of outgoing queue buffer overflows
gossip.leader_election.leader.%{channel}gaugePeer is leader (1) or follower (0)
gossip.membership.total_peers_known.%{channel}gaugeTotal known peers
gossip.payload_buffer.size.%{channel}gaugeSize of the payload buffer
gossip.privdata.commit_block_duration.%{channel}histogramTime it takes to commit private data and the corresponding block (in seconds)
gossip.privdata.fetch_duration.%{channel}histogramTime it takes to fetch missing private data from peers (in seconds)
gossip.privdata.list_missing_duration.%{channel}histogramTime it takes to list the missing private data (in seconds)
gossip.privdata.pull_duration.%{channel}histogramTime it takes to pull a missing private data element (in seconds)
gossip.privdata.purge_duration.%{channel}histogramTime it takes to purge private data (in seconds)
gossip.privdata.reconciliation_duration.%{channel}histogramTime it takes for reconciliation to complete (in seconds)
gossip.privdata.retrieve_duration.%{channel}histogramTime it takes to retrieve missing private data elements from the ledger (in seconds)
gossip.privdata.send_duration.%{channel}histogramTime it takes to send a missing private data element (in seconds)
gossip.privdata.validation_duration.%{channel}histogramTime it takes to validate a block (in seconds)
gossip.state.commit_duration.%{channel}histogramTime it takes to commit a block in seconds
gossip.state.height.%{channel}gaugeCurrent ledger height
grpc.comm.conn_closedcountergRPC connections closed. Open minus closed is the active number of connections.
grpc.comm.conn_openedcountergRPC connections opened. Open minus closed is the active number of connections.
grpc.server.stream_messages_received.%{service}.%{method}counterThe number of stream messages received.
grpc.server.stream_messages_sent.%{service}.%{method}counterThe number of stream messages sent.
grpc.server.stream_request_duration.%{service}.%{method}.%{code}histogramThe time to complete a stream request.
grpc.server.stream_requests_completed.%{service}.%{method}.%{code}counterThe number of stream requests completed.
grpc.server.stream_requests_received.%{service}.%{method}counterThe number of stream requests received.
grpc.server.unary_request_duration.%{service}.%{method}.%{code}histogramThe time to complete a unary request.
grpc.server.unary_requests_completed.%{service}.%{method}.%{code}counterThe number of unary requests completed.
grpc.server.unary_requests_received.%{service}.%{method}counterThe number of unary requests received.
ledger.block_processing_time.%{channel}histogramTime taken in seconds for ledger block processing.
ledger.blockchain_height.%{channel}gaugeHeight of the chain in blocks.
ledger.blockstorage_and_pvtdata_commit_time.%{channel}histogramTime taken in seconds for committing the block and private data to storage.
ledger.blockstorage_commit_time.%{channel}histogramTime taken in seconds for committing the block to storage.
ledger.statedb_commit_time.%{channel}histogramTime taken in seconds for committing block changes to state db.
ledger.transaction_count.%{channel}.%{transaction_type}.%{chaincode}.%{validation_code}counterNumber of transactions processed.
logging.entries_checked.%{level}counterNumber of log entries checked against the active logging level
logging.entries_written.%{level}counterNumber of log entries that are written

如果你对这篇内容有疑问,欢迎到本站社区发帖提问 参与讨论,获取更多帮助,或者扫码二维码加入 Web 技术交流群。

扫码二维码加入Web技术交流群

发布评论

需要 登录 才能够评论, 你可以免费 注册 一个本站的账号。
列表为空,暂无数据
    我们使用 Cookies 和其他技术来定制您的体验包括您的登录状态等。通过阅读我们的 隐私政策 了解更多相关信息。 单击 接受 或继续使用网站,即表示您同意使用 Cookies 和您的相关数据。
    原文