You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@brpc.apache.org by ja...@apache.org on 2020/01/03 05:02:52 UTC

[incubator-brpc] branch master updated (86ca8af -> aba2676)

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

jamesge pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-brpc.git.


    from 86ca8af  removed butil/md5.cc butil/md5.h test/md5_unittest.cc which is replaceable by openssl/md5.h
     new db21017  dos2unix
     new 1ad1cc5  remove authors
     new aba2676  remove authors 2

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 LICENSE                                            |   3 -
 example/grpc_c++/client.cpp                        |   1 -
 example/grpc_c++/server.cpp                        |   2 -
 src/brpc/acceptor.cpp                              |   2 -
 src/brpc/acceptor.h                                |   3 -
 src/brpc/adaptive_connection_type.cpp              |   1 -
 src/brpc/adaptive_connection_type.h                |   1 -
 src/brpc/amf.cpp                                   |   1 -
 src/brpc/amf.h                                     |   1 -
 src/brpc/amf_inl.h                                 |   1 -
 src/brpc/authenticator.h                           |   1 -
 src/brpc/builtin/bad_method_service.cpp            |   1 -
 src/brpc/builtin/bad_method_service.h              |   1 -
 src/brpc/builtin/bthreads_service.cpp              |   1 -
 src/brpc/builtin/bthreads_service.h                |   1 -
 src/brpc/builtin/common.cpp                        |   1 -
 src/brpc/builtin/common.h                          |   1 -
 src/brpc/builtin/connections_service.cpp           |   1 -
 src/brpc/builtin/connections_service.h             |   1 -
 src/brpc/builtin/dir_service.cpp                   |   1 -
 src/brpc/builtin/dir_service.h                     |   1 -
 src/brpc/builtin/flags_service.cpp                 |   1 -
 src/brpc/builtin/flags_service.h                   |   1 -
 src/brpc/builtin/flamegraph_perl.h                 |   1 -
 src/brpc/builtin/flot_min_js.cpp                   |   1 -
 src/brpc/builtin/flot_min_js.h                     |   1 -
 src/brpc/builtin/get_favicon_service.cpp           |   1 -
 src/brpc/builtin/get_favicon_service.h             |   1 -
 src/brpc/builtin/health_service.cpp                |   1 -
 src/brpc/builtin/health_service.h                  |   1 -
 src/brpc/builtin/hotspots_service.cpp              |   2 -
 src/brpc/builtin/hotspots_service.h                |   1 -
 src/brpc/builtin/ids_service.cpp                   |   1 -
 src/brpc/builtin/ids_service.h                     |   1 -
 src/brpc/builtin/index_service.cpp                 |   1 -
 src/brpc/builtin/index_service.h                   |   1 -
 src/brpc/builtin/jquery_min_js.cpp                 |   1 -
 src/brpc/builtin/jquery_min_js.h                   |   1 -
 src/brpc/builtin/list_service.cpp                  |   1 -
 src/brpc/builtin/list_service.h                    |   1 -
 src/brpc/builtin/pprof_perl.cpp                    |   1 -
 src/brpc/builtin/pprof_perl.h                      |   1 -
 src/brpc/builtin/prometheus_metrics_service.cpp    |   1 -
 src/brpc/builtin/prometheus_metrics_service.h      |   1 -
 src/brpc/builtin/protobufs_service.cpp             |   1 -
 src/brpc/builtin/protobufs_service.h               |   1 -
 src/brpc/builtin/rpcz_service.cpp                  |   1 -
 src/brpc/builtin/rpcz_service.h                    |   1 -
 src/brpc/builtin/sockets_service.cpp               |   1 -
 src/brpc/builtin/sockets_service.h                 |   1 -
 src/brpc/builtin/sorttable_js.cpp                  |   1 -
 src/brpc/builtin/sorttable_js.h                    |   1 -
 src/brpc/builtin/status_service.cpp                |   1 -
 src/brpc/builtin/status_service.h                  |   1 -
 src/brpc/builtin/tabbed.h                          |   1 -
 src/brpc/builtin/threads_service.cpp               |   1 -
 src/brpc/builtin/threads_service.h                 |   1 -
 src/brpc/builtin/vars_service.cpp                  |   1 -
 src/brpc/builtin/vars_service.h                    |   1 -
 src/brpc/builtin/version_service.cpp               |   1 -
 src/brpc/builtin/version_service.h                 |   1 -
 src/brpc/builtin/viz_min_js.cpp                    |   1 -
 src/brpc/builtin/viz_min_js.h                      |   1 -
 src/brpc/builtin/vlog_service.cpp                  |   1 -
 src/brpc/builtin/vlog_service.h                    |   1 -
 src/brpc/channel.cpp                               |   3 -
 src/brpc/channel.h                                 |   2 -
 src/brpc/channel_base.h                            |   1 -
 src/brpc/closure_guard.h                           |   1 -
 src/brpc/cluster_recover_policy.cpp                |   1 -
 src/brpc/cluster_recover_policy.h                  |   1 -
 src/brpc/compress.cpp                              |   2 -
 src/brpc/compress.h                                |   2 -
 src/brpc/controller.cpp                            |   3 -
 src/brpc/controller.h                              |   1 -
 src/brpc/data_factory.h                            |   1 -
 src/brpc/describable.h                             |   1 -
 src/brpc/destroyable.h                             |   1 -
 src/brpc/details/has_epollrdhup.cpp                |   1 -
 src/brpc/details/has_epollrdhup.h                  |   1 -
 src/brpc/details/health_check.cpp                  |   2 -
 src/brpc/details/health_check.h                    |   2 -
 src/brpc/details/hpack-static-table.h              |   1 -
 src/brpc/details/hpack.cpp                         |   1 -
 src/brpc/details/hpack.h                           |   1 -
 src/brpc/details/http_message.cpp                  |   2 -
 src/brpc/details/http_message.h                    |   2 -
 src/brpc/details/load_balancer_with_naming.cpp     |   1 -
 src/brpc/details/load_balancer_with_naming.h       |   1 -
 src/brpc/details/mesalink_ssl_helper.cpp           |   1 -
 src/brpc/details/method_status.cpp                 |   1 -
 src/brpc/details/method_status.h                   |   1 -
 src/brpc/details/naming_service_thread.cpp         |   1 -
 src/brpc/details/naming_service_thread.h           |   1 -
 src/brpc/details/profiler_linker.h                 |   1 -
 src/brpc/details/rtmp_utils.cpp                    |   1 -
 src/brpc/details/rtmp_utils.h                      |   1 -
 src/brpc/details/sparse_minute_counter.h           |   1 -
 src/brpc/details/ssl_helper.cpp                    |   1 -
 src/brpc/details/ssl_helper.h                      |   1 -
 src/brpc/details/usercode_backup_pool.cpp          |   1 -
 src/brpc/details/usercode_backup_pool.h            |   1 -
 src/brpc/event_dispatcher.cpp                      |   2 -
 src/brpc/event_dispatcher.h                        |   2 -
 src/brpc/excluded_servers.h                        |   1 -
 src/brpc/extension.h                               |   1 -
 src/brpc/extension_inl.h                           |   1 -
 src/brpc/global.cpp                                |   1 -
 src/brpc/global.h                                  |   1 -
 src/brpc/grpc.cpp                                  |   1 -
 src/brpc/grpc.h                                    |   1 -
 src/brpc/health_reporter.h                         |   1 -
 src/brpc/http_header.cpp                           |   2 -
 src/brpc/http_header.h                             |   2 -
 src/brpc/http_method.cpp                           |   2 -
 src/brpc/http_method.h                             |   2 -
 src/brpc/http_status_code.cpp                      |   1 -
 src/brpc/http_status_code.h                        |   1 -
 src/brpc/input_message_base.h                      |   1 -
 src/brpc/input_messenger.cpp                       |   1 -
 src/brpc/input_messenger.h                         |   1 -
 src/brpc/load_balancer.cpp                         |   1 -
 src/brpc/load_balancer.h                           |   1 -
 src/brpc/memcache.cpp                              |   1 -
 src/brpc/memcache.h                                |   1 -
 src/brpc/naming_service.h                          |   1 -
 src/brpc/naming_service_filter.h                   |   1 -
 src/brpc/nshead_message.cpp                        |   1 -
 src/brpc/nshead_message.h                          |   1 -
 src/brpc/nshead_pb_service_adaptor.cpp             |   1 -
 src/brpc/nshead_pb_service_adaptor.h               |   1 -
 src/brpc/nshead_service.cpp                        |   1 -
 src/brpc/nshead_service.h                          |   1 -
 src/brpc/parallel_channel.cpp                      |   1 -
 src/brpc/parallel_channel.h                        |   1 -
 src/brpc/parse_result.h                            |   1 -
 src/brpc/partition_channel.cpp                     |   1 -
 src/brpc/partition_channel.h                       |   1 -
 src/brpc/periodic_naming_service.cpp               |   1 -
 src/brpc/periodic_naming_service.h                 |   1 -
 src/brpc/periodic_task.cpp                         |   1 -
 src/brpc/periodic_task.h                           |   1 -
 src/brpc/policy/baidu_rpc_protocol.cpp             |   2 -
 src/brpc/policy/baidu_rpc_protocol.h               |   2 -
 .../policy/consistent_hashing_load_balancer.cpp    |   1 -
 src/brpc/policy/consistent_hashing_load_balancer.h |   1 -
 src/brpc/policy/consul_naming_service.cpp          |   1 -
 src/brpc/policy/consul_naming_service.h            |   1 -
 src/brpc/policy/discovery_naming_service.cpp       |   1 -
 src/brpc/policy/discovery_naming_service.h         |   1 -
 src/brpc/policy/domain_naming_service.cpp          |   1 -
 src/brpc/policy/domain_naming_service.h            |   1 -
 src/brpc/policy/dynpart_load_balancer.cpp          |   1 -
 src/brpc/policy/dynpart_load_balancer.h            |   1 -
 src/brpc/policy/file_naming_service.cpp            |   1 -
 src/brpc/policy/file_naming_service.h              |   1 -
 src/brpc/policy/giano_authenticator.cpp            |   1 -
 src/brpc/policy/giano_authenticator.h              |   1 -
 src/brpc/policy/gzip_compress.cpp                  |   1 -
 src/brpc/policy/gzip_compress.h                    |   1 -
 src/brpc/policy/hasher.cpp                         |   1 -
 src/brpc/policy/hasher.h                           |   1 -
 src/brpc/policy/http2_rpc_protocol.cpp             |   2 -
 src/brpc/policy/http2_rpc_protocol.h               |   2 -
 src/brpc/policy/http_rpc_protocol.cpp              |   2 -
 src/brpc/policy/http_rpc_protocol.h                |   2 -
 src/brpc/policy/hulu_pbrpc_controller.h            |   1 -
 src/brpc/policy/hulu_pbrpc_protocol.cpp            |   2 -
 src/brpc/policy/hulu_pbrpc_protocol.h              |   2 -
 src/brpc/policy/list_naming_service.cpp            |   1 -
 src/brpc/policy/list_naming_service.h              |   1 -
 src/brpc/policy/locality_aware_load_balancer.cpp   |   1 -
 src/brpc/policy/locality_aware_load_balancer.h     |   1 -
 src/brpc/policy/memcache_binary_header.h           |   1 -
 src/brpc/policy/memcache_binary_protocol.cpp       |   1 -
 src/brpc/policy/memcache_binary_protocol.h         |   1 -
 src/brpc/policy/most_common_message.h              |   1 -
 src/brpc/policy/nova_pbrpc_protocol.cpp            |   2 -
 src/brpc/policy/nova_pbrpc_protocol.h              |   2 -
 src/brpc/policy/nshead_mcpack_protocol.cpp         |   1 -
 src/brpc/policy/nshead_mcpack_protocol.h           |   1 -
 src/brpc/policy/nshead_protocol.cpp                |   1 -
 src/brpc/policy/nshead_protocol.h                  |   1 -
 src/brpc/policy/public_pbrpc_protocol.cpp          |   1 -
 src/brpc/policy/public_pbrpc_protocol.h            |   1 -
 src/brpc/policy/randomized_load_balancer.cpp       |   1 -
 src/brpc/policy/randomized_load_balancer.h         |   1 -
 src/brpc/policy/redis_protocol.cpp                 |   1 -
 src/brpc/policy/redis_protocol.h                   |   1 -
 src/brpc/policy/remote_file_naming_service.cpp     |   1 -
 src/brpc/policy/remote_file_naming_service.h       |   1 -
 src/brpc/policy/round_robin_load_balancer.cpp      |   1 -
 src/brpc/policy/round_robin_load_balancer.h        |   1 -
 src/brpc/policy/rtmp_protocol.cpp                  |   2 -
 src/brpc/policy/rtmp_protocol.h                    |   2 -
 src/brpc/policy/snappy_compress.cpp                |   1 -
 src/brpc/policy/snappy_compress.h                  |   1 -
 src/brpc/policy/sofa_pbrpc_protocol.cpp            |   1 -
 src/brpc/policy/sofa_pbrpc_protocol.h              |   1 -
 src/brpc/policy/streaming_rpc_protocol.cpp         |   1 -
 src/brpc/policy/streaming_rpc_protocol.h           |   1 -
 src/brpc/policy/thrift_protocol.cpp                |   1 -
 src/brpc/policy/thrift_protocol.h                  |   1 -
 src/brpc/policy/ubrpc2pb_protocol.cpp              |   1 -
 src/brpc/policy/ubrpc2pb_protocol.h                |   1 -
 .../policy/weighted_round_robin_load_balancer.cpp  | 513 ++++++++++-----------
 .../policy/weighted_round_robin_load_balancer.h    |   1 -
 src/brpc/progressive_attachment.cpp                |   2 -
 src/brpc/progressive_attachment.h                  |   1 -
 src/brpc/progressive_reader.h                      |   1 -
 src/brpc/protocol.cpp                              |   2 -
 src/brpc/protocol.h                                |   2 -
 src/brpc/redis.cpp                                 |   1 -
 src/brpc/redis.h                                   |   1 -
 src/brpc/redis_command.cpp                         |   1 -
 src/brpc/redis_command.h                           |   1 -
 src/brpc/redis_reply.cpp                           |   1 -
 src/brpc/redis_reply.h                             |   1 -
 src/brpc/reloadable_flags.cpp                      |   1 -
 src/brpc/reloadable_flags.h                        |   1 -
 src/brpc/restful.cpp                               |   1 -
 src/brpc/restful.h                                 |   1 -
 src/brpc/retry_policy.cpp                          |   1 -
 src/brpc/retry_policy.h                            |   1 -
 src/brpc/rpc_dump.cpp                              |   1 -
 src/brpc/rpc_dump.h                                |   1 -
 src/brpc/rtmp.cpp                                  |   2 -
 src/brpc/rtmp.h                                    |   2 -
 src/brpc/selective_channel.cpp                     |   1 -
 src/brpc/selective_channel.h                       |   1 -
 src/brpc/serialized_request.cpp                    |   1 -
 src/brpc/serialized_request.h                      |   1 -
 src/brpc/server.cpp                                |   3 -
 src/brpc/server.h                                  |   2 -
 src/brpc/server_id.cpp                             |   1 -
 src/brpc/server_id.h                               |   1 -
 src/brpc/shared_object.h                           |   1 -
 src/brpc/simple_data_pool.h                        |   1 -
 src/brpc/socket.cpp                                |   3 -
 src/brpc/socket.h                                  |   3 -
 src/brpc/socket_id.h                               |   1 -
 src/brpc/socket_map.cpp                            |   2 -
 src/brpc/socket_map.h                              |   1 -
 src/brpc/socket_message.h                          |   1 -
 src/brpc/span.cpp                                  |   1 -
 src/brpc/span.h                                    |   1 -
 src/brpc/ssl_options.cpp                           |   1 -
 src/brpc/ssl_options.h                             |   1 -
 src/brpc/stream.cpp                                |   1 -
 src/brpc/stream.h                                  |   1 -
 src/brpc/stream_creator.h                          |   1 -
 src/brpc/stream_impl.h                             |   1 -
 src/brpc/thrift_message.cpp                        |   1 -
 src/brpc/thrift_message.h                          |   1 -
 src/brpc/thrift_service.cpp                        |   1 -
 src/brpc/thrift_service.h                          |   1 -
 src/brpc/traceprintf.h                             |   1 -
 src/brpc/trackme.cpp                               |   1 -
 src/brpc/trackme.h                                 |   1 -
 src/brpc/ts.cpp                                    |   1 -
 src/brpc/ts.h                                      |   1 -
 src/brpc/uri.cpp                                   |   2 -
 src/brpc/uri.h                                     |   2 -
 src/bthread/bthread.cpp                            |   1 -
 src/bthread/bthread.h                              |   1 -
 src/bthread/butex.cpp                              |   1 -
 src/bthread/butex.h                                |   1 -
 src/bthread/comlog_initializer.h                   |   1 -
 src/bthread/condition_variable.cpp                 |   1 -
 src/bthread/condition_variable.h                   |   1 -
 src/bthread/countdown_event.cpp                    |   1 -
 src/bthread/countdown_event.h                      |   1 -
 src/bthread/errno.cpp                              |   1 -
 src/bthread/errno.h                                |   1 -
 src/bthread/execution_queue.cpp                    |   1 -
 src/bthread/execution_queue.h                      |   1 -
 src/bthread/execution_queue_inl.h                  |   1 -
 src/bthread/fd.cpp                                 |   1 -
 src/bthread/id.cpp                                 |   1 -
 src/bthread/id.h                                   |   1 -
 src/bthread/interrupt_pthread.cpp                  |   1 -
 src/bthread/interrupt_pthread.h                    |   1 -
 src/bthread/key.cpp                                |   1 -
 src/bthread/list_of_abafree_id.h                   |   1 -
 src/bthread/log.h                                  |   1 -
 src/bthread/mutex.cpp                              |   1 -
 src/bthread/mutex.h                                |   1 -
 src/bthread/parking_lot.h                          |   1 -
 src/bthread/processor.h                            |   1 -
 src/bthread/remote_task_queue.h                    |   1 -
 src/bthread/stack.cpp                              |   1 -
 src/bthread/stack.h                                |   1 -
 src/bthread/stack_inl.h                            |   1 -
 src/bthread/sys_futex.cpp                          |   1 -
 src/bthread/sys_futex.h                            |   1 -
 src/bthread/task_control.cpp                       |   1 -
 src/bthread/task_control.h                         |   1 -
 src/bthread/task_group.cpp                         |   1 -
 src/bthread/task_group.h                           |   1 -
 src/bthread/task_group_inl.h                       |   1 -
 src/bthread/task_meta.h                            |   1 -
 src/bthread/timer_thread.cpp                       |   1 -
 src/bthread/timer_thread.h                         |   1 -
 src/bthread/types.h                                |   1 -
 src/bthread/unstable.h                             |   1 -
 src/bthread/work_stealing_queue.h                  |   1 -
 src/butil/arena.cpp                                |   1 -
 src/butil/arena.h                                  |   1 -
 src/butil/binary_printer.cpp                       |   1 -
 src/butil/binary_printer.h                         |   1 -
 src/butil/bit_array.h                              |   1 -
 src/butil/class_name.cpp                           |   1 -
 src/butil/class_name.h                             |   1 -
 src/butil/comlog_sink.cc                           |   1 -
 src/butil/comlog_sink.h                            |   1 -
 src/butil/compat.h                                 |   2 -
 src/butil/containers/bounded_queue.h               |   1 -
 src/butil/containers/case_ignored_flat_map.cpp     |   1 -
 src/butil/containers/case_ignored_flat_map.h       |   1 -
 src/butil/containers/doubly_buffered_data.h        |   1 -
 src/butil/containers/flat_map.h                    |   1 -
 src/butil/containers/flat_map_inl.h                |   1 -
 src/butil/containers/pooled_map.h                  |   1 -
 src/butil/endpoint.cpp                             |   1 -
 src/butil/endpoint.h                               |   1 -
 src/butil/errno.cpp                                |   1 -
 src/butil/errno.h                                  |   1 -
 src/butil/fast_rand.cpp                            |   1 -
 src/butil/fast_rand.h                              |   1 -
 src/butil/fd_guard.h                               |   1 -
 src/butil/fd_utility.cpp                           |   1 -
 src/butil/fd_utility.h                             |   1 -
 src/butil/files/dir_reader_unix.h                  |   1 -
 src/butil/files/file_watcher.cpp                   |   1 -
 src/butil/files/file_watcher.h                     |   1 -
 src/butil/files/temp_file.cpp                      |   2 -
 src/butil/files/temp_file.h                        |   2 -
 src/butil/find_cstr.cpp                            |   1 -
 src/butil/find_cstr.h                              |   1 -
 src/butil/iobuf.cpp                                |   1 -
 src/butil/iobuf.h                                  |   1 -
 src/butil/iobuf_inl.h                              |   1 -
 src/butil/logging.cc                               |   1 -
 src/butil/logging.h                                |   1 -
 src/butil/memory/singleton_on_pthread_once.h       |   1 -
 src/butil/object_pool.h                            |   1 -
 src/butil/object_pool_inl.h                        |   1 -
 src/butil/popen.cpp                                |   1 -
 src/butil/popen.h                                  |   1 -
 src/butil/process_util.cc                          |   1 -
 src/butil/process_util.h                           |   1 -
 src/butil/ptr_container.h                          |   1 -
 src/butil/reader_writer.h                          |   1 -
 src/butil/recordio.h                               |   1 -
 src/butil/resource_pool.h                          |   1 -
 src/butil/resource_pool_inl.h                      |   1 -
 src/butil/single_threaded_pool.h                   |   1 -
 src/butil/status.cpp                               |   1 -
 src/butil/string_splitter.h                        |   1 -
 src/butil/string_splitter_inl.h                    |   1 -
 src/butil/synchronous_event.h                      |   1 -
 src/butil/thread_local.cpp                         |   1 -
 src/butil/thread_local.h                           |   1 -
 src/butil/thread_local_inl.h                       |   1 -
 src/butil/time.cpp                                 |   1 -
 src/butil/time.h                                   |   1 -
 src/butil/unix_socket.cpp                          |   1 -
 src/butil/unix_socket.h                            |   1 -
 src/butil/zero_copy_stream_as_streambuf.cpp        |   1 -
 src/butil/zero_copy_stream_as_streambuf.h          |   1 -
 src/bvar/bvar.h                                    |   1 -
 src/bvar/collector.cpp                             |   1 -
 src/bvar/collector.h                               |   1 -
 src/bvar/default_variables.cpp                     |   1 -
 src/bvar/detail/agent_group.h                      |   1 -
 src/bvar/detail/call_op_returning_void.h           |   1 -
 src/bvar/detail/combiner.h                         |   1 -
 src/bvar/detail/percentile.cpp                     |   1 -
 src/bvar/detail/percentile.h                       |   1 -
 src/bvar/detail/sampler.cpp                        |   1 -
 src/bvar/detail/sampler.h                          |   1 -
 src/bvar/detail/series.h                           |   1 -
 src/bvar/gflag.cpp                                 |   1 -
 src/bvar/gflag.h                                   |   1 -
 src/bvar/latency_recorder.cpp                      |   1 -
 src/bvar/latency_recorder.h                        |   1 -
 src/bvar/passive_status.h                          |   1 -
 src/bvar/recorder.h                                |   1 -
 src/bvar/reducer.h                                 |   1 -
 src/bvar/scoped_timer.h                            |   1 -
 src/bvar/status.h                                  |   1 -
 src/bvar/utils/lock_timer.h                        |   1 -
 src/bvar/variable.cpp                              |   1 -
 src/bvar/variable.h                                |   1 -
 src/bvar/vector.h                                  |   1 -
 src/bvar/window.h                                  |   1 -
 src/mcpack2pb/field_type.cpp                       |   1 -
 src/mcpack2pb/field_type.h                         |   1 -
 src/mcpack2pb/generator.cpp                        |   1 -
 src/mcpack2pb/mcpack2pb.cpp                        |   1 -
 src/mcpack2pb/mcpack2pb.h                          |   1 -
 src/mcpack2pb/parser-inl.h                         |   1 -
 src/mcpack2pb/parser.cpp                           |   1 -
 src/mcpack2pb/parser.h                             |   1 -
 src/mcpack2pb/serializer-inl.h                     |   1 -
 src/mcpack2pb/serializer.cpp                       |   1 -
 src/mcpack2pb/serializer.h                         |   1 -
 test/bounded_queue_unittest.cc                     |   1 -
 test/brpc_grpc_protocol_unittest.cpp               |   1 -
 test/bthread_countdown_event_unittest.cpp          |   1 -
 test/bvar_file_dumper_unittest.cpp                 |   1 -
 test/bvar_lock_timer_unittest.cpp                  |   1 -
 test/bvar_percentile_unittest.cpp                  |   1 -
 test/bvar_recorder_unittest.cpp                    |   1 -
 test/bvar_status_unittest.cpp                      |   1 -
 test/bvar_variable_unittest.cpp                    |   1 -
 test/popen_unittest.cpp                            |   1 -
 tools/parallel_http/parallel_http.cpp              |   1 -
 tools/rpc_replay/rpc_replay.cpp                    |   1 -
 tools/rpc_view/rpc_view.cpp                        |   1 -
 tools/trackme_server/trackme_server.cpp            |   1 -
 421 files changed, 256 insertions(+), 731 deletions(-)


---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@brpc.apache.org
For additional commands, e-mail: dev-help@brpc.apache.org


[incubator-brpc] 02/03: remove authors

Posted by ja...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

jamesge pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-brpc.git

commit 1ad1cc57ecc50d4dd631e32781459830f75ca23a
Author: jamesge <jg...@gmail.com>
AuthorDate: Fri Jan 3 13:00:41 2020 +0800

    remove authors
---
 LICENSE                                              | 3 ---
 example/grpc_c++/client.cpp                          | 1 -
 example/grpc_c++/server.cpp                          | 2 --
 src/brpc/acceptor.cpp                                | 2 --
 src/brpc/acceptor.h                                  | 3 ---
 src/brpc/adaptive_connection_type.cpp                | 1 -
 src/brpc/adaptive_connection_type.h                  | 1 -
 src/brpc/amf.cpp                                     | 1 -
 src/brpc/amf.h                                       | 1 -
 src/brpc/amf_inl.h                                   | 1 -
 src/brpc/authenticator.h                             | 1 -
 src/brpc/builtin/bad_method_service.cpp              | 1 -
 src/brpc/builtin/bad_method_service.h                | 1 -
 src/brpc/builtin/bthreads_service.cpp                | 1 -
 src/brpc/builtin/bthreads_service.h                  | 1 -
 src/brpc/builtin/common.cpp                          | 1 -
 src/brpc/builtin/common.h                            | 1 -
 src/brpc/builtin/connections_service.cpp             | 1 -
 src/brpc/builtin/connections_service.h               | 1 -
 src/brpc/builtin/dir_service.cpp                     | 1 -
 src/brpc/builtin/dir_service.h                       | 1 -
 src/brpc/builtin/flags_service.cpp                   | 1 -
 src/brpc/builtin/flags_service.h                     | 1 -
 src/brpc/builtin/flamegraph_perl.h                   | 1 -
 src/brpc/builtin/flot_min_js.cpp                     | 1 -
 src/brpc/builtin/flot_min_js.h                       | 1 -
 src/brpc/builtin/get_favicon_service.cpp             | 1 -
 src/brpc/builtin/get_favicon_service.h               | 1 -
 src/brpc/builtin/health_service.cpp                  | 1 -
 src/brpc/builtin/health_service.h                    | 1 -
 src/brpc/builtin/hotspots_service.cpp                | 2 --
 src/brpc/builtin/hotspots_service.h                  | 1 -
 src/brpc/builtin/ids_service.cpp                     | 1 -
 src/brpc/builtin/ids_service.h                       | 1 -
 src/brpc/builtin/index_service.cpp                   | 1 -
 src/brpc/builtin/index_service.h                     | 1 -
 src/brpc/builtin/jquery_min_js.cpp                   | 1 -
 src/brpc/builtin/jquery_min_js.h                     | 1 -
 src/brpc/builtin/list_service.cpp                    | 1 -
 src/brpc/builtin/list_service.h                      | 1 -
 src/brpc/builtin/pprof_perl.cpp                      | 1 -
 src/brpc/builtin/pprof_perl.h                        | 1 -
 src/brpc/builtin/prometheus_metrics_service.cpp      | 1 -
 src/brpc/builtin/prometheus_metrics_service.h        | 1 -
 src/brpc/builtin/protobufs_service.cpp               | 1 -
 src/brpc/builtin/protobufs_service.h                 | 1 -
 src/brpc/builtin/rpcz_service.cpp                    | 1 -
 src/brpc/builtin/rpcz_service.h                      | 1 -
 src/brpc/builtin/sockets_service.cpp                 | 1 -
 src/brpc/builtin/sockets_service.h                   | 1 -
 src/brpc/builtin/sorttable_js.cpp                    | 1 -
 src/brpc/builtin/sorttable_js.h                      | 1 -
 src/brpc/builtin/status_service.cpp                  | 1 -
 src/brpc/builtin/status_service.h                    | 1 -
 src/brpc/builtin/tabbed.h                            | 1 -
 src/brpc/builtin/threads_service.cpp                 | 1 -
 src/brpc/builtin/threads_service.h                   | 1 -
 src/brpc/builtin/vars_service.cpp                    | 1 -
 src/brpc/builtin/vars_service.h                      | 1 -
 src/brpc/builtin/version_service.cpp                 | 1 -
 src/brpc/builtin/version_service.h                   | 1 -
 src/brpc/builtin/viz_min_js.cpp                      | 1 -
 src/brpc/builtin/viz_min_js.h                        | 1 -
 src/brpc/builtin/vlog_service.cpp                    | 1 -
 src/brpc/builtin/vlog_service.h                      | 1 -
 src/brpc/channel.cpp                                 | 3 ---
 src/brpc/channel.h                                   | 2 --
 src/brpc/channel_base.h                              | 1 -
 src/brpc/closure_guard.h                             | 1 -
 src/brpc/cluster_recover_policy.cpp                  | 1 -
 src/brpc/cluster_recover_policy.h                    | 1 -
 src/brpc/compress.cpp                                | 2 --
 src/brpc/compress.h                                  | 2 --
 src/brpc/controller.cpp                              | 3 ---
 src/brpc/controller.h                                | 1 -
 src/brpc/data_factory.h                              | 1 -
 src/brpc/describable.h                               | 1 -
 src/brpc/destroyable.h                               | 1 -
 src/brpc/details/has_epollrdhup.cpp                  | 1 -
 src/brpc/details/has_epollrdhup.h                    | 1 -
 src/brpc/details/health_check.cpp                    | 2 --
 src/brpc/details/health_check.h                      | 2 --
 src/brpc/details/hpack-static-table.h                | 1 -
 src/brpc/details/hpack.cpp                           | 1 -
 src/brpc/details/hpack.h                             | 1 -
 src/brpc/details/http_message.cpp                    | 2 --
 src/brpc/details/http_message.h                      | 2 --
 src/brpc/details/load_balancer_with_naming.cpp       | 1 -
 src/brpc/details/load_balancer_with_naming.h         | 1 -
 src/brpc/details/mesalink_ssl_helper.cpp             | 1 -
 src/brpc/details/method_status.cpp                   | 1 -
 src/brpc/details/method_status.h                     | 1 -
 src/brpc/details/naming_service_thread.cpp           | 1 -
 src/brpc/details/naming_service_thread.h             | 1 -
 src/brpc/details/profiler_linker.h                   | 1 -
 src/brpc/details/rtmp_utils.cpp                      | 1 -
 src/brpc/details/rtmp_utils.h                        | 1 -
 src/brpc/details/sparse_minute_counter.h             | 1 -
 src/brpc/details/ssl_helper.cpp                      | 1 -
 src/brpc/details/ssl_helper.h                        | 1 -
 src/brpc/details/usercode_backup_pool.cpp            | 1 -
 src/brpc/details/usercode_backup_pool.h              | 1 -
 src/brpc/event_dispatcher.cpp                        | 2 --
 src/brpc/event_dispatcher.h                          | 2 --
 src/brpc/excluded_servers.h                          | 1 -
 src/brpc/extension.h                                 | 1 -
 src/brpc/extension_inl.h                             | 1 -
 src/brpc/global.cpp                                  | 1 -
 src/brpc/global.h                                    | 1 -
 src/brpc/grpc.cpp                                    | 1 -
 src/brpc/grpc.h                                      | 1 -
 src/brpc/health_reporter.h                           | 1 -
 src/brpc/http_header.cpp                             | 2 --
 src/brpc/http_header.h                               | 2 --
 src/brpc/http_method.cpp                             | 2 --
 src/brpc/http_method.h                               | 2 --
 src/brpc/http_status_code.cpp                        | 1 -
 src/brpc/http_status_code.h                          | 1 -
 src/brpc/input_message_base.h                        | 1 -
 src/brpc/input_messenger.cpp                         | 1 -
 src/brpc/input_messenger.h                           | 1 -
 src/brpc/load_balancer.cpp                           | 1 -
 src/brpc/load_balancer.h                             | 1 -
 src/brpc/memcache.cpp                                | 1 -
 src/brpc/memcache.h                                  | 1 -
 src/brpc/naming_service.h                            | 1 -
 src/brpc/naming_service_filter.h                     | 1 -
 src/brpc/nshead_message.cpp                          | 1 -
 src/brpc/nshead_message.h                            | 1 -
 src/brpc/nshead_pb_service_adaptor.cpp               | 1 -
 src/brpc/nshead_pb_service_adaptor.h                 | 1 -
 src/brpc/nshead_service.cpp                          | 1 -
 src/brpc/nshead_service.h                            | 1 -
 src/brpc/parallel_channel.cpp                        | 1 -
 src/brpc/parallel_channel.h                          | 1 -
 src/brpc/parse_result.h                              | 1 -
 src/brpc/partition_channel.cpp                       | 1 -
 src/brpc/partition_channel.h                         | 1 -
 src/brpc/periodic_naming_service.cpp                 | 1 -
 src/brpc/periodic_naming_service.h                   | 1 -
 src/brpc/periodic_task.cpp                           | 1 -
 src/brpc/periodic_task.h                             | 1 -
 src/brpc/policy/baidu_rpc_protocol.cpp               | 2 --
 src/brpc/policy/baidu_rpc_protocol.h                 | 2 --
 src/brpc/policy/consistent_hashing_load_balancer.cpp | 1 -
 src/brpc/policy/consistent_hashing_load_balancer.h   | 1 -
 src/brpc/policy/consul_naming_service.cpp            | 1 -
 src/brpc/policy/consul_naming_service.h              | 1 -
 src/brpc/policy/discovery_naming_service.cpp         | 1 -
 src/brpc/policy/discovery_naming_service.h           | 1 -
 src/brpc/policy/domain_naming_service.cpp            | 1 -
 src/brpc/policy/domain_naming_service.h              | 1 -
 src/brpc/policy/dynpart_load_balancer.cpp            | 1 -
 src/brpc/policy/dynpart_load_balancer.h              | 1 -
 src/brpc/policy/file_naming_service.cpp              | 1 -
 src/brpc/policy/file_naming_service.h                | 1 -
 src/brpc/policy/giano_authenticator.cpp              | 1 -
 src/brpc/policy/giano_authenticator.h                | 1 -
 src/brpc/policy/gzip_compress.cpp                    | 1 -
 src/brpc/policy/gzip_compress.h                      | 1 -
 src/brpc/policy/hasher.cpp                           | 1 -
 src/brpc/policy/hasher.h                             | 1 -
 src/brpc/policy/http2_rpc_protocol.cpp               | 2 --
 src/brpc/policy/http2_rpc_protocol.h                 | 2 --
 src/brpc/policy/http_rpc_protocol.cpp                | 2 --
 src/brpc/policy/http_rpc_protocol.h                  | 2 --
 src/brpc/policy/hulu_pbrpc_controller.h              | 1 -
 src/brpc/policy/hulu_pbrpc_protocol.cpp              | 2 --
 src/brpc/policy/hulu_pbrpc_protocol.h                | 2 --
 src/brpc/policy/list_naming_service.cpp              | 1 -
 src/brpc/policy/list_naming_service.h                | 1 -
 src/brpc/policy/locality_aware_load_balancer.cpp     | 1 -
 src/brpc/policy/locality_aware_load_balancer.h       | 1 -
 src/brpc/policy/memcache_binary_header.h             | 1 -
 src/brpc/policy/memcache_binary_protocol.cpp         | 1 -
 src/brpc/policy/memcache_binary_protocol.h           | 1 -
 src/brpc/policy/most_common_message.h                | 1 -
 src/brpc/policy/nova_pbrpc_protocol.cpp              | 2 --
 src/brpc/policy/nova_pbrpc_protocol.h                | 2 --
 src/brpc/policy/nshead_mcpack_protocol.cpp           | 1 -
 src/brpc/policy/nshead_mcpack_protocol.h             | 1 -
 src/brpc/policy/nshead_protocol.cpp                  | 1 -
 src/brpc/policy/nshead_protocol.h                    | 1 -
 src/brpc/policy/public_pbrpc_protocol.cpp            | 1 -
 src/brpc/policy/public_pbrpc_protocol.h              | 1 -
 src/brpc/policy/randomized_load_balancer.cpp         | 1 -
 src/brpc/policy/randomized_load_balancer.h           | 1 -
 src/brpc/policy/redis_protocol.cpp                   | 1 -
 src/brpc/policy/redis_protocol.h                     | 1 -
 src/brpc/policy/remote_file_naming_service.cpp       | 1 -
 src/brpc/policy/remote_file_naming_service.h         | 1 -
 src/brpc/policy/round_robin_load_balancer.cpp        | 1 -
 src/brpc/policy/round_robin_load_balancer.h          | 1 -
 src/brpc/policy/rtmp_protocol.cpp                    | 2 --
 src/brpc/policy/rtmp_protocol.h                      | 2 --
 src/brpc/policy/snappy_compress.cpp                  | 1 -
 src/brpc/policy/snappy_compress.h                    | 1 -
 src/brpc/policy/sofa_pbrpc_protocol.cpp              | 1 -
 src/brpc/policy/sofa_pbrpc_protocol.h                | 1 -
 src/brpc/policy/streaming_rpc_protocol.cpp           | 1 -
 src/brpc/policy/streaming_rpc_protocol.h             | 1 -
 src/brpc/policy/thrift_protocol.cpp                  | 1 -
 src/brpc/policy/thrift_protocol.h                    | 1 -
 src/brpc/policy/ubrpc2pb_protocol.cpp                | 1 -
 src/brpc/policy/ubrpc2pb_protocol.h                  | 1 -
 src/brpc/policy/weighted_round_robin_load_balancer.h | 1 -
 src/brpc/progressive_attachment.cpp                  | 2 --
 src/brpc/progressive_attachment.h                    | 1 -
 src/brpc/progressive_reader.h                        | 1 -
 src/brpc/protocol.cpp                                | 2 --
 src/brpc/protocol.h                                  | 2 --
 src/brpc/redis.cpp                                   | 1 -
 src/brpc/redis.h                                     | 1 -
 src/brpc/redis_command.cpp                           | 1 -
 src/brpc/redis_command.h                             | 1 -
 src/brpc/redis_reply.cpp                             | 1 -
 src/brpc/redis_reply.h                               | 1 -
 src/brpc/reloadable_flags.cpp                        | 1 -
 src/brpc/reloadable_flags.h                          | 1 -
 src/brpc/restful.cpp                                 | 1 -
 src/brpc/restful.h                                   | 1 -
 src/brpc/retry_policy.cpp                            | 1 -
 src/brpc/retry_policy.h                              | 1 -
 src/brpc/rpc_dump.cpp                                | 1 -
 src/brpc/rpc_dump.h                                  | 1 -
 src/brpc/rtmp.cpp                                    | 2 --
 src/brpc/rtmp.h                                      | 2 --
 src/brpc/selective_channel.cpp                       | 1 -
 src/brpc/selective_channel.h                         | 1 -
 src/brpc/serialized_request.cpp                      | 1 -
 src/brpc/serialized_request.h                        | 1 -
 src/brpc/server.cpp                                  | 3 ---
 src/brpc/server.h                                    | 2 --
 src/brpc/server_id.cpp                               | 1 -
 src/brpc/server_id.h                                 | 1 -
 src/brpc/shared_object.h                             | 1 -
 src/brpc/simple_data_pool.h                          | 1 -
 src/brpc/socket.cpp                                  | 3 ---
 src/brpc/socket.h                                    | 3 ---
 src/brpc/socket_id.h                                 | 1 -
 src/brpc/socket_map.cpp                              | 2 --
 src/brpc/socket_map.h                                | 1 -
 src/brpc/socket_message.h                            | 1 -
 src/brpc/span.cpp                                    | 1 -
 src/brpc/span.h                                      | 1 -
 src/brpc/ssl_options.cpp                             | 1 -
 src/brpc/ssl_options.h                               | 1 -
 src/brpc/stream.cpp                                  | 1 -
 src/brpc/stream.h                                    | 1 -
 src/brpc/stream_creator.h                            | 1 -
 src/brpc/stream_impl.h                               | 1 -
 src/brpc/thrift_message.cpp                          | 1 -
 src/brpc/thrift_message.h                            | 1 -
 src/brpc/thrift_service.cpp                          | 1 -
 src/brpc/thrift_service.h                            | 1 -
 src/brpc/traceprintf.h                               | 1 -
 src/brpc/trackme.cpp                                 | 1 -
 src/brpc/trackme.h                                   | 1 -
 src/brpc/ts.cpp                                      | 1 -
 src/brpc/ts.h                                        | 1 -
 src/brpc/uri.cpp                                     | 2 --
 src/brpc/uri.h                                       | 2 --
 src/bthread/bthread.cpp                              | 1 -
 src/bthread/bthread.h                                | 1 -
 src/bthread/butex.cpp                                | 1 -
 src/bthread/butex.h                                  | 1 -
 src/bthread/comlog_initializer.h                     | 1 -
 src/bthread/condition_variable.cpp                   | 1 -
 src/bthread/condition_variable.h                     | 1 -
 src/bthread/countdown_event.cpp                      | 1 -
 src/bthread/countdown_event.h                        | 1 -
 src/bthread/errno.cpp                                | 1 -
 src/bthread/errno.h                                  | 1 -
 src/bthread/execution_queue.cpp                      | 1 -
 src/bthread/execution_queue.h                        | 1 -
 src/bthread/execution_queue_inl.h                    | 1 -
 src/bthread/fd.cpp                                   | 1 -
 src/bthread/id.cpp                                   | 1 -
 src/bthread/id.h                                     | 1 -
 src/bthread/interrupt_pthread.cpp                    | 1 -
 src/bthread/interrupt_pthread.h                      | 1 -
 src/bthread/key.cpp                                  | 1 -
 src/bthread/list_of_abafree_id.h                     | 1 -
 src/bthread/log.h                                    | 1 -
 src/bthread/mutex.cpp                                | 1 -
 src/bthread/mutex.h                                  | 1 -
 src/bthread/parking_lot.h                            | 1 -
 src/bthread/processor.h                              | 1 -
 src/bthread/remote_task_queue.h                      | 1 -
 src/bthread/stack.cpp                                | 1 -
 src/bthread/stack.h                                  | 1 -
 src/bthread/stack_inl.h                              | 1 -
 src/bthread/sys_futex.cpp                            | 1 -
 src/bthread/sys_futex.h                              | 1 -
 src/bthread/task_control.cpp                         | 1 -
 src/bthread/task_control.h                           | 1 -
 src/bthread/task_group.cpp                           | 1 -
 src/bthread/task_group.h                             | 1 -
 src/bthread/task_group_inl.h                         | 1 -
 src/bthread/task_meta.h                              | 1 -
 src/bthread/timer_thread.cpp                         | 1 -
 src/bthread/timer_thread.h                           | 1 -
 src/bthread/types.h                                  | 1 -
 src/bthread/unstable.h                               | 1 -
 src/bthread/work_stealing_queue.h                    | 1 -
 src/butil/arena.cpp                                  | 1 -
 src/butil/arena.h                                    | 1 -
 src/butil/binary_printer.cpp                         | 1 -
 src/butil/binary_printer.h                           | 1 -
 src/butil/bit_array.h                                | 1 -
 src/butil/class_name.cpp                             | 1 -
 src/butil/class_name.h                               | 1 -
 src/butil/comlog_sink.cc                             | 1 -
 src/butil/comlog_sink.h                              | 1 -
 src/butil/compat.h                                   | 2 --
 src/butil/containers/bounded_queue.h                 | 1 -
 src/butil/containers/case_ignored_flat_map.cpp       | 1 -
 src/butil/containers/case_ignored_flat_map.h         | 1 -
 src/butil/containers/doubly_buffered_data.h          | 1 -
 src/butil/containers/flat_map.h                      | 1 -
 src/butil/containers/flat_map_inl.h                  | 1 -
 src/butil/containers/pooled_map.h                    | 1 -
 src/butil/endpoint.cpp                               | 1 -
 src/butil/endpoint.h                                 | 1 -
 src/butil/errno.cpp                                  | 1 -
 src/butil/errno.h                                    | 1 -
 src/butil/fast_rand.cpp                              | 1 -
 src/butil/fast_rand.h                                | 1 -
 src/butil/fd_guard.h                                 | 1 -
 src/butil/fd_utility.cpp                             | 1 -
 src/butil/fd_utility.h                               | 1 -
 src/butil/files/dir_reader_unix.h                    | 1 -
 src/butil/files/file_watcher.cpp                     | 1 -
 src/butil/files/file_watcher.h                       | 1 -
 src/butil/files/temp_file.cpp                        | 2 --
 src/butil/files/temp_file.h                          | 2 --
 src/butil/find_cstr.cpp                              | 1 -
 src/butil/find_cstr.h                                | 1 -
 src/butil/iobuf.cpp                                  | 1 -
 src/butil/iobuf.h                                    | 1 -
 src/butil/iobuf_inl.h                                | 1 -
 src/butil/logging.cc                                 | 1 -
 src/butil/logging.h                                  | 1 -
 src/butil/memory/singleton_on_pthread_once.h         | 1 -
 src/butil/object_pool.h                              | 1 -
 src/butil/object_pool_inl.h                          | 1 -
 src/butil/popen.cpp                                  | 1 -
 src/butil/popen.h                                    | 1 -
 src/butil/process_util.cc                            | 1 -
 src/butil/process_util.h                             | 1 -
 src/butil/reader_writer.h                            | 1 -
 src/butil/recordio.h                                 | 1 -
 src/butil/resource_pool.h                            | 1 -
 src/butil/resource_pool_inl.h                        | 1 -
 src/butil/single_threaded_pool.h                     | 1 -
 src/butil/status.cpp                                 | 1 -
 src/butil/string_splitter.h                          | 1 -
 src/butil/string_splitter_inl.h                      | 1 -
 src/butil/synchronous_event.h                        | 1 -
 src/butil/thread_local.cpp                           | 1 -
 src/butil/thread_local.h                             | 1 -
 src/butil/thread_local_inl.h                         | 1 -
 src/butil/time.cpp                                   | 1 -
 src/butil/time.h                                     | 1 -
 src/butil/unix_socket.cpp                            | 1 -
 src/butil/unix_socket.h                              | 1 -
 src/butil/zero_copy_stream_as_streambuf.cpp          | 1 -
 src/butil/zero_copy_stream_as_streambuf.h            | 1 -
 src/bvar/bvar.h                                      | 1 -
 src/bvar/collector.cpp                               | 1 -
 src/bvar/collector.h                                 | 1 -
 src/bvar/default_variables.cpp                       | 1 -
 src/bvar/detail/agent_group.h                        | 1 -
 src/bvar/detail/call_op_returning_void.h             | 1 -
 src/bvar/detail/combiner.h                           | 1 -
 src/bvar/detail/percentile.cpp                       | 1 -
 src/bvar/detail/percentile.h                         | 1 -
 src/bvar/detail/sampler.cpp                          | 1 -
 src/bvar/detail/sampler.h                            | 1 -
 src/bvar/detail/series.h                             | 1 -
 src/bvar/gflag.cpp                                   | 1 -
 src/bvar/gflag.h                                     | 1 -
 src/bvar/latency_recorder.cpp                        | 1 -
 src/bvar/latency_recorder.h                          | 1 -
 src/bvar/passive_status.h                            | 1 -
 src/bvar/recorder.h                                  | 1 -
 src/bvar/reducer.h                                   | 1 -
 src/bvar/scoped_timer.h                              | 1 -
 src/bvar/status.h                                    | 1 -
 src/bvar/utils/lock_timer.h                          | 1 -
 src/bvar/variable.cpp                                | 1 -
 src/bvar/variable.h                                  | 1 -
 src/bvar/vector.h                                    | 1 -
 src/bvar/window.h                                    | 1 -
 src/mcpack2pb/field_type.cpp                         | 1 -
 src/mcpack2pb/field_type.h                           | 1 -
 src/mcpack2pb/generator.cpp                          | 1 -
 src/mcpack2pb/mcpack2pb.cpp                          | 1 -
 src/mcpack2pb/mcpack2pb.h                            | 1 -
 src/mcpack2pb/parser-inl.h                           | 1 -
 src/mcpack2pb/parser.cpp                             | 1 -
 src/mcpack2pb/parser.h                               | 1 -
 src/mcpack2pb/serializer-inl.h                       | 1 -
 src/mcpack2pb/serializer.cpp                         | 1 -
 src/mcpack2pb/serializer.h                           | 1 -
 test/bounded_queue_unittest.cc                       | 1 -
 test/brpc_grpc_protocol_unittest.cpp                 | 1 -
 test/bthread_countdown_event_unittest.cpp            | 1 -
 test/bvar_file_dumper_unittest.cpp                   | 1 -
 test/bvar_lock_timer_unittest.cpp                    | 1 -
 test/bvar_percentile_unittest.cpp                    | 1 -
 test/bvar_recorder_unittest.cpp                      | 1 -
 test/bvar_status_unittest.cpp                        | 1 -
 test/bvar_variable_unittest.cpp                      | 1 -
 test/popen_unittest.cpp                              | 1 -
 tools/parallel_http/parallel_http.cpp                | 1 -
 tools/rpc_replay/rpc_replay.cpp                      | 1 -
 tools/rpc_view/rpc_view.cpp                          | 1 -
 tools/trackme_server/trackme_server.cpp              | 1 -
 419 files changed, 473 deletions(-)

diff --git a/LICENSE b/LICENSE
index a3155f4..b789c87 100644
--- a/LICENSE
+++ b/LICENSE
@@ -224,9 +224,6 @@ src/butil/third_party/dynamic_annotations: licensed under the following terms:
   (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
   OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
   
-  ---
-  Author: Kostya Serebryany
-
 --------------------------------------------------------------------------------
 
 src/butil/third_party/icu: licensed under the following terms:
diff --git a/example/grpc_c++/client.cpp b/example/grpc_c++/client.cpp
index 3690b9a..0ce4b90 100644
--- a/example/grpc_c++/client.cpp
+++ b/example/grpc_c++/client.cpp
@@ -16,7 +16,6 @@
 // under the License.
 
 // A client sending requests to server every 1 second using grpc.
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #include <gflags/gflags.h>
 #include <butil/logging.h>
diff --git a/example/grpc_c++/server.cpp b/example/grpc_c++/server.cpp
index a02b83b..b12d01f 100644
--- a/example/grpc_c++/server.cpp
+++ b/example/grpc_c++/server.cpp
@@ -16,8 +16,6 @@
 // under the License.
 
 // A server to receive HelloRequest and send back HelloReply
-//
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #include <gflags/gflags.h>
 #include <butil/logging.h>
diff --git a/src/brpc/acceptor.cpp b/src/brpc/acceptor.cpp
index 1b8d83e..0e12751 100644
--- a/src/brpc/acceptor.cpp
+++ b/src/brpc/acceptor.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang(jiangrujie@baidu.com)
-//          Ge,Jun(gejun@baidu.com)
 
 #include <inttypes.h>
 #include <gflags/gflags.h>
diff --git a/src/brpc/acceptor.h b/src/brpc/acceptor.h
index 2b0e13c..fec220b 100644
--- a/src/brpc/acceptor.h
+++ b/src/brpc/acceptor.h
@@ -15,9 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang(jiangrujie@baidu.com)
-//          Ge,Jun(gejun@baidu.com)
-
 #ifndef BRPC_ACCEPTOR_H
 #define BRPC_ACCEPTOR_H
 
diff --git a/src/brpc/adaptive_connection_type.cpp b/src/brpc/adaptive_connection_type.cpp
index 6ae8a5e..539a177 100644
--- a/src/brpc/adaptive_connection_type.cpp
+++ b/src/brpc/adaptive_connection_type.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/logging.h"
 #include "brpc/adaptive_connection_type.h"
diff --git a/src/brpc/adaptive_connection_type.h b/src/brpc/adaptive_connection_type.h
index 8587f94..36a4954 100644
--- a/src/brpc/adaptive_connection_type.h
+++ b/src/brpc/adaptive_connection_type.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_ADAPTIVE_CONNECTION_TYPE_H
 #define BRPC_ADAPTIVE_CONNECTION_TYPE_H
diff --git a/src/brpc/amf.cpp b/src/brpc/amf.cpp
index 902c839..023eaa9 100644
--- a/src/brpc/amf.cpp
+++ b/src/brpc/amf.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>
 #include "butil/sys_byteorder.h"
diff --git a/src/brpc/amf.h b/src/brpc/amf.h
index 748adee..e9777e8 100644
--- a/src/brpc/amf.h
+++ b/src/brpc/amf.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_AMF_H
 #define BRPC_AMF_H
diff --git a/src/brpc/amf_inl.h b/src/brpc/amf_inl.h
index 881c308..d9d3a56 100644
--- a/src/brpc/amf_inl.h
+++ b/src/brpc/amf_inl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_AMF_INL_H
 #define BRPC_AMF_INL_H
diff --git a/src/brpc/authenticator.h b/src/brpc/authenticator.h
index 3b2fe41..501e427 100644
--- a/src/brpc/authenticator.h
+++ b/src/brpc/authenticator.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_AUTHENTICATOR_H
 #define BRPC_AUTHENTICATOR_H
diff --git a/src/brpc/builtin/bad_method_service.cpp b/src/brpc/builtin/bad_method_service.cpp
index 07da500..346b68d 100644
--- a/src/brpc/builtin/bad_method_service.cpp
+++ b/src/brpc/builtin/bad_method_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #include <ostream>
 #include <vector>
diff --git a/src/brpc/builtin/bad_method_service.h b/src/brpc/builtin/bad_method_service.h
index 5156aab..a127f62 100644
--- a/src/brpc/builtin/bad_method_service.h
+++ b/src/brpc/builtin/bad_method_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_BADMETHOD_SERVICE_H
 #define BRPC_BADMETHOD_SERVICE_H
diff --git a/src/brpc/builtin/bthreads_service.cpp b/src/brpc/builtin/bthreads_service.cpp
index 7c6fba3..209f7a9 100644
--- a/src/brpc/builtin/bthreads_service.cpp
+++ b/src/brpc/builtin/bthreads_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include "brpc/closure_guard.h"        // ClosureGuard
diff --git a/src/brpc/builtin/bthreads_service.h b/src/brpc/builtin/bthreads_service.h
index 7a59604..813a3a0 100644
--- a/src/brpc/builtin/bthreads_service.h
+++ b/src/brpc/builtin/bthreads_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BTHREADS_SERVICE_H
 #define BRPC_BTHREADS_SERVICE_H
diff --git a/src/brpc/builtin/common.cpp b/src/brpc/builtin/common.cpp
index c6b219e..9cdc72f 100644
--- a/src/brpc/builtin/common.cpp
+++ b/src/brpc/builtin/common.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <iomanip>
 #include <sys/time.h>
diff --git a/src/brpc/builtin/common.h b/src/brpc/builtin/common.h
index 71b5232..f4d6962 100644
--- a/src/brpc/builtin/common.h
+++ b/src/brpc/builtin/common.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_COMMON_H
 #define BRPC_BUILTIN_COMMON_H
diff --git a/src/brpc/builtin/connections_service.cpp b/src/brpc/builtin/connections_service.cpp
index 21860c1..fdef0e6 100644
--- a/src/brpc/builtin/connections_service.cpp
+++ b/src/brpc/builtin/connections_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include <iomanip>
diff --git a/src/brpc/builtin/connections_service.h b/src/brpc/builtin/connections_service.h
index 96cdb4f..57eaae4 100644
--- a/src/brpc/builtin/connections_service.h
+++ b/src/brpc/builtin/connections_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_CONNECTIONS_SERVICE_H
 #define BRPC_CONNECTIONS_SERVICE_H
diff --git a/src/brpc/builtin/dir_service.cpp b/src/brpc/builtin/dir_service.cpp
index da55ed7..98973b9 100644
--- a/src/brpc/builtin/dir_service.cpp
+++ b/src/brpc/builtin/dir_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include <dirent.h>                    // opendir
diff --git a/src/brpc/builtin/dir_service.h b/src/brpc/builtin/dir_service.h
index 20c4794..40fd54c 100644
--- a/src/brpc/builtin/dir_service.h
+++ b/src/brpc/builtin/dir_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_DIR_SERVICE_H
 #define BRPC_DIR_SERVICE_H
diff --git a/src/brpc/builtin/flags_service.cpp b/src/brpc/builtin/flags_service.cpp
index b820152..27ad5bc 100644
--- a/src/brpc/builtin/flags_service.cpp
+++ b/src/brpc/builtin/flags_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include <vector>                           // std::vector
diff --git a/src/brpc/builtin/flags_service.h b/src/brpc/builtin/flags_service.h
index ec8df22..c7d9d99 100644
--- a/src/brpc/builtin/flags_service.h
+++ b/src/brpc/builtin/flags_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_FLAGS_SERVICE_H
 #define BRPC_FLAGS_SERVICE_H
diff --git a/src/brpc/builtin/flamegraph_perl.h b/src/brpc/builtin/flamegraph_perl.h
index 406cc56..964ec5b 100644
--- a/src/brpc/builtin/flamegraph_perl.h
+++ b/src/brpc/builtin/flamegraph_perl.h
@@ -14,7 +14,6 @@
 // KIND, either express or implied.  See the License for the
 // specific language governing permissions and limitations
 // under the License.
-// Authors: Tian,Ye (tianye15@baidu.com)
 
 #pragma once
 
diff --git a/src/brpc/builtin/flot_min_js.cpp b/src/brpc/builtin/flot_min_js.cpp
index bfcb1f5..a123b4b 100644
--- a/src/brpc/builtin/flot_min_js.cpp
+++ b/src/brpc/builtin/flot_min_js.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <pthread.h>
 #include "butil/logging.h"
diff --git a/src/brpc/builtin/flot_min_js.h b/src/brpc/builtin/flot_min_js.h
index 1014554..63a9db5 100644
--- a/src/brpc/builtin/flot_min_js.h
+++ b/src/brpc/builtin/flot_min_js.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_FLOT_MIN_JS_H
 #define BRPC_BUILTIN_FLOT_MIN_JS_H
diff --git a/src/brpc/builtin/get_favicon_service.cpp b/src/brpc/builtin/get_favicon_service.cpp
index f8ab437..64b0d70 100644
--- a/src/brpc/builtin/get_favicon_service.cpp
+++ b/src/brpc/builtin/get_favicon_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include "butil/macros.h"                           // ARRAY_SIZE
 #include "butil/iobuf.h"                            // butil::IOBuf
diff --git a/src/brpc/builtin/get_favicon_service.h b/src/brpc/builtin/get_favicon_service.h
index 4205bb5..318aeff 100644
--- a/src/brpc/builtin/get_favicon_service.h
+++ b/src/brpc/builtin/get_favicon_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_GET_FAVICON_SERVICE_H
 #define  BRPC_GET_FAVICON_SERVICE_H
diff --git a/src/brpc/builtin/health_service.cpp b/src/brpc/builtin/health_service.cpp
index 503a38e..d45b2a3 100644
--- a/src/brpc/builtin/health_service.cpp
+++ b/src/brpc/builtin/health_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/controller.h"           // Controller
 #include "brpc/server.h"               // Server
diff --git a/src/brpc/builtin/health_service.h b/src/brpc/builtin/health_service.h
index 9c26d67..7451e97 100644
--- a/src/brpc/builtin/health_service.h
+++ b/src/brpc/builtin/health_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_HEALTH_SERVICE_H
 #define  BRPC_HEALTH_SERVICE_H
diff --git a/src/brpc/builtin/hotspots_service.cpp b/src/brpc/builtin/hotspots_service.cpp
index ad56eeb..5961274 100644
--- a/src/brpc/builtin/hotspots_service.cpp
+++ b/src/brpc/builtin/hotspots_service.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Tian,Ye(tianye15@baidu.com)
 
 #include <stdio.h>
 #include <thread>
diff --git a/src/brpc/builtin/hotspots_service.h b/src/brpc/builtin/hotspots_service.h
index 56fe4ea..23696ee 100644
--- a/src/brpc/builtin/hotspots_service.h
+++ b/src/brpc/builtin/hotspots_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_HOTSPOTS_SERVICE_H
 #define BRPC_HOTSPOTS_SERVICE_H
diff --git a/src/brpc/builtin/ids_service.cpp b/src/brpc/builtin/ids_service.cpp
index 6646b05..ba6a25f 100644
--- a/src/brpc/builtin/ids_service.cpp
+++ b/src/brpc/builtin/ids_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include "brpc/closure_guard.h"        // ClosureGuard
diff --git a/src/brpc/builtin/ids_service.h b/src/brpc/builtin/ids_service.h
index 0e3b172..f645a9e 100644
--- a/src/brpc/builtin/ids_service.h
+++ b/src/brpc/builtin/ids_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_IDS_SERVICE_H
 #define BRPC_IDS_SERVICE_H
diff --git a/src/brpc/builtin/index_service.cpp b/src/brpc/builtin/index_service.cpp
index feccfdb..f067b55 100644
--- a/src/brpc/builtin/index_service.cpp
+++ b/src/brpc/builtin/index_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>                  // DECLARE_xxx
 #include <google/protobuf/descriptor.h>
diff --git a/src/brpc/builtin/index_service.h b/src/brpc/builtin/index_service.h
index d5e4af5..f7e2b68 100644
--- a/src/brpc/builtin/index_service.h
+++ b/src/brpc/builtin/index_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_INDEX_SERVICE_H
 #define  BRPC_INDEX_SERVICE_H
diff --git a/src/brpc/builtin/jquery_min_js.cpp b/src/brpc/builtin/jquery_min_js.cpp
index a795acd..818e399 100644
--- a/src/brpc/builtin/jquery_min_js.cpp
+++ b/src/brpc/builtin/jquery_min_js.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <pthread.h>
 #include "butil/logging.h"
diff --git a/src/brpc/builtin/jquery_min_js.h b/src/brpc/builtin/jquery_min_js.h
index ed4893d..dc6b9ce 100644
--- a/src/brpc/builtin/jquery_min_js.h
+++ b/src/brpc/builtin/jquery_min_js.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_JQUERY_MIN_JS_H
 #define BRPC_BUILTIN_JQUERY_MIN_JS_H
diff --git a/src/brpc/builtin/list_service.cpp b/src/brpc/builtin/list_service.cpp
index bbd694d..17fa941 100644
--- a/src/brpc/builtin/list_service.cpp
+++ b/src/brpc/builtin/list_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <vector>                           // std::vector
 #include <google/protobuf/descriptor.h>     // ServiceDescriptor
diff --git a/src/brpc/builtin/list_service.h b/src/brpc/builtin/list_service.h
index 192addb..fafb419 100644
--- a/src/brpc/builtin/list_service.h
+++ b/src/brpc/builtin/list_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_LIST_SERVICE_H
 #define  BRPC_LIST_SERVICE_H
diff --git a/src/brpc/builtin/pprof_perl.cpp b/src/brpc/builtin/pprof_perl.cpp
index 7496cb9..1ea5903 100644
--- a/src/brpc/builtin/pprof_perl.cpp
+++ b/src/brpc/builtin/pprof_perl.cpp
@@ -26,7 +26,6 @@
 // (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
 // OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/builtin/pprof_perl.h"
 
diff --git a/src/brpc/builtin/pprof_perl.h b/src/brpc/builtin/pprof_perl.h
index e86c78d..bb6d79d 100644
--- a/src/brpc/builtin/pprof_perl.h
+++ b/src/brpc/builtin/pprof_perl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_PPROF_PERL_H
 #define BRPC_BUILTIN_PPROF_PERL_H
diff --git a/src/brpc/builtin/prometheus_metrics_service.cpp b/src/brpc/builtin/prometheus_metrics_service.cpp
index b050c82..5eddb1a 100644
--- a/src/brpc/builtin/prometheus_metrics_service.cpp
+++ b/src/brpc/builtin/prometheus_metrics_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #include <vector>
 #include <iomanip>
diff --git a/src/brpc/builtin/prometheus_metrics_service.h b/src/brpc/builtin/prometheus_metrics_service.h
index 809da24..c844e1e 100644
--- a/src/brpc/builtin/prometheus_metrics_service.h
+++ b/src/brpc/builtin/prometheus_metrics_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #ifndef BRPC_PROMETHEUS_METRICS_SERVICE_H
 #define BRPC_PROMETHEUS_METRICS_SERVICE_H
diff --git a/src/brpc/builtin/protobufs_service.cpp b/src/brpc/builtin/protobufs_service.cpp
index e4679e2..2344e46 100644
--- a/src/brpc/builtin/protobufs_service.cpp
+++ b/src/brpc/builtin/protobufs_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>     // ServiceDescriptor
 #include "brpc/controller.h"           // Controller
diff --git a/src/brpc/builtin/protobufs_service.h b/src/brpc/builtin/protobufs_service.h
index 05ea13a..2f0c597 100644
--- a/src/brpc/builtin/protobufs_service.h
+++ b/src/brpc/builtin/protobufs_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_PROTOBUFS_SERVICE_H
 #define  BRPC_PROTOBUFS_SERVICE_H
diff --git a/src/brpc/builtin/rpcz_service.cpp b/src/brpc/builtin/rpcz_service.cpp
index 6a21a47..d4374e4 100644
--- a/src/brpc/builtin/rpcz_service.cpp
+++ b/src/brpc/builtin/rpcz_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include <iomanip>
diff --git a/src/brpc/builtin/rpcz_service.h b/src/brpc/builtin/rpcz_service.h
index 94b3f32..3254050 100644
--- a/src/brpc/builtin/rpcz_service.h
+++ b/src/brpc/builtin/rpcz_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_RPCZ_SERVICE_H
 #define BRPC_RPCZ_SERVICE_H
diff --git a/src/brpc/builtin/sockets_service.cpp b/src/brpc/builtin/sockets_service.cpp
index 53b9a4b..deedf65 100644
--- a/src/brpc/builtin/sockets_service.cpp
+++ b/src/brpc/builtin/sockets_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include "brpc/closure_guard.h"        // ClosureGuard
diff --git a/src/brpc/builtin/sockets_service.h b/src/brpc/builtin/sockets_service.h
index 5d329e4..ff9926b 100644
--- a/src/brpc/builtin/sockets_service.h
+++ b/src/brpc/builtin/sockets_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SOCKETS_SERVICE_H
 #define BRPC_SOCKETS_SERVICE_H
diff --git a/src/brpc/builtin/sorttable_js.cpp b/src/brpc/builtin/sorttable_js.cpp
index ef705c0..a37bac7 100644
--- a/src/brpc/builtin/sorttable_js.cpp
+++ b/src/brpc/builtin/sorttable_js.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <pthread.h>
 #include "brpc/builtin/sorttable_js.h"
diff --git a/src/brpc/builtin/sorttable_js.h b/src/brpc/builtin/sorttable_js.h
index ef9b2dc..01026b4 100644
--- a/src/brpc/builtin/sorttable_js.h
+++ b/src/brpc/builtin/sorttable_js.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_SORTTABLE_JS_H
 #define BRPC_BUILTIN_SORTTABLE_JS_H
diff --git a/src/brpc/builtin/status_service.cpp b/src/brpc/builtin/status_service.cpp
index fc0f5ee..0a2ca7c 100644
--- a/src/brpc/builtin/status_service.cpp
+++ b/src/brpc/builtin/status_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include <google/protobuf/descriptor.h>     // ServiceDescriptor
diff --git a/src/brpc/builtin/status_service.h b/src/brpc/builtin/status_service.h
index ffb19aa..4058b7f 100644
--- a/src/brpc/builtin/status_service.h
+++ b/src/brpc/builtin/status_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_STATUS_SERVICE_H
 #define  BRPC_STATUS_SERVICE_H
diff --git a/src/brpc/builtin/tabbed.h b/src/brpc/builtin/tabbed.h
index 0b1ebd7..a6755e1 100644
--- a/src/brpc/builtin/tabbed.h
+++ b/src/brpc/builtin/tabbed.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_TABBED_H
 #define BRPC_BUILTIN_TABBED_H
diff --git a/src/brpc/builtin/threads_service.cpp b/src/brpc/builtin/threads_service.cpp
index ad49e9d..458c1c3 100644
--- a/src/brpc/builtin/threads_service.cpp
+++ b/src/brpc/builtin/threads_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/time.h"
 #include "butil/logging.h"
diff --git a/src/brpc/builtin/threads_service.h b/src/brpc/builtin/threads_service.h
index dedd8b7..d9978e1 100644
--- a/src/brpc/builtin/threads_service.h
+++ b/src/brpc/builtin/threads_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_THREADS_SERVICE_H
 #define  BRPC_THREADS_SERVICE_H
diff --git a/src/brpc/builtin/vars_service.cpp b/src/brpc/builtin/vars_service.cpp
index bfbf720..f60c49f 100644
--- a/src/brpc/builtin/vars_service.cpp
+++ b/src/brpc/builtin/vars_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <ostream>
 #include <vector>                           // std::vector
diff --git a/src/brpc/builtin/vars_service.h b/src/brpc/builtin/vars_service.h
index 457622c..ed5e1f1 100644
--- a/src/brpc/builtin/vars_service.h
+++ b/src/brpc/builtin/vars_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_VARS_SERVICE_H
 #define BRPC_VARS_SERVICE_H
diff --git a/src/brpc/builtin/version_service.cpp b/src/brpc/builtin/version_service.cpp
index b4681bf..fed6dc2 100644
--- a/src/brpc/builtin/version_service.cpp
+++ b/src/brpc/builtin/version_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/controller.h"           // Controller
 #include "brpc/server.h"               // Server
diff --git a/src/brpc/builtin/version_service.h b/src/brpc/builtin/version_service.h
index c0ce8c3..eeccd7b 100644
--- a/src/brpc/builtin/version_service.h
+++ b/src/brpc/builtin/version_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_VERSION_SERVICE_H
 #define  BRPC_VERSION_SERVICE_H
diff --git a/src/brpc/builtin/viz_min_js.cpp b/src/brpc/builtin/viz_min_js.cpp
index 987f8d2..36970ef 100644
--- a/src/brpc/builtin/viz_min_js.cpp
+++ b/src/brpc/builtin/viz_min_js.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <pthread.h>
 #include "butil/logging.h"
diff --git a/src/brpc/builtin/viz_min_js.h b/src/brpc/builtin/viz_min_js.h
index ad0fe8e..8791f6b 100644
--- a/src/brpc/builtin/viz_min_js.h
+++ b/src/brpc/builtin/viz_min_js.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_BUILTIN_VIZ_MIN_JS_H
 #define BRPC_BUILTIN_VIZ_MIN_JS_H
diff --git a/src/brpc/builtin/vlog_service.cpp b/src/brpc/builtin/vlog_service.cpp
index 1b60560..2980d0b 100644
--- a/src/brpc/builtin/vlog_service.cpp
+++ b/src/brpc/builtin/vlog_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #if !BRPC_WITH_GLOG
 
diff --git a/src/brpc/builtin/vlog_service.h b/src/brpc/builtin/vlog_service.h
index 7398144..ce717df 100644
--- a/src/brpc/builtin/vlog_service.h
+++ b/src/brpc/builtin/vlog_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_VLOG_SERVICE_H
 #define  BRPC_VLOG_SERVICE_H
diff --git a/src/brpc/channel.cpp b/src/brpc/channel.cpp
index d960436..2b9f581 100755
--- a/src/brpc/channel.cpp
+++ b/src/brpc/channel.cpp
@@ -15,9 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang(jiangrujie@baidu.com)
-//          Zhangyi Chen(chenzhangyi01@baidu.com)
 
 #include <inttypes.h>
 #include <google/protobuf/descriptor.h>
diff --git a/src/brpc/channel.h b/src/brpc/channel.h
index 9b87869..684e8f1 100644
--- a/src/brpc/channel.h
+++ b/src/brpc/channel.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_CHANNEL_H
 #define BRPC_CHANNEL_H
diff --git a/src/brpc/channel_base.h b/src/brpc/channel_base.h
index 3a46c87..ed6ff24 100644
--- a/src/brpc/channel_base.h
+++ b/src/brpc/channel_base.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_CHANNEL_BASE_H
 #define BRPC_CHANNEL_BASE_H
diff --git a/src/brpc/closure_guard.h b/src/brpc/closure_guard.h
index 9e31800..c1405b5 100644
--- a/src/brpc/closure_guard.h
+++ b/src/brpc/closure_guard.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_CLOSURE_GUARD_H
 #define BRPC_CLOSURE_GUARD_H
diff --git a/src/brpc/cluster_recover_policy.cpp b/src/brpc/cluster_recover_policy.cpp
index aef4754..d1338f6 100644
--- a/src/brpc/cluster_recover_policy.cpp
+++ b/src/brpc/cluster_recover_policy.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #include <vector>
 #include <gflags/gflags.h>
diff --git a/src/brpc/cluster_recover_policy.h b/src/brpc/cluster_recover_policy.h
index 616feb7..fe492aa 100644
--- a/src/brpc/cluster_recover_policy.h
+++ b/src/brpc/cluster_recover_policy.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #ifndef BRPC_CLUSTER_RECOVER_POLICY
 #define BRPC_CLUSTER_RECOVER_POLICY
diff --git a/src/brpc/compress.cpp b/src/brpc/compress.cpp
index 18bd1a4..dd9ba82 100644
--- a/src/brpc/compress.cpp
+++ b/src/brpc/compress.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include "butil/logging.h"
 #include "brpc/compress.h"
diff --git a/src/brpc/compress.h b/src/brpc/compress.h
index 20324b6..0b0fcb1 100644
--- a/src/brpc/compress.h
+++ b/src/brpc/compress.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_COMPRESS_H
 #define BRPC_COMPRESS_H
diff --git a/src/brpc/controller.cpp b/src/brpc/controller.cpp
index 890fea2..8455508 100644
--- a/src/brpc/controller.cpp
+++ b/src/brpc/controller.cpp
@@ -15,9 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang(jiangrujie@baidu.com)
-//          Zhangyi Chen(chenzhangyi01@baidu.com)
 
 #include <signal.h>
 #include <openssl/md5.h>
diff --git a/src/brpc/controller.h b/src/brpc/controller.h
index 32e3808..69b3f48 100755
--- a/src/brpc/controller.h
+++ b/src/brpc/controller.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_CONTROLLER_H
 #define BRPC_CONTROLLER_H
diff --git a/src/brpc/data_factory.h b/src/brpc/data_factory.h
index e825d36..4fd8bf5 100644
--- a/src/brpc/data_factory.h
+++ b/src/brpc/data_factory.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_DATA_FACTORY_H
 #define BRPC_DATA_FACTORY_H
diff --git a/src/brpc/describable.h b/src/brpc/describable.h
index 9acd9a0..9cb7b75 100644
--- a/src/brpc/describable.h
+++ b/src/brpc/describable.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_DESCRIBABLE_H
 #define BRPC_DESCRIBABLE_H
diff --git a/src/brpc/destroyable.h b/src/brpc/destroyable.h
index 26744be..d37f45d 100644
--- a/src/brpc/destroyable.h
+++ b/src/brpc/destroyable.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_DESTROYABLE_H
 #define BRPC_DESTROYABLE_H
diff --git a/src/brpc/details/has_epollrdhup.cpp b/src/brpc/details/has_epollrdhup.cpp
index 0180545..dd085ad 100644
--- a/src/brpc/details/has_epollrdhup.cpp
+++ b/src/brpc/details/has_epollrdhup.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/build_config.h"
 
diff --git a/src/brpc/details/has_epollrdhup.h b/src/brpc/details/has_epollrdhup.h
index 18f2f4d..059acd4 100644
--- a/src/brpc/details/has_epollrdhup.h
+++ b/src/brpc/details/has_epollrdhup.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_HAS_EPOLLRDHUP_H
 #define BRPC_HAS_EPOLLRDHUP_H
diff --git a/src/brpc/details/health_check.cpp b/src/brpc/details/health_check.cpp
index 1a7fce8..6cb5f47 100644
--- a/src/brpc/details/health_check.cpp
+++ b/src/brpc/details/health_check.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu(zhujiashun@baidu.com)
 
 #include "brpc/details/health_check.h"
 #include "brpc/socket.h"
diff --git a/src/brpc/details/health_check.h b/src/brpc/details/health_check.h
index 933b633..5a20756 100644
--- a/src/brpc/details/health_check.h
+++ b/src/brpc/details/health_check.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu(zhujiashun@baidu.com)
 
 #ifndef _HEALTH_CHECK_H
 #define _HEALTH_CHECK_H
diff --git a/src/brpc/details/hpack-static-table.h b/src/brpc/details/hpack-static-table.h
index 768d265..08abc3d 100644
--- a/src/brpc/details/hpack-static-table.h
+++ b/src/brpc/details/hpack-static-table.h
@@ -18,7 +18,6 @@
 // Intentionally no header guard
 
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 namespace brpc {
 
diff --git a/src/brpc/details/hpack.cpp b/src/brpc/details/hpack.cpp
index fa2c736..43a2d9e 100644
--- a/src/brpc/details/hpack.cpp
+++ b/src/brpc/details/hpack.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include "brpc/details/hpack.h"
 
diff --git a/src/brpc/details/hpack.h b/src/brpc/details/hpack.h
index 98934c2..05a5f30 100644
--- a/src/brpc/details/hpack.h
+++ b/src/brpc/details/hpack.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_HPACK_H
 #define  BRPC_HPACK_H
diff --git a/src/brpc/details/http_message.cpp b/src/brpc/details/http_message.cpp
index ca17925..96bb326 100644
--- a/src/brpc/details/http_message.cpp
+++ b/src/brpc/details/http_message.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include <cstdlib>
 
diff --git a/src/brpc/details/http_message.h b/src/brpc/details/http_message.h
index 26684f8..548f61f 100644
--- a/src/brpc/details/http_message.h
+++ b/src/brpc/details/http_message.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_HTTP_MESSAGE_H
 #define BRPC_HTTP_MESSAGE_H
diff --git a/src/brpc/details/load_balancer_with_naming.cpp b/src/brpc/details/load_balancer_with_naming.cpp
index b8147ea..2fad84b 100644
--- a/src/brpc/details/load_balancer_with_naming.cpp
+++ b/src/brpc/details/load_balancer_with_naming.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/details/load_balancer_with_naming.h"
 
diff --git a/src/brpc/details/load_balancer_with_naming.h b/src/brpc/details/load_balancer_with_naming.h
index e79de4f..9364d84 100644
--- a/src/brpc/details/load_balancer_with_naming.h
+++ b/src/brpc/details/load_balancer_with_naming.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_LOAD_BALANCER_WITH_NAMING_H
 #define BRPC_LOAD_BALANCER_WITH_NAMING_H
diff --git a/src/brpc/details/mesalink_ssl_helper.cpp b/src/brpc/details/mesalink_ssl_helper.cpp
index d3c3517..96b9cf5 100644
--- a/src/brpc/details/mesalink_ssl_helper.cpp
+++ b/src/brpc/details/mesalink_ssl_helper.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Yiming Jing (jingyijming@baidu.com)
 
 #ifdef USE_MESALINK
 
diff --git a/src/brpc/details/method_status.cpp b/src/brpc/details/method_status.cpp
index 7609aed..faf6449 100644
--- a/src/brpc/details/method_status.cpp
+++ b/src/brpc/details/method_status.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <limits>
 #include "butil/macros.h"
diff --git a/src/brpc/details/method_status.h b/src/brpc/details/method_status.h
index 05ffc53..094e895 100644
--- a/src/brpc/details/method_status.h
+++ b/src/brpc/details/method_status.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_METHOD_STATUS_H
 #define  BRPC_METHOD_STATUS_H
diff --git a/src/brpc/details/naming_service_thread.cpp b/src/brpc/details/naming_service_thread.cpp
index abe9b4c..6104451 100644
--- a/src/brpc/details/naming_service_thread.cpp
+++ b/src/brpc/details/naming_service_thread.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <set>
 #include <pthread.h>
diff --git a/src/brpc/details/naming_service_thread.h b/src/brpc/details/naming_service_thread.h
index 57ef7c9..90dd004 100644
--- a/src/brpc/details/naming_service_thread.h
+++ b/src/brpc/details/naming_service_thread.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_NAMING_SERVICE_THREAD_H
 #define BRPC_NAMING_SERVICE_THREAD_H
diff --git a/src/brpc/details/profiler_linker.h b/src/brpc/details/profiler_linker.h
index 3a33b37..8df0197 100644
--- a/src/brpc/details/profiler_linker.h
+++ b/src/brpc/details/profiler_linker.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PROFILER_LINKER_H
 #define BRPC_PROFILER_LINKER_H
diff --git a/src/brpc/details/rtmp_utils.cpp b/src/brpc/details/rtmp_utils.cpp
index 47736cb..ea37636 100644
--- a/src/brpc/details/rtmp_utils.cpp
+++ b/src/brpc/details/rtmp_utils.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/details/rtmp_utils.h"
 
diff --git a/src/brpc/details/rtmp_utils.h b/src/brpc/details/rtmp_utils.h
index 20dbf4e..f1d46fc 100644
--- a/src/brpc/details/rtmp_utils.h
+++ b/src/brpc/details/rtmp_utils.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_DETAILS_RTMP_UTILS_H
 #define BRPC_DETAILS_RTMP_UTILS_H
diff --git a/src/brpc/details/sparse_minute_counter.h b/src/brpc/details/sparse_minute_counter.h
index ffc97d6..3834afa 100644
--- a/src/brpc/details/sparse_minute_counter.h
+++ b/src/brpc/details/sparse_minute_counter.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SPARSE_MINUTE_COUNTER_H
 #define BRPC_SPARSE_MINUTE_COUNTER_H
diff --git a/src/brpc/details/ssl_helper.cpp b/src/brpc/details/ssl_helper.cpp
index 07263fb..1495a71 100644
--- a/src/brpc/details/ssl_helper.cpp
+++ b/src/brpc/details/ssl_helper.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 
 #ifndef USE_MESALINK
diff --git a/src/brpc/details/ssl_helper.h b/src/brpc/details/ssl_helper.h
index e946de5..8f09aae 100644
--- a/src/brpc/details/ssl_helper.h
+++ b/src/brpc/details/ssl_helper.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_SSL_HELPER_H
 #define BRPC_SSL_HELPER_H
diff --git a/src/brpc/details/usercode_backup_pool.cpp b/src/brpc/details/usercode_backup_pool.cpp
index 4b1e71a..53a1541 100644
--- a/src/brpc/details/usercode_backup_pool.cpp
+++ b/src/brpc/details/usercode_backup_pool.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <deque>
 #include <vector>
diff --git a/src/brpc/details/usercode_backup_pool.h b/src/brpc/details/usercode_backup_pool.h
index 1dfde9c..e53752f 100644
--- a/src/brpc/details/usercode_backup_pool.h
+++ b/src/brpc/details/usercode_backup_pool.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_USERCODE_BACKUP_POOL_H
 #define  BRPC_USERCODE_BACKUP_POOL_H
diff --git a/src/brpc/event_dispatcher.cpp b/src/brpc/event_dispatcher.cpp
index fb0c29d..9cf2249 100644
--- a/src/brpc/event_dispatcher.cpp
+++ b/src/brpc/event_dispatcher.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 #include <gflags/gflags.h>                            // DEFINE_int32
 #include "butil/compat.h"
diff --git a/src/brpc/event_dispatcher.h b/src/brpc/event_dispatcher.h
index bda4d81..b6cae40 100644
--- a/src/brpc/event_dispatcher.h
+++ b/src/brpc/event_dispatcher.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_EVENT_DISPATCHER_H
 #define BRPC_EVENT_DISPATCHER_H
diff --git a/src/brpc/excluded_servers.h b/src/brpc/excluded_servers.h
index 04f347e..ad095f4 100644
--- a/src/brpc/excluded_servers.h
+++ b/src/brpc/excluded_servers.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_EXCLUDED_SERVERS_H
 #define BRPC_EXCLUDED_SERVERS_H
diff --git a/src/brpc/extension.h b/src/brpc/extension.h
index becaa34..9d6c94b 100644
--- a/src/brpc/extension.h
+++ b/src/brpc/extension.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_EXTENSION_H
 #define BRPC_EXTENSION_H
diff --git a/src/brpc/extension_inl.h b/src/brpc/extension_inl.h
index 5072e1d..8eede30 100644
--- a/src/brpc/extension_inl.h
+++ b/src/brpc/extension_inl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_EXTENSION_INL_H
 #define BRPC_EXTENSION_INL_H
diff --git a/src/brpc/global.cpp b/src/brpc/global.cpp
index 5205b3d..3bd13ec 100755
--- a/src/brpc/global.cpp
+++ b/src/brpc/global.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef USE_MESALINK
 #include <openssl/ssl.h>
diff --git a/src/brpc/global.h b/src/brpc/global.h
index bbd7fef..06f1d69 100644
--- a/src/brpc/global.h
+++ b/src/brpc/global.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_GLOBAL_H
 #define BRPC_GLOBAL_H
diff --git a/src/brpc/grpc.cpp b/src/brpc/grpc.cpp
index b1ebdd6..4e4b822 100644
--- a/src/brpc/grpc.cpp
+++ b/src/brpc/grpc.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 
 #include <sstream>                  // std::stringstream
diff --git a/src/brpc/grpc.h b/src/brpc/grpc.h
index 4643cfb..9c4a733 100644
--- a/src/brpc/grpc.h
+++ b/src/brpc/grpc.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #ifndef BRPC_GRPC_H
 #define BRPC_GRPC_H
diff --git a/src/brpc/health_reporter.h b/src/brpc/health_reporter.h
index 048956f..85a600a 100644
--- a/src/brpc/health_reporter.h
+++ b/src/brpc/health_reporter.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_HEALTH_REPORTER_H
 #define BRPC_HEALTH_REPORTER_H
diff --git a/src/brpc/http_header.cpp b/src/brpc/http_header.cpp
index ccfa309..ec9e88e 100644
--- a/src/brpc/http_header.cpp
+++ b/src/brpc/http_header.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen(chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include "brpc/http_status_code.h"     // HTTP_STATUS_*
 #include "brpc/http_header.h"
diff --git a/src/brpc/http_header.h b/src/brpc/http_header.h
index 7e0fe98..6de0b64 100644
--- a/src/brpc/http_header.h
+++ b/src/brpc/http_header.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen(chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_HTTP_HEADER_H
 #define  BRPC_HTTP_HEADER_H
diff --git a/src/brpc/http_method.cpp b/src/brpc/http_method.cpp
index 43457f8..acb0de1 100644
--- a/src/brpc/http_method.cpp
+++ b/src/brpc/http_method.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen(chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include <stdlib.h>                     // abort()
 #include "butil/macros.h"
diff --git a/src/brpc/http_method.h b/src/brpc/http_method.h
index 41811b7..5bf0f91 100644
--- a/src/brpc/http_method.h
+++ b/src/brpc/http_method.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen(chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_HTTP_METHOD_H
 #define  BRPC_HTTP_METHOD_H
diff --git a/src/brpc/http_status_code.cpp b/src/brpc/http_status_code.cpp
index afb5841..cd3a7c2 100644
--- a/src/brpc/http_status_code.cpp
+++ b/src/brpc/http_status_code.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen(chenzhangyi01@baidu.com)
 
 #include <stdio.h>                                  // snprintf
 
diff --git a/src/brpc/http_status_code.h b/src/brpc/http_status_code.h
index 8b75f7a..3dedfee 100644
--- a/src/brpc/http_status_code.h
+++ b/src/brpc/http_status_code.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen(chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_HTTP_STATUS_CODE_H
 #define  BRPC_HTTP_STATUS_CODE_H
diff --git a/src/brpc/input_message_base.h b/src/brpc/input_message_base.h
index fa45744..86b2578 100644
--- a/src/brpc/input_message_base.h
+++ b/src/brpc/input_message_base.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_INPUT_MESSAGE_BASE_H
 #define BRPC_INPUT_MESSAGE_BASE_H
diff --git a/src/brpc/input_messenger.cpp b/src/brpc/input_messenger.cpp
index de0b952..aff1b98 100644
--- a/src/brpc/input_messenger.cpp
+++ b/src/brpc/input_messenger.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include "butil/fd_guard.h"                      // fd_guard
diff --git a/src/brpc/input_messenger.h b/src/brpc/input_messenger.h
index 27aa67e..f588b57 100644
--- a/src/brpc/input_messenger.h
+++ b/src/brpc/input_messenger.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_INPUT_MESSENGER_H
 #define BRPC_INPUT_MESSENGER_H
diff --git a/src/brpc/load_balancer.cpp b/src/brpc/load_balancer.cpp
index 372e7b1..18f6a7a 100644
--- a/src/brpc/load_balancer.cpp
+++ b/src/brpc/load_balancer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include "brpc/reloadable_flags.h"
diff --git a/src/brpc/load_balancer.h b/src/brpc/load_balancer.h
index 94d1b56..830c9ef 100644
--- a/src/brpc/load_balancer.h
+++ b/src/brpc/load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_LOAD_BALANCER_H
 #define BRPC_LOAD_BALANCER_H
diff --git a/src/brpc/memcache.cpp b/src/brpc/memcache.cpp
index 6dc2dab..cd7ea30 100644
--- a/src/brpc/memcache.cpp
+++ b/src/brpc/memcache.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <algorithm>
 #include <google/protobuf/reflection_ops.h>
diff --git a/src/brpc/memcache.h b/src/brpc/memcache.h
index 15e76fc..bd54c39 100644
--- a/src/brpc/memcache.h
+++ b/src/brpc/memcache.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_MEMCACHE_H
 #define BRPC_MEMCACHE_H
diff --git a/src/brpc/naming_service.h b/src/brpc/naming_service.h
index d071329..1298bc9 100644
--- a/src/brpc/naming_service.h
+++ b/src/brpc/naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_NAMING_SERVICE_H
 #define BRPC_NAMING_SERVICE_H
diff --git a/src/brpc/naming_service_filter.h b/src/brpc/naming_service_filter.h
index 24bd396..37f6801 100644
--- a/src/brpc/naming_service_filter.h
+++ b/src/brpc/naming_service_filter.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_NAMING_SERVICE_FILTER_H
 #define BRPC_NAMING_SERVICE_FILTER_H
diff --git a/src/brpc/nshead_message.cpp b/src/brpc/nshead_message.cpp
index f660cf0..e58de2a 100644
--- a/src/brpc/nshead_message.cpp
+++ b/src/brpc/nshead_message.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <algorithm>
 #include <google/protobuf/reflection_ops.h>                 // ReflectionOps::Merge
diff --git a/src/brpc/nshead_message.h b/src/brpc/nshead_message.h
index 7a4ba91..3f41454 100644
--- a/src/brpc/nshead_message.h
+++ b/src/brpc/nshead_message.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_NSHEAD_MESSAGE_H
 #define BRPC_NSHEAD_MESSAGE_H
diff --git a/src/brpc/nshead_pb_service_adaptor.cpp b/src/brpc/nshead_pb_service_adaptor.cpp
index 0981d93..ed3552f 100644
--- a/src/brpc/nshead_pb_service_adaptor.cpp
+++ b/src/brpc/nshead_pb_service_adaptor.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/nshead_pb_service_adaptor.h b/src/brpc/nshead_pb_service_adaptor.h
index bd511c5..8fa1e82 100644
--- a/src/brpc/nshead_pb_service_adaptor.h
+++ b/src/brpc/nshead_pb_service_adaptor.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_NSHEAD_PB_SERVICE_ADAPTOR_H
 #define BRPC_NSHEAD_PB_SERVICE_ADAPTOR_H
diff --git a/src/brpc/nshead_service.cpp b/src/brpc/nshead_service.cpp
index 65a83a0..0f043e2 100644
--- a/src/brpc/nshead_service.cpp
+++ b/src/brpc/nshead_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/class_name.h"
 #include "brpc/nshead_service.h"
diff --git a/src/brpc/nshead_service.h b/src/brpc/nshead_service.h
index da98047..c90c787 100644
--- a/src/brpc/nshead_service.h
+++ b/src/brpc/nshead_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_NSHEAD_SERVICE_H
 #define BRPC_NSHEAD_SERVICE_H
diff --git a/src/brpc/parallel_channel.cpp b/src/brpc/parallel_channel.cpp
index 38cd5f3..cf92e71 100644
--- a/src/brpc/parallel_channel.cpp
+++ b/src/brpc/parallel_channel.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "bthread/bthread.h"                  // bthread_id_xx
 #include "bthread/unstable.h"                 // bthread_timer_add
diff --git a/src/brpc/parallel_channel.h b/src/brpc/parallel_channel.h
index 681536d..8e82f60 100644
--- a/src/brpc/parallel_channel.h
+++ b/src/brpc/parallel_channel.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PARALLEL_CHANNEL_H
 #define BRPC_PARALLEL_CHANNEL_H
diff --git a/src/brpc/parse_result.h b/src/brpc/parse_result.h
index a153f6b..e84f80e 100644
--- a/src/brpc/parse_result.h
+++ b/src/brpc/parse_result.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PARSE_RESULT_H
 #define BRPC_PARSE_RESULT_H
diff --git a/src/brpc/partition_channel.cpp b/src/brpc/partition_channel.cpp
index 738d2fc..c15fddd 100644
--- a/src/brpc/partition_channel.cpp
+++ b/src/brpc/partition_channel.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/containers/flat_map.h"
 #include "brpc/log.h"
diff --git a/src/brpc/partition_channel.h b/src/brpc/partition_channel.h
index 6353e5e..f2421b8 100644
--- a/src/brpc/partition_channel.h
+++ b/src/brpc/partition_channel.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PARTITION_CHANNEL_H
 #define BRPC_PARTITION_CHANNEL_H
diff --git a/src/brpc/periodic_naming_service.cpp b/src/brpc/periodic_naming_service.cpp
index fc62565..e113624 100644
--- a/src/brpc/periodic_naming_service.cpp
+++ b/src/brpc/periodic_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include "butil/logging.h"
diff --git a/src/brpc/periodic_naming_service.h b/src/brpc/periodic_naming_service.h
index 4c4c68a..b27033f 100644
--- a/src/brpc/periodic_naming_service.h
+++ b/src/brpc/periodic_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PERIODIC_NAMING_SERVICE_H
 #define BRPC_PERIODIC_NAMING_SERVICE_H
diff --git a/src/brpc/periodic_task.cpp b/src/brpc/periodic_task.cpp
index 3d761ff..27ea3ec 100644
--- a/src/brpc/periodic_task.cpp
+++ b/src/brpc/periodic_task.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <bthread/bthread.h>
 #include <bthread/unstable.h>
diff --git a/src/brpc/periodic_task.h b/src/brpc/periodic_task.h
index a180730..cb54760 100644
--- a/src/brpc/periodic_task.h
+++ b/src/brpc/periodic_task.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_HEALTH_CHECK_MANAGER_H
 #define BRPC_HEALTH_CHECK_MANAGER_H
diff --git a/src/brpc/policy/baidu_rpc_protocol.cpp b/src/brpc/policy/baidu_rpc_protocol.cpp
index 5b82b16..88197f6 100644
--- a/src/brpc/policy/baidu_rpc_protocol.cpp
+++ b/src/brpc/policy/baidu_rpc_protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/baidu_rpc_protocol.h b/src/brpc/policy/baidu_rpc_protocol.h
index d245cf2..e3e4954 100644
--- a/src/brpc/policy/baidu_rpc_protocol.h
+++ b/src/brpc/policy/baidu_rpc_protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef BRPC_POLICY_BRPC_PROTOCOL_H
 #define BRPC_POLICY_BRPC_PROTOCOL_H
diff --git a/src/brpc/policy/consistent_hashing_load_balancer.cpp b/src/brpc/policy/consistent_hashing_load_balancer.cpp
index db48ca8..fd22380 100644
--- a/src/brpc/policy/consistent_hashing_load_balancer.cpp
+++ b/src/brpc/policy/consistent_hashing_load_balancer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include <algorithm>                                           // std::set_union
 #include <array>
diff --git a/src/brpc/policy/consistent_hashing_load_balancer.h b/src/brpc/policy/consistent_hashing_load_balancer.h
index 05b659f..5da7548 100644
--- a/src/brpc/policy/consistent_hashing_load_balancer.h
+++ b/src/brpc/policy/consistent_hashing_load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_CONSISTENT_HASHING_LOAD_BALANCER_H
 #define  BRPC_CONSISTENT_HASHING_LOAD_BALANCER_H
diff --git a/src/brpc/policy/consul_naming_service.cpp b/src/brpc/policy/consul_naming_service.cpp
index f170ce6..f4b2345 100644
--- a/src/brpc/policy/consul_naming_service.cpp
+++ b/src/brpc/policy/consul_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Yaofu Zhang (zhangyaofu@qiyi.com)
 
 #include <gflags/gflags.h>
 #include <string>                                       // std::string
diff --git a/src/brpc/policy/consul_naming_service.h b/src/brpc/policy/consul_naming_service.h
index 776b8c3..93bee06 100644
--- a/src/brpc/policy/consul_naming_service.h
+++ b/src/brpc/policy/consul_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Yaofu Zhang (zhangyaofu@qiyi.com)
 
 #ifndef  BRPC_POLICY_CONSUL_NAMING_SERVICE
 #define  BRPC_POLICY_CONSUL_NAMING_SERVICE
diff --git a/src/brpc/policy/discovery_naming_service.cpp b/src/brpc/policy/discovery_naming_service.cpp
index 2aa7805..7efa536 100644
--- a/src/brpc/policy/discovery_naming_service.cpp
+++ b/src/brpc/policy/discovery_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #include <gflags/gflags.h>
 #include "butil/third_party/rapidjson/document.h"
diff --git a/src/brpc/policy/discovery_naming_service.h b/src/brpc/policy/discovery_naming_service.h
index 11c0cd6..8a092a8 100644
--- a/src/brpc/policy/discovery_naming_service.h
+++ b/src/brpc/policy/discovery_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #ifndef BRPC_POLICY_DISCOVERY_NAMING_SERVICE_H
 #define BRPC_POLICY_DISCOVERY_NAMING_SERVICE_H
diff --git a/src/brpc/policy/domain_naming_service.cpp b/src/brpc/policy/domain_naming_service.cpp
index ee5e3b9..aea943c 100644
--- a/src/brpc/policy/domain_naming_service.cpp
+++ b/src/brpc/policy/domain_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #include "butil/build_config.h"                       // OS_MACOSX
 #include <netdb.h>                                    // gethostbyname_r
diff --git a/src/brpc/policy/domain_naming_service.h b/src/brpc/policy/domain_naming_service.h
index c555b8e..a20d2ae 100644
--- a/src/brpc/policy/domain_naming_service.h
+++ b/src/brpc/policy/domain_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef  BRPC_POLICY_DOMAIN_NAMING_SERVICE_H
 #define  BRPC_POLICY_DOMAIN_NAMING_SERVICE_H
diff --git a/src/brpc/policy/dynpart_load_balancer.cpp b/src/brpc/policy/dynpart_load_balancer.cpp
index bfb192a..4785a0f 100644
--- a/src/brpc/policy/dynpart_load_balancer.cpp
+++ b/src/brpc/policy/dynpart_load_balancer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/macros.h"
 #include "butil/fast_rand.h"
diff --git a/src/brpc/policy/dynpart_load_balancer.h b/src/brpc/policy/dynpart_load_balancer.h
index 02cf92b..d3fd9d6 100644
--- a/src/brpc/policy/dynpart_load_balancer.h
+++ b/src/brpc/policy/dynpart_load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_DYNPART_LOAD_BALANCER_H
 #define BRPC_POLICY_DYNPART_LOAD_BALANCER_H
diff --git a/src/brpc/policy/file_naming_service.cpp b/src/brpc/policy/file_naming_service.cpp
index 0da9805..df49673 100644
--- a/src/brpc/policy/file_naming_service.cpp
+++ b/src/brpc/policy/file_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <stdio.h>                                      // getline
 #include <string>                                       // std::string
diff --git a/src/brpc/policy/file_naming_service.h b/src/brpc/policy/file_naming_service.h
index a5c4484..c9d6cbb 100644
--- a/src/brpc/policy/file_naming_service.h
+++ b/src/brpc/policy/file_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_POLICY_FILE_NAMING_SERVICE
 #define  BRPC_POLICY_FILE_NAMING_SERVICE
diff --git a/src/brpc/policy/giano_authenticator.cpp b/src/brpc/policy/giano_authenticator.cpp
index dca3b98..d74f106 100644
--- a/src/brpc/policy/giano_authenticator.cpp
+++ b/src/brpc/policy/giano_authenticator.cpp
@@ -17,7 +17,6 @@
 
 #ifdef BAIDU_INTERNAL
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #include "butil/logging.h"
 #include "brpc/policy/giano_authenticator.h"
diff --git a/src/brpc/policy/giano_authenticator.h b/src/brpc/policy/giano_authenticator.h
index a008f6d..d2b9acb 100644
--- a/src/brpc/policy/giano_authenticator.h
+++ b/src/brpc/policy/giano_authenticator.h
@@ -17,7 +17,6 @@
 
 #ifdef BAIDU_INTERNAL
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_POLICY_GIANO_AUTHENTICATOR_H
 #define BRPC_POLICY_GIANO_AUTHENTICATOR_H
diff --git a/src/brpc/policy/gzip_compress.cpp b/src/brpc/policy/gzip_compress.cpp
index edba16d..35367e3 100644
--- a/src/brpc/policy/gzip_compress.cpp
+++ b/src/brpc/policy/gzip_compress.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/io/gzip_stream.h>    // GzipXXXStream
 #include "butil/logging.h"
diff --git a/src/brpc/policy/gzip_compress.h b/src/brpc/policy/gzip_compress.h
index f45edd4..426aaf5 100644
--- a/src/brpc/policy/gzip_compress.h
+++ b/src/brpc/policy/gzip_compress.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_GZIP_COMPRESS_H
 #define BRPC_POLICY_GZIP_COMPRESS_H
diff --git a/src/brpc/policy/hasher.cpp b/src/brpc/policy/hasher.cpp
index 7cb0bc9..f533099 100644
--- a/src/brpc/policy/hasher.cpp
+++ b/src/brpc/policy/hasher.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include <limits.h>
 #include <openssl/md5.h>
diff --git a/src/brpc/policy/hasher.h b/src/brpc/policy/hasher.h
index fd70e51..cb660ca 100644
--- a/src/brpc/policy/hasher.h
+++ b/src/brpc/policy/hasher.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_HASHER_H
 #define  BRPC_HASHER_H
diff --git a/src/brpc/policy/http2_rpc_protocol.cpp b/src/brpc/policy/http2_rpc_protocol.cpp
index df205f5..1bf4159 100644
--- a/src/brpc/policy/http2_rpc_protocol.cpp
+++ b/src/brpc/policy/http2_rpc_protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu(zhujiashun@baidu.com)
 
 #include "brpc/policy/http2_rpc_protocol.h"
 #include "brpc/details/controller_private_accessor.h"
diff --git a/src/brpc/policy/http2_rpc_protocol.h b/src/brpc/policy/http2_rpc_protocol.h
index 6ab657b..8574723 100644
--- a/src/brpc/policy/http2_rpc_protocol.h
+++ b/src/brpc/policy/http2_rpc_protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu(zhujiashun@baidu.com)
 
 #ifndef BAIDU_RPC_POLICY_HTTP2_RPC_PROTOCOL_H
 #define BAIDU_RPC_POLICY_HTTP2_RPC_PROTOCOL_H
diff --git a/src/brpc/policy/http_rpc_protocol.cpp b/src/brpc/policy/http_rpc_protocol.cpp
index 012e303..41a61c2 100644
--- a/src/brpc/policy/http_rpc_protocol.cpp
+++ b/src/brpc/policy/http_rpc_protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>             // MethodDescriptor
 #include <gflags/gflags.h>
diff --git a/src/brpc/policy/http_rpc_protocol.h b/src/brpc/policy/http_rpc_protocol.h
index 46993cd..b6f986a 100644
--- a/src/brpc/policy/http_rpc_protocol.h
+++ b/src/brpc/policy/http_rpc_protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_HTTP_RPC_PROTOCOL_H
 #define BRPC_POLICY_HTTP_RPC_PROTOCOL_H
diff --git a/src/brpc/policy/hulu_pbrpc_controller.h b/src/brpc/policy/hulu_pbrpc_controller.h
index c2e7266..751c874 100644
--- a/src/brpc/policy/hulu_pbrpc_controller.h
+++ b/src/brpc/policy/hulu_pbrpc_controller.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_HULU_PBRPC_CONTROLLER_H
 #define  BRPC_HULU_PBRPC_CONTROLLER_H
diff --git a/src/brpc/policy/hulu_pbrpc_protocol.cpp b/src/brpc/policy/hulu_pbrpc_protocol.cpp
index 50cb9ef..50660a0 100644
--- a/src/brpc/policy/hulu_pbrpc_protocol.cpp
+++ b/src/brpc/policy/hulu_pbrpc_protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>          // MethodDescriptor
 #include <google/protobuf/message.h>             // Message
diff --git a/src/brpc/policy/hulu_pbrpc_protocol.h b/src/brpc/policy/hulu_pbrpc_protocol.h
index b341341..d62f8a6 100644
--- a/src/brpc/policy/hulu_pbrpc_protocol.h
+++ b/src/brpc/policy/hulu_pbrpc_protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_HULU_PBRPC_PROTOCOL_H
 #define BRPC_POLICY_HULU_PBRPC_PROTOCOL_H
diff --git a/src/brpc/policy/list_naming_service.cpp b/src/brpc/policy/list_naming_service.cpp
index b9c4e4f..bffc9a0 100644
--- a/src/brpc/policy/list_naming_service.cpp
+++ b/src/brpc/policy/list_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <stdlib.h>                                   // strtol
 #include <string>                                     // std::string
diff --git a/src/brpc/policy/list_naming_service.h b/src/brpc/policy/list_naming_service.h
index 3a57434..d99ab4e 100644
--- a/src/brpc/policy/list_naming_service.h
+++ b/src/brpc/policy/list_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_POLICY_LIST_NAMING_SERVICE
 #define  BRPC_POLICY_LIST_NAMING_SERVICE
diff --git a/src/brpc/policy/locality_aware_load_balancer.cpp b/src/brpc/policy/locality_aware_load_balancer.cpp
index a82af08..f97b035 100644
--- a/src/brpc/policy/locality_aware_load_balancer.cpp
+++ b/src/brpc/policy/locality_aware_load_balancer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <limits>                                            // numeric_limits
 #include <gflags/gflags.h>
diff --git a/src/brpc/policy/locality_aware_load_balancer.h b/src/brpc/policy/locality_aware_load_balancer.h
index 8da16c0..0e40101 100644
--- a/src/brpc/policy/locality_aware_load_balancer.h
+++ b/src/brpc/policy/locality_aware_load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_LOCALITY_AWARE_LOAD_BALANCER_H
 #define BRPC_POLICY_LOCALITY_AWARE_LOAD_BALANCER_H
diff --git a/src/brpc/policy/memcache_binary_header.h b/src/brpc/policy/memcache_binary_header.h
index 854bdfc..93ba879 100644
--- a/src/brpc/policy/memcache_binary_header.h
+++ b/src/brpc/policy/memcache_binary_header.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_MEMCACHE_BINARY_HEADER_H
 #define BRPC_MEMCACHE_BINARY_HEADER_H
diff --git a/src/brpc/policy/memcache_binary_protocol.cpp b/src/brpc/policy/memcache_binary_protocol.cpp
index 1fa8903..a5a69e5 100644
--- a/src/brpc/policy/memcache_binary_protocol.cpp
+++ b/src/brpc/policy/memcache_binary_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/memcache_binary_protocol.h b/src/brpc/policy/memcache_binary_protocol.h
index f180dd8..0db3b9f 100644
--- a/src/brpc/policy/memcache_binary_protocol.h
+++ b/src/brpc/policy/memcache_binary_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_MEMCACHE_BINARY_PROTOCOL_H
 #define BRPC_POLICY_MEMCACHE_BINARY_PROTOCOL_H
diff --git a/src/brpc/policy/most_common_message.h b/src/brpc/policy/most_common_message.h
index 83e3cf2..ef682a7 100644
--- a/src/brpc/policy/most_common_message.h
+++ b/src/brpc/policy/most_common_message.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_MOST_COMMON_MESSAGE_H
 #define BRPC_POLICY_MOST_COMMON_MESSAGE_H
diff --git a/src/brpc/policy/nova_pbrpc_protocol.cpp b/src/brpc/policy/nova_pbrpc_protocol.cpp
index 412c9ea..e21b312 100644
--- a/src/brpc/policy/nova_pbrpc_protocol.cpp
+++ b/src/brpc/policy/nova_pbrpc_protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/nova_pbrpc_protocol.h b/src/brpc/policy/nova_pbrpc_protocol.h
index 9a16994..448c3db 100644
--- a/src/brpc/policy/nova_pbrpc_protocol.h
+++ b/src/brpc/policy/nova_pbrpc_protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com) 
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_NOVA_PBRPC_PROTOCOL_H
 #define BRPC_POLICY_NOVA_PBRPC_PROTOCOL_H
diff --git a/src/brpc/policy/nshead_mcpack_protocol.cpp b/src/brpc/policy/nshead_mcpack_protocol.cpp
index b4daadb..b5e201b 100644
--- a/src/brpc/policy/nshead_mcpack_protocol.cpp
+++ b/src/brpc/policy/nshead_mcpack_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/nshead_mcpack_protocol.h b/src/brpc/policy/nshead_mcpack_protocol.h
index 9e42fb8..bda4031 100644
--- a/src/brpc/policy/nshead_mcpack_protocol.h
+++ b/src/brpc/policy/nshead_mcpack_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_NSHEAD_MCPACK_PROTOCOL_H
 #define BRPC_POLICY_NSHEAD_MCPACK_PROTOCOL_H
diff --git a/src/brpc/policy/nshead_protocol.cpp b/src/brpc/policy/nshead_protocol.cpp
index 98b18b8..1c2186b 100644
--- a/src/brpc/policy/nshead_protocol.cpp
+++ b/src/brpc/policy/nshead_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/nshead_protocol.h b/src/brpc/policy/nshead_protocol.h
index 9e06b47..41e2710 100644
--- a/src/brpc/policy/nshead_protocol.h
+++ b/src/brpc/policy/nshead_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_NSHEAD_PROTOCOL_H
 #define BRPC_POLICY_NSHEAD_PROTOCOL_H
diff --git a/src/brpc/policy/public_pbrpc_protocol.cpp b/src/brpc/policy/public_pbrpc_protocol.cpp
index 784ed2f..d1bc832 100644
--- a/src/brpc/policy/public_pbrpc_protocol.cpp
+++ b/src/brpc/policy/public_pbrpc_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #include <google/protobuf/descriptor.h>            // MethodDescriptor
 #include <google/protobuf/message.h>               // Message
diff --git a/src/brpc/policy/public_pbrpc_protocol.h b/src/brpc/policy/public_pbrpc_protocol.h
index ecc43ae..3e630a5 100644
--- a/src/brpc/policy/public_pbrpc_protocol.h
+++ b/src/brpc/policy/public_pbrpc_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_POLICY_PUBLIC_PBRPC_PROTOCOL_H
 #define BRPC_POLICY_PUBLIC_PBRPC_PROTOCOL_H
diff --git a/src/brpc/policy/randomized_load_balancer.cpp b/src/brpc/policy/randomized_load_balancer.cpp
index 3600fa6..cac695a 100644
--- a/src/brpc/policy/randomized_load_balancer.cpp
+++ b/src/brpc/policy/randomized_load_balancer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/macros.h"
 #include "butil/fast_rand.h"
diff --git a/src/brpc/policy/randomized_load_balancer.h b/src/brpc/policy/randomized_load_balancer.h
index 0816dcb..e599648 100644
--- a/src/brpc/policy/randomized_load_balancer.h
+++ b/src/brpc/policy/randomized_load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_RANDOMIZED_LOAD_BALANCER_H
 #define BRPC_POLICY_RANDOMIZED_LOAD_BALANCER_H
diff --git a/src/brpc/policy/redis_protocol.cpp b/src/brpc/policy/redis_protocol.cpp
index 2865b8d..9ef305d 100644
--- a/src/brpc/policy/redis_protocol.cpp
+++ b/src/brpc/policy/redis_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 //          Jiashun Zhu(zhujiashun2010@gmail.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
diff --git a/src/brpc/policy/redis_protocol.h b/src/brpc/policy/redis_protocol.h
index b46bed4..b3f7184 100644
--- a/src/brpc/policy/redis_protocol.h
+++ b/src/brpc/policy/redis_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_REDIS_PROTOCOL_H
 #define BRPC_POLICY_REDIS_PROTOCOL_H
diff --git a/src/brpc/policy/remote_file_naming_service.cpp b/src/brpc/policy/remote_file_naming_service.cpp
index ee1d3bc..c5aeac9 100644
--- a/src/brpc/policy/remote_file_naming_service.cpp
+++ b/src/brpc/policy/remote_file_naming_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include <stdio.h>                                      // getline
diff --git a/src/brpc/policy/remote_file_naming_service.h b/src/brpc/policy/remote_file_naming_service.h
index c5acb93..ab4bed9 100644
--- a/src/brpc/policy/remote_file_naming_service.h
+++ b/src/brpc/policy/remote_file_naming_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_POLICY_HTTP_FILE_NAMING_SERVICE
 #define  BRPC_POLICY_HTTP_FILE_NAMING_SERVICE
diff --git a/src/brpc/policy/round_robin_load_balancer.cpp b/src/brpc/policy/round_robin_load_balancer.cpp
index 171f4e6..ee7fa53 100644
--- a/src/brpc/policy/round_robin_load_balancer.cpp
+++ b/src/brpc/policy/round_robin_load_balancer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/macros.h"
 #include "butil/fast_rand.h"
diff --git a/src/brpc/policy/round_robin_load_balancer.h b/src/brpc/policy/round_robin_load_balancer.h
index 2f117d8..c5a34a8 100644
--- a/src/brpc/policy/round_robin_load_balancer.h
+++ b/src/brpc/policy/round_robin_load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_ROUND_ROBIN_LOAD_BALANCER_H
 #define BRPC_POLICY_ROUND_ROBIN_LOAD_BALANCER_H
diff --git a/src/brpc/policy/rtmp_protocol.cpp b/src/brpc/policy/rtmp_protocol.cpp
index a6e7bae..2e7d509 100644
--- a/src/brpc/policy/rtmp_protocol.cpp
+++ b/src/brpc/policy/rtmp_protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu (zhujiashun@baidu.com)
 
 #include <openssl/hmac.h> // HMAC_CTX_init
 #include <google/protobuf/io/zero_copy_stream_impl_lite.h>
diff --git a/src/brpc/policy/rtmp_protocol.h b/src/brpc/policy/rtmp_protocol.h
index e538d55..b5572c2 100644
--- a/src/brpc/policy/rtmp_protocol.h
+++ b/src/brpc/policy/rtmp_protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu (zhujiashun@baidu.com)
 
 #ifndef BRPC_POLICY_RTMP_PROTOCOL_H
 #define BRPC_POLICY_RTMP_PROTOCOL_H
diff --git a/src/brpc/policy/snappy_compress.cpp b/src/brpc/policy/snappy_compress.cpp
index c270d23..77e8017 100644
--- a/src/brpc/policy/snappy_compress.cpp
+++ b/src/brpc/policy/snappy_compress.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiang,Lin (jianglin05@baidu.com)
 
 #include "butil/logging.h"
 #include "butil/third_party/snappy/snappy.h"
diff --git a/src/brpc/policy/snappy_compress.h b/src/brpc/policy/snappy_compress.h
index 19af34d..082aba9 100644
--- a/src/brpc/policy/snappy_compress.h
+++ b/src/brpc/policy/snappy_compress.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiang,Lin (jianglin05@baidu.com)
 
 #ifndef BRPC_POLICY_SNAPPY_COMPRESS_H
 #define BRPC_POLICY_SNAPPY_COMPRESS_H
diff --git a/src/brpc/policy/sofa_pbrpc_protocol.cpp b/src/brpc/policy/sofa_pbrpc_protocol.cpp
index 42bb4d9..27d8037 100644
--- a/src/brpc/policy/sofa_pbrpc_protocol.cpp
+++ b/src/brpc/policy/sofa_pbrpc_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>          // MethodDescriptor
 #include <google/protobuf/message.h>             // Message
diff --git a/src/brpc/policy/sofa_pbrpc_protocol.h b/src/brpc/policy/sofa_pbrpc_protocol.h
index 523bd62..715949e 100644
--- a/src/brpc/policy/sofa_pbrpc_protocol.h
+++ b/src/brpc/policy/sofa_pbrpc_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_SOFA_PBRPC_PROTOCOL_H
 #define BRPC_POLICY_SOFA_PBRPC_PROTOCOL_H
diff --git a/src/brpc/policy/streaming_rpc_protocol.cpp b/src/brpc/policy/streaming_rpc_protocol.cpp
index fb6f3e9..df47032 100644
--- a/src/brpc/policy/streaming_rpc_protocol.cpp
+++ b/src/brpc/policy/streaming_rpc_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include "brpc/policy/streaming_rpc_protocol.h"
 
diff --git a/src/brpc/policy/streaming_rpc_protocol.h b/src/brpc/policy/streaming_rpc_protocol.h
index 4b12fe4..ff9e207 100644
--- a/src/brpc/policy/streaming_rpc_protocol.h
+++ b/src/brpc/policy/streaming_rpc_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_STREAMING_RPC_PROTOCOL_H
 #define  BRPC_STREAMING_RPC_PROTOCOL_H
diff --git a/src/brpc/policy/thrift_protocol.cpp b/src/brpc/policy/thrift_protocol.cpp
index a255851..eae081a 100755
--- a/src/brpc/policy/thrift_protocol.cpp
+++ b/src/brpc/policy/thrift_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: wangxuefeng (wangxuefeng@didichuxing.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/thrift_protocol.h b/src/brpc/policy/thrift_protocol.h
index 7007acd..223e1f1 100755
--- a/src/brpc/policy/thrift_protocol.h
+++ b/src/brpc/policy/thrift_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: wangxuefeng (wangxuefeng@didichuxing.com)
 
 #ifndef BRPC_POLICY_THRIFT_PROTOCOL_H
 #define BRPC_POLICY_THRIFT_PROTOCOL_H
diff --git a/src/brpc/policy/ubrpc2pb_protocol.cpp b/src/brpc/policy/ubrpc2pb_protocol.cpp
index 7f83db0..69c9428 100644
--- a/src/brpc/policy/ubrpc2pb_protocol.cpp
+++ b/src/brpc/policy/ubrpc2pb_protocol.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>         // MethodDescriptor
 #include <google/protobuf/message.h>            // Message
diff --git a/src/brpc/policy/ubrpc2pb_protocol.h b/src/brpc/policy/ubrpc2pb_protocol.h
index 09b6500..669222d 100644
--- a/src/brpc/policy/ubrpc2pb_protocol.h
+++ b/src/brpc/policy/ubrpc2pb_protocol.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_POLICY_UBRPC2PB_PROTOCOL_H
 #define BRPC_POLICY_UBRPC2PB_PROTOCOL_H
diff --git a/src/brpc/policy/weighted_round_robin_load_balancer.h b/src/brpc/policy/weighted_round_robin_load_balancer.h
index 35d534c..0e92388 100644
--- a/src/brpc/policy/weighted_round_robin_load_balancer.h
+++ b/src/brpc/policy/weighted_round_robin_load_balancer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Daojin Cai (caidaojin@qiyi.com)
 
 #ifndef BRPC_POLICY_WEIGHTED_ROUND_ROBIN_LOAD_BALANCER_H
 #define BRPC_POLICY_WEIGHTED_ROUND_ROBIN_LOAD_BALANCER_H
diff --git a/src/brpc/progressive_attachment.cpp b/src/brpc/progressive_attachment.cpp
index d61feee..0f8a3a3 100644
--- a/src/brpc/progressive_attachment.cpp
+++ b/src/brpc/progressive_attachment.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include "butil/logging.h"
 #include "bthread/bthread.h"   // INVALID_BTHREAD_ID before bthread r32748
diff --git a/src/brpc/progressive_attachment.h b/src/brpc/progressive_attachment.h
index b37d386..31477f8 100644
--- a/src/brpc/progressive_attachment.h
+++ b/src/brpc/progressive_attachment.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PROGRESSIVE_ATTACHMENT_H
 #define BRPC_PROGRESSIVE_ATTACHMENT_H
diff --git a/src/brpc/progressive_reader.h b/src/brpc/progressive_reader.h
index d76335c..6f54ae6 100644
--- a/src/brpc/progressive_reader.h
+++ b/src/brpc/progressive_reader.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_PROGRESSIVE_READER_H
 #define BRPC_PROGRESSIVE_READER_H
diff --git a/src/brpc/protocol.cpp b/src/brpc/protocol.cpp
index e20c88e..11297ea 100644
--- a/src/brpc/protocol.cpp
+++ b/src/brpc/protocol.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 // Since kDefaultTotalBytesLimit is private, we need some hacks to get the limit.
 // Works for pb 2.4, 2.6, 3.0
diff --git a/src/brpc/protocol.h b/src/brpc/protocol.h
index aa78207..c1e0602 100755
--- a/src/brpc/protocol.h
+++ b/src/brpc/protocol.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_PROTOCOL_H
 #define BRPC_PROTOCOL_H
diff --git a/src/brpc/redis.cpp b/src/brpc/redis.cpp
index 59d321c..fd5c309 100644
--- a/src/brpc/redis.cpp
+++ b/src/brpc/redis.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/reflection_ops.h>     // ReflectionOps::Merge
 #include <gflags/gflags.h>
diff --git a/src/brpc/redis.h b/src/brpc/redis.h
index 69d1208..e9013ad 100644
--- a/src/brpc/redis.h
+++ b/src/brpc/redis.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_REDIS_H
 #define BRPC_REDIS_H
diff --git a/src/brpc/redis_command.cpp b/src/brpc/redis_command.cpp
index 009bbee..a850549 100644
--- a/src/brpc/redis_command.cpp
+++ b/src/brpc/redis_command.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "butil/logging.h"
 #include "brpc/log.h"
diff --git a/src/brpc/redis_command.h b/src/brpc/redis_command.h
index 65531fa..cecf02c 100644
--- a/src/brpc/redis_command.h
+++ b/src/brpc/redis_command.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_REDIS_COMMAND_H
 #define BRPC_REDIS_COMMAND_H
diff --git a/src/brpc/redis_reply.cpp b/src/brpc/redis_reply.cpp
index 70bde1a..5d67477 100644
--- a/src/brpc/redis_reply.cpp
+++ b/src/brpc/redis_reply.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <limits>
 #include "butil/logging.h"
diff --git a/src/brpc/redis_reply.h b/src/brpc/redis_reply.h
index 9c135a9..ec26915 100644
--- a/src/brpc/redis_reply.h
+++ b/src/brpc/redis_reply.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_REDIS_REPLY_H
 #define BRPC_REDIS_REPLY_H
diff --git a/src/brpc/reloadable_flags.cpp b/src/brpc/reloadable_flags.cpp
index d21c342..0b92487 100644
--- a/src/brpc/reloadable_flags.cpp
+++ b/src/brpc/reloadable_flags.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <unistd.h>                    // write, _exit
 #include <gflags/gflags.h>
diff --git a/src/brpc/reloadable_flags.h b/src/brpc/reloadable_flags.h
index 8cf0360..74c5923 100644
--- a/src/brpc/reloadable_flags.h
+++ b/src/brpc/reloadable_flags.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_RELOADABLE_FLAGS_H
 #define BRPC_RELOADABLE_FLAGS_H
diff --git a/src/brpc/restful.cpp b/src/brpc/restful.cpp
index 3fc9219..32554e8 100644
--- a/src/brpc/restful.cpp
+++ b/src/brpc/restful.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <google/protobuf/descriptor.h>
 #include "brpc/log.h"
diff --git a/src/brpc/restful.h b/src/brpc/restful.h
index 3f52a9b..ceab491 100644
--- a/src/brpc/restful.h
+++ b/src/brpc/restful.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_RESTFUL_H
 #define BRPC_RESTFUL_H
diff --git a/src/brpc/retry_policy.cpp b/src/brpc/retry_policy.cpp
index fbfb418..4fdd594 100644
--- a/src/brpc/retry_policy.cpp
+++ b/src/brpc/retry_policy.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/retry_policy.h"
 
diff --git a/src/brpc/retry_policy.h b/src/brpc/retry_policy.h
index 3db55b7..b4852da 100644
--- a/src/brpc/retry_policy.h
+++ b/src/brpc/retry_policy.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_RETRY_POLICY_H
 #define BRPC_RETRY_POLICY_H
diff --git a/src/brpc/rpc_dump.cpp b/src/brpc/rpc_dump.cpp
index 9a22760..bf3d7fc 100644
--- a/src/brpc/rpc_dump.cpp
+++ b/src/brpc/rpc_dump.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include <fcntl.h>                    // O_CREAT
diff --git a/src/brpc/rpc_dump.h b/src/brpc/rpc_dump.h
index 1c13ccb..5ab558f 100644
--- a/src/brpc/rpc_dump.h
+++ b/src/brpc/rpc_dump.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_RPC_DUMP_H
 #define BRPC_RPC_DUMP_H
diff --git a/src/brpc/rtmp.cpp b/src/brpc/rtmp.cpp
index cea0f74..3797972 100644
--- a/src/brpc/rtmp.cpp
+++ b/src/brpc/rtmp.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu (zhujiashun@baidu.com)
 
 #include <gflags/gflags.h>
 #include <google/protobuf/io/zero_copy_stream_impl_lite.h> // StringOutputStream
diff --git a/src/brpc/rtmp.h b/src/brpc/rtmp.h
index 778baff..90b4730 100644
--- a/src/brpc/rtmp.h
+++ b/src/brpc/rtmp.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu (zhujiashun@baidu.com)
 
 #ifndef BRPC_RTMP_H
 #define BRPC_RTMP_H
diff --git a/src/brpc/selective_channel.cpp b/src/brpc/selective_channel.cpp
index c2fb492..66a916b 100644
--- a/src/brpc/selective_channel.cpp
+++ b/src/brpc/selective_channel.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <map>
 #include <gflags/gflags.h>
diff --git a/src/brpc/selective_channel.h b/src/brpc/selective_channel.h
index 47e739d..8b93e5b 100644
--- a/src/brpc/selective_channel.h
+++ b/src/brpc/selective_channel.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SELECTIVE_CHANNEL_H
 #define BRPC_SELECTIVE_CHANNEL_H
diff --git a/src/brpc/serialized_request.cpp b/src/brpc/serialized_request.cpp
index b56f147..23beeb7 100644
--- a/src/brpc/serialized_request.cpp
+++ b/src/brpc/serialized_request.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/serialized_request.h"
 #include "butil/logging.h"
diff --git a/src/brpc/serialized_request.h b/src/brpc/serialized_request.h
index 02b6805..c59495d 100644
--- a/src/brpc/serialized_request.h
+++ b/src/brpc/serialized_request.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SERIALIZED_REQUEST_H
 #define BRPC_SERIALIZED_REQUEST_H
diff --git a/src/brpc/server.cpp b/src/brpc/server.cpp
index a93e6d8..b021a55 100644
--- a/src/brpc/server.cpp
+++ b/src/brpc/server.cpp
@@ -15,9 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang(jiangrujie@baidu.com)
-//          Zhangyi Chen(chenzhangyi01@baidu.com)
 
 #include <wordexp.h>                                // wordexp
 #include <iomanip>
diff --git a/src/brpc/server.h b/src/brpc/server.h
index 2ac973a..6dbc7c6 100644
--- a/src/brpc/server.h
+++ b/src/brpc/server.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_SERVER_H
 #define BRPC_SERVER_H
diff --git a/src/brpc/server_id.cpp b/src/brpc/server_id.cpp
index 98e13d0..c3a595b 100644
--- a/src/brpc/server_id.cpp
+++ b/src/brpc/server_id.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include "brpc/server_id.h"
 
diff --git a/src/brpc/server_id.h b/src/brpc/server_id.h
index f0cb72b..a1d3aee 100644
--- a/src/brpc/server_id.h
+++ b/src/brpc/server_id.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SERVER_ID_H
 #define BRPC_SERVER_ID_H
diff --git a/src/brpc/shared_object.h b/src/brpc/shared_object.h
index 380fba5..8b64840 100644
--- a/src/brpc/shared_object.h
+++ b/src/brpc/shared_object.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SHARED_OBJECT_H
 #define BRPC_SHARED_OBJECT_H
diff --git a/src/brpc/simple_data_pool.h b/src/brpc/simple_data_pool.h
index c738e34..affd8f1 100644
--- a/src/brpc/simple_data_pool.h
+++ b/src/brpc/simple_data_pool.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SIMPLE_DATA_POOL_H
 #define BRPC_SIMPLE_DATA_POOL_H
diff --git a/src/brpc/socket.cpp b/src/brpc/socket.cpp
index cb2d241..d20cb49 100644
--- a/src/brpc/socket.cpp
+++ b/src/brpc/socket.cpp
@@ -15,9 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
-//          Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include "butil/compat.h"                        // OS_MACOSX
 #include <openssl/ssl.h>
diff --git a/src/brpc/socket.h b/src/brpc/socket.h
index 9739af4..ed87696 100644
--- a/src/brpc/socket.h
+++ b/src/brpc/socket.h
@@ -15,9 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
-//          Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef BRPC_SOCKET_H
 #define BRPC_SOCKET_H
diff --git a/src/brpc/socket_id.h b/src/brpc/socket_id.h
index 1ae85ce..7204324 100644
--- a/src/brpc/socket_id.h
+++ b/src/brpc/socket_id.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SOCKET_ID_H
 #define BRPC_SOCKET_ID_H
diff --git a/src/brpc/socket_map.cpp b/src/brpc/socket_map.cpp
index bca0f8b..613f333 100644
--- a/src/brpc/socket_map.cpp
+++ b/src/brpc/socket_map.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Rujie Jiang (jiangrujie@baidu.com)
 
 #include <gflags/gflags.h>
 #include <map>
diff --git a/src/brpc/socket_map.h b/src/brpc/socket_map.h
index fd6a6cb..7a91b34 100644
--- a/src/brpc/socket_map.h
+++ b/src/brpc/socket_map.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SOCKET_MAP_H
 #define BRPC_SOCKET_MAP_H
diff --git a/src/brpc/socket_message.h b/src/brpc/socket_message.h
index c0aa6a7..25afe41 100644
--- a/src/brpc/socket_message.h
+++ b/src/brpc/socket_message.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_SOCKET_MESSAGE_H
 #define BRPC_SOCKET_MESSAGE_H
diff --git a/src/brpc/span.cpp b/src/brpc/span.cpp
index 9381b26..784330f 100644
--- a/src/brpc/span.cpp
+++ b/src/brpc/span.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <netinet/in.h>
 #include <gflags/gflags.h>
diff --git a/src/brpc/span.h b/src/brpc/span.h
index c29e69a..43ede3d 100644
--- a/src/brpc/span.h
+++ b/src/brpc/span.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 // NOTE: RPC users are not supposed to include this file.
 
diff --git a/src/brpc/ssl_options.cpp b/src/brpc/ssl_options.cpp
index a601778..e3b8f5b 100644
--- a/src/brpc/ssl_options.cpp
+++ b/src/brpc/ssl_options.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #include "brpc/ssl_options.h"
 
diff --git a/src/brpc/ssl_options.h b/src/brpc/ssl_options.h
index 76fb658..e39d3e4 100644
--- a/src/brpc/ssl_options.h
+++ b/src/brpc/ssl_options.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Rujie Jiang (jiangrujie@baidu.com)
 
 #ifndef BRPC_SSL_OPTION_H
 #define BRPC_SSL_OPTION_H
diff --git a/src/brpc/stream.cpp b/src/brpc/stream.cpp
index 920c2f5..e48441e 100644
--- a/src/brpc/stream.cpp
+++ b/src/brpc/stream.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #include "brpc/stream.h"
 
diff --git a/src/brpc/stream.h b/src/brpc/stream.h
index a193dd0..53a5fc4 100644
--- a/src/brpc/stream.h
+++ b/src/brpc/stream.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_STREAM_H
 #define  BRPC_STREAM_H
diff --git a/src/brpc/stream_creator.h b/src/brpc/stream_creator.h
index 394eb37..1bc2f07 100644
--- a/src/brpc/stream_creator.h
+++ b/src/brpc/stream_creator.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_STREAM_CREATOR_H
 #define BRPC_STREAM_CREATOR_H
diff --git a/src/brpc/stream_impl.h b/src/brpc/stream_impl.h
index 97b7d96..4adb9ac 100644
--- a/src/brpc/stream_impl.h
+++ b/src/brpc/stream_impl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
 
 #ifndef  BRPC_STREAM_IMPL_H
 #define  BRPC_STREAM_IMPL_H
diff --git a/src/brpc/thrift_message.cpp b/src/brpc/thrift_message.cpp
index c408f72..c3be85a 100644
--- a/src/brpc/thrift_message.cpp
+++ b/src/brpc/thrift_message.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: wangxuefeng (wangxuefeng@didichuxing.com)
 
 #define INTERNAL_SUPPRESS_PROTOBUF_FIELD_DEPRECATION
 #include "brpc/thrift_message.h"
diff --git a/src/brpc/thrift_message.h b/src/brpc/thrift_message.h
index 9bc38cb..a152b16 100644
--- a/src/brpc/thrift_message.h
+++ b/src/brpc/thrift_message.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: wangxuefeng (wangxuefeng@didichuxing.com)
 
 #ifndef BRPC_THRIFT_MESSAGE_H
 #define BRPC_THRIFT_MESSAGE_H
diff --git a/src/brpc/thrift_service.cpp b/src/brpc/thrift_service.cpp
index 2a501f1..283ea48 100644
--- a/src/brpc/thrift_service.cpp
+++ b/src/brpc/thrift_service.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: wangxuefeng (wangxuefeng@didichuxing.com)
 
 #include "butil/class_name.h"
 #include "brpc/thrift_service.h"
diff --git a/src/brpc/thrift_service.h b/src/brpc/thrift_service.h
index ef5e905..c3d341e 100644
--- a/src/brpc/thrift_service.h
+++ b/src/brpc/thrift_service.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: wangxuefeng (wangxuefeng@didichuxing.com)
 
 #ifndef BRPC_THRIFT_SERVICE_H
 #define BRPC_THRIFT_SERVICE_H
diff --git a/src/brpc/traceprintf.h b/src/brpc/traceprintf.h
index 5f07c0e..513daf2 100644
--- a/src/brpc/traceprintf.h
+++ b/src/brpc/traceprintf.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_TRACEPRINTF_H
 #define BRPC_TRACEPRINTF_H
diff --git a/src/brpc/trackme.cpp b/src/brpc/trackme.cpp
index d47a4ff..b0f56f3 100644
--- a/src/brpc/trackme.cpp
+++ b/src/brpc/trackme.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef _GNU_SOURCE
 #define _GNU_SOURCE
diff --git a/src/brpc/trackme.h b/src/brpc/trackme.h
index f7618cb..55c25f1 100644
--- a/src/brpc/trackme.h
+++ b/src/brpc/trackme.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #ifndef BRPC_TRACKME_H
 #define BRPC_TRACKME_H
diff --git a/src/brpc/ts.cpp b/src/brpc/ts.cpp
index 70ce320..6649924 100644
--- a/src/brpc/ts.cpp
+++ b/src/brpc/ts.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 // [Modified from the code in SRS2 (src/kernel/srs_kernel_ts.cpp)]
 // The MIT License (MIT)
diff --git a/src/brpc/ts.h b/src/brpc/ts.h
index 12f3cca..fe18e2f 100644
--- a/src/brpc/ts.h
+++ b/src/brpc/ts.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 // [Modified from the code in SRS2 (src/kernel/srs_kernel_ts.cpp)]
 // The MIT License (MIT)
diff --git a/src/brpc/uri.cpp b/src/brpc/uri.cpp
index 1f5ffaa..5003de8 100644
--- a/src/brpc/uri.cpp
+++ b/src/brpc/uri.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #include "brpc/log.h"
 #include "brpc/details/http_parser.h"      // http_parser_parse_url
diff --git a/src/brpc/uri.h b/src/brpc/uri.h
index 70f1089..42e8d0b 100644
--- a/src/brpc/uri.h
+++ b/src/brpc/uri.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Zhangyi Chen (chenzhangyi01@baidu.com)
-//          Ge,Jun (gejun@baidu.com)
 
 #ifndef  BRPC_URI_H
 #define  BRPC_URI_H
diff --git a/src/bthread/bthread.cpp b/src/bthread/bthread.cpp
index 4f12e3a..d136997 100644
--- a/src/bthread/bthread.cpp
+++ b/src/bthread/bthread.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #include <gflags/gflags.h>
diff --git a/src/bthread/bthread.h b/src/bthread/bthread.h
index d93daea..c5fa4c6 100644
--- a/src/bthread/bthread.h
+++ b/src/bthread/bthread.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_BTHREAD_H
diff --git a/src/bthread/butex.cpp b/src/bthread/butex.cpp
index 84540b9..f8d947d 100644
--- a/src/bthread/butex.cpp
+++ b/src/bthread/butex.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 22 17:30:12 CST 2014
 
 #include "butil/atomicops.h"                // butil::atomic
diff --git a/src/bthread/butex.h b/src/bthread/butex.h
index bc55fa1..4e65091 100644
--- a/src/bthread/butex.h
+++ b/src/bthread/butex.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 22 17:30:12 CST 2014
 
 #ifndef BTHREAD_BUTEX_H
diff --git a/src/bthread/comlog_initializer.h b/src/bthread/comlog_initializer.h
index 1a5b0fb..29f82f9 100644
--- a/src/bthread/comlog_initializer.h
+++ b/src/bthread/comlog_initializer.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Sep 15 10:51:15 CST 2014
 
 #ifndef BTHREAD_COMLOG_INITIALIZER_H
diff --git a/src/bthread/condition_variable.cpp b/src/bthread/condition_variable.cpp
index e1411c2..789aa14 100644
--- a/src/bthread/condition_variable.cpp
+++ b/src/bthread/condition_variable.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Aug  3 12:46:15 CST 2014
 
 #include "butil/atomicops.h"
diff --git a/src/bthread/condition_variable.h b/src/bthread/condition_variable.h
index 08f2b3b..789d2ba 100644
--- a/src/bthread/condition_variable.h
+++ b/src/bthread/condition_variable.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/12/14 21:26:26
 
 #ifndef  BTHREAD_CONDITION_VARIABLE_H
diff --git a/src/bthread/countdown_event.cpp b/src/bthread/countdown_event.cpp
index 033774a..3d0d652 100644
--- a/src/bthread/countdown_event.cpp
+++ b/src/bthread/countdown_event.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2016/06/03 13:15:24
 
 #include "butil/atomicops.h"     // butil::atomic<int>
diff --git a/src/bthread/countdown_event.h b/src/bthread/countdown_event.h
index bb6b415..d1ee669 100644
--- a/src/bthread/countdown_event.h
+++ b/src/bthread/countdown_event.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2016/06/03 13:06:40
 
 #ifndef BTHREAD_COUNTDOWN_EVENT_H
diff --git a/src/bthread/errno.cpp b/src/bthread/errno.cpp
index 56b6f22..b5d45b8 100644
--- a/src/bthread/errno.cpp
+++ b/src/bthread/errno.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Wed Jul 30 11:47:19 CST 2014
 
 #include "bthread/errno.h"
diff --git a/src/bthread/errno.h b/src/bthread/errno.h
index f3dcdef..600fb08 100644
--- a/src/bthread/errno.h
+++ b/src/bthread/errno.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Wed Jul 30 11:47:19 CST 2014
 
 #ifndef BTHREAD_ERRNO_H
diff --git a/src/bthread/execution_queue.cpp b/src/bthread/execution_queue.cpp
index 73cfc23..569698b 100644
--- a/src/bthread/execution_queue.cpp
+++ b/src/bthread/execution_queue.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2016/04/16 18:43:24
 
 #include "bthread/execution_queue.h"
diff --git a/src/bthread/execution_queue.h b/src/bthread/execution_queue.h
index 283fe38..61cb99e 100644
--- a/src/bthread/execution_queue.h
+++ b/src/bthread/execution_queue.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/10/23 18:16:16
 
 #ifndef  BTHREAD_EXECUTION_QUEUE_H
diff --git a/src/bthread/execution_queue_inl.h b/src/bthread/execution_queue_inl.h
index 561525a..7911db6 100644
--- a/src/bthread/execution_queue_inl.h
+++ b/src/bthread/execution_queue_inl.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/10/27 17:39:48
 
 #ifndef  BTHREAD_EXECUTION_QUEUE_INL_H
diff --git a/src/bthread/fd.cpp b/src/bthread/fd.cpp
index 17ab6db..7d8e138 100644
--- a/src/bthread/fd.cpp
+++ b/src/bthread/fd.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Aug  7 18:56:27 CST 2014
 
 #include "butil/compat.h"
diff --git a/src/bthread/id.cpp b/src/bthread/id.cpp
index 3e3fcda..23046b2 100644
--- a/src/bthread/id.cpp
+++ b/src/bthread/id.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Aug  3 12:46:15 CST 2014
 
 #include <deque>
diff --git a/src/bthread/id.h b/src/bthread/id.h
index 502086f..5364ea5 100644
--- a/src/bthread/id.h
+++ b/src/bthread/id.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_ID_H
diff --git a/src/bthread/interrupt_pthread.cpp b/src/bthread/interrupt_pthread.cpp
index 19ad4df..0643886 100644
--- a/src/bthread/interrupt_pthread.cpp
+++ b/src/bthread/interrupt_pthread.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #include <signal.h>
diff --git a/src/bthread/interrupt_pthread.h b/src/bthread/interrupt_pthread.h
index b7f3c29..99edd51 100644
--- a/src/bthread/interrupt_pthread.h
+++ b/src/bthread/interrupt_pthread.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_INTERRUPT_PTHREAD_H
diff --git a/src/bthread/key.cpp b/src/bthread/key.cpp
index 438e01e..a4a0840 100644
--- a/src/bthread/key.cpp
+++ b/src/bthread/key.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Aug  3 12:46:15 CST 2014
 
 #include <pthread.h>
diff --git a/src/bthread/list_of_abafree_id.h b/src/bthread/list_of_abafree_id.h
index 362980a..bf1aba0 100644
--- a/src/bthread/list_of_abafree_id.h
+++ b/src/bthread/list_of_abafree_id.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Jun 20 11:57:23 CST 2016
 
 #ifndef BTHREAD_LIST_OF_ABAFREE_ID_H
diff --git a/src/bthread/log.h b/src/bthread/log.h
index 5d24407..2f3522b 100644
--- a/src/bthread/log.h
+++ b/src/bthread/log.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Sep 15 10:51:15 CST 2014
 
 #ifndef BTHREAD_LOG_H
diff --git a/src/bthread/mutex.cpp b/src/bthread/mutex.cpp
index 7d5ed64..441bc6c 100644
--- a/src/bthread/mutex.cpp
+++ b/src/bthread/mutex.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Aug  3 12:46:15 CST 2014
 
 #include <pthread.h>
diff --git a/src/bthread/mutex.h b/src/bthread/mutex.h
index e47958e..257f179 100644
--- a/src/bthread/mutex.h
+++ b/src/bthread/mutex.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/12/14 18:17:04
 
 #ifndef  BTHREAD_MUTEX_H
diff --git a/src/bthread/parking_lot.h b/src/bthread/parking_lot.h
index 13bb92b..2efc835 100644
--- a/src/bthread/parking_lot.h
+++ b/src/bthread/parking_lot.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: chenzhangyi01@baidu.com, gejun@baidu.com
 // Date: 2017/07/27 23:07:06
 
 #ifndef BTHREAD_PARKING_LOT_H
diff --git a/src/bthread/processor.h b/src/bthread/processor.h
index 4471cec..fcc244c 100644
--- a/src/bthread/processor.h
+++ b/src/bthread/processor.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Dec  5 13:40:57 CST 2014
 
 #ifndef BTHREAD_PROCESSOR_H
diff --git a/src/bthread/remote_task_queue.h b/src/bthread/remote_task_queue.h
index 3f9bb24..ab75727 100644
--- a/src/bthread/remote_task_queue.h
+++ b/src/bthread/remote_task_queue.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun, 22 Jan 2017
 
 #ifndef BTHREAD_REMOTE_TASK_QUEUE_H
diff --git a/src/bthread/stack.cpp b/src/bthread/stack.cpp
index 05560da..43e57ef 100644
--- a/src/bthread/stack.cpp
+++ b/src/bthread/stack.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Sep  7 22:37:39 CST 2014
 
 #include <unistd.h>                               // getpagesize
diff --git a/src/bthread/stack.h b/src/bthread/stack.h
index 9a9de59..7f3b1d8 100644
--- a/src/bthread/stack.h
+++ b/src/bthread/stack.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Sep  7 22:37:39 CST 2014
 
 #ifndef BTHREAD_ALLOCATE_STACK_H
diff --git a/src/bthread/stack_inl.h b/src/bthread/stack_inl.h
index 62df8bc..0ccff13 100644
--- a/src/bthread/stack_inl.h
+++ b/src/bthread/stack_inl.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Sep  7 22:37:39 CST 2014
 
 #ifndef BTHREAD_ALLOCATE_STACK_INL_H
diff --git a/src/bthread/sys_futex.cpp b/src/bthread/sys_futex.cpp
index 16e3516..11387a0 100644
--- a/src/bthread/sys_futex.cpp
+++ b/src/bthread/sys_futex.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Zhu,Jiashun (zhujiashun@baidu.com)
 // Date: Wed Mar 14 17:44:58 CST 2018
 
 #include "bthread/sys_futex.h"
diff --git a/src/bthread/sys_futex.h b/src/bthread/sys_futex.h
index f57dfcb..11470f6 100644
--- a/src/bthread/sys_futex.h
+++ b/src/bthread/sys_futex.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_SYS_FUTEX_H
diff --git a/src/bthread/task_control.cpp b/src/bthread/task_control.cpp
index 068d9c7..3b90dc7 100644
--- a/src/bthread/task_control.cpp
+++ b/src/bthread/task_control.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #include "butil/scoped_lock.h"             // BAIDU_SCOPED_LOCK
diff --git a/src/bthread/task_control.h b/src/bthread/task_control.h
index afe0d81..fd40d6c 100644
--- a/src/bthread/task_control.h
+++ b/src/bthread/task_control.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_TASK_CONTROL_H
diff --git a/src/bthread/task_group.cpp b/src/bthread/task_group.cpp
index a087893..d561c57 100644
--- a/src/bthread/task_group.cpp
+++ b/src/bthread/task_group.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #include <sys/types.h>
diff --git a/src/bthread/task_group.h b/src/bthread/task_group.h
index 4c5d8cd..12ee126 100644
--- a/src/bthread/task_group.h
+++ b/src/bthread/task_group.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_TASK_GROUP_H
diff --git a/src/bthread/task_group_inl.h b/src/bthread/task_group_inl.h
index 60c9549..d48ceaa 100644
--- a/src/bthread/task_group_inl.h
+++ b/src/bthread/task_group_inl.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_TASK_GROUP_INL_H
diff --git a/src/bthread/task_meta.h b/src/bthread/task_meta.h
index f33593e..740d7d9 100644
--- a/src/bthread/task_meta.h
+++ b/src/bthread/task_meta.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_TASK_META_H
diff --git a/src/bthread/timer_thread.cpp b/src/bthread/timer_thread.cpp
index 1cc5cd8..5010206 100644
--- a/src/bthread/timer_thread.cpp
+++ b/src/bthread/timer_thread.cpp
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 
 #include <queue>                           // heap functions
 #include "butil/scoped_lock.h"
diff --git a/src/bthread/timer_thread.h b/src/bthread/timer_thread.h
index 27f3f4b..c12c2a8 100644
--- a/src/bthread/timer_thread.h
+++ b/src/bthread/timer_thread.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 
 #ifndef BTHREAD_TIMER_THREAD_H
 #define BTHREAD_TIMER_THREAD_H
diff --git a/src/bthread/types.h b/src/bthread/types.h
index d43b6cd..8263ea9 100644
--- a/src/bthread/types.h
+++ b/src/bthread/types.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_TYPES_H
diff --git a/src/bthread/unstable.h b/src/bthread/unstable.h
index 0d16537..361acef 100644
--- a/src/bthread/unstable.h
+++ b/src/bthread/unstable.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_UNSTABLE_H
diff --git a/src/bthread/work_stealing_queue.h b/src/bthread/work_stealing_queue.h
index 6fd88e1..3750ac5 100644
--- a/src/bthread/work_stealing_queue.h
+++ b/src/bthread/work_stealing_queue.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 10 17:40:58 CST 2012
 
 #ifndef BTHREAD_WORK_STEALING_QUEUE_H
diff --git a/src/butil/arena.cpp b/src/butil/arena.cpp
index 2bdc573..9c66217 100644
--- a/src/butil/arena.cpp
+++ b/src/butil/arena.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Jun  5 18:25:40 CST 2015
 
 #include <stdlib.h>
diff --git a/src/butil/arena.h b/src/butil/arena.h
index 06c4d1b..03693a7 100644
--- a/src/butil/arena.h
+++ b/src/butil/arena.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Jun  5 18:25:40 CST 2015
 
 // Do small memory allocations on continuous blocks.
diff --git a/src/butil/binary_printer.cpp b/src/butil/binary_printer.cpp
index 6cca5fb..1b17134 100644
--- a/src/butil/binary_printer.cpp
+++ b/src/butil/binary_printer.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #include <inttypes.h>
diff --git a/src/butil/binary_printer.h b/src/butil/binary_printer.h
index 79890f7..068ef24 100644
--- a/src/butil/binary_printer.h
+++ b/src/butil/binary_printer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #ifndef BUTIL_BINARY_PRINTER_H
diff --git a/src/butil/bit_array.h b/src/butil/bit_array.h
index cb4f90e..54beb39 100644
--- a/src/butil/bit_array.h
+++ b/src/butil/bit_array.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Feb 25 23:43:39 CST 2014
 
 // Provide functions to get/set bits of an integral array. These functions
diff --git a/src/butil/class_name.cpp b/src/butil/class_name.cpp
index f80d48e..133b45b 100644
--- a/src/butil/class_name.cpp
+++ b/src/butil/class_name.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #include <cxxabi.h>                              // __cxa_demangle
diff --git a/src/butil/class_name.h b/src/butil/class_name.h
index e0b8074..48babf7 100644
--- a/src/butil/class_name.h
+++ b/src/butil/class_name.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 // Get name of a class. For example, class_name<T>() returns the name of T
diff --git a/src/butil/comlog_sink.cc b/src/butil/comlog_sink.cc
index 493da15..c645447 100644
--- a/src/butil/comlog_sink.cc
+++ b/src/butil/comlog_sink.cc
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Jul 20 12:39:39 CST 2015
 
 #include <com_log.h>
diff --git a/src/butil/comlog_sink.h b/src/butil/comlog_sink.h
index 37b527d..6444ff6 100644
--- a/src/butil/comlog_sink.h
+++ b/src/butil/comlog_sink.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Jul 20 12:39:39 CST 2015
 
 // Redirect LOG() into comlog.
diff --git a/src/butil/compat.h b/src/butil/compat.h
index 0254c52..d75e163 100644
--- a/src/butil/compat.h
+++ b/src/butil/compat.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
-//          Jiashun Zhu(zhujiashun@baidu.com)
 
 #ifndef BUTIL_COMPAT_H
 #define BUTIL_COMPAT_H
diff --git a/src/butil/containers/bounded_queue.h b/src/butil/containers/bounded_queue.h
index fb688ca..55f06e1 100644
--- a/src/butil/containers/bounded_queue.h
+++ b/src/butil/containers/bounded_queue.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sat Aug 18 12:42:16 CST 2012
 
 // A thread-unsafe bounded queue(ring buffer). It can push/pop from both
diff --git a/src/butil/containers/case_ignored_flat_map.cpp b/src/butil/containers/case_ignored_flat_map.cpp
index 835d555..7f2fadc 100644
--- a/src/butil/containers/case_ignored_flat_map.cpp
+++ b/src/butil/containers/case_ignored_flat_map.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Dec  4 14:57:27 CST 2016
 
 namespace butil {
diff --git a/src/butil/containers/case_ignored_flat_map.h b/src/butil/containers/case_ignored_flat_map.h
index fe19ac8..99add6c 100644
--- a/src/butil/containers/case_ignored_flat_map.h
+++ b/src/butil/containers/case_ignored_flat_map.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Dec  4 14:57:27 CST 2016
 
 #ifndef BUTIL_CASE_IGNORED_FLAT_MAP_H
diff --git a/src/butil/containers/doubly_buffered_data.h b/src/butil/containers/doubly_buffered_data.h
index 076bc71..93ba342 100644
--- a/src/butil/containers/doubly_buffered_data.h
+++ b/src/butil/containers/doubly_buffered_data.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Sep 22 22:23:13 CST 2014
 
 #ifndef BUTIL_DOUBLY_BUFFERED_DATA_H
diff --git a/src/butil/containers/flat_map.h b/src/butil/containers/flat_map.h
index eda7172..ef89aa6 100644
--- a/src/butil/containers/flat_map.h
+++ b/src/butil/containers/flat_map.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Wed Nov 27 12:59:20 CST 2013
 
 // This closed addressing hash-map puts first linked node in bucket array
diff --git a/src/butil/containers/flat_map_inl.h b/src/butil/containers/flat_map_inl.h
index 8610b34..ef08d7b 100644
--- a/src/butil/containers/flat_map_inl.h
+++ b/src/butil/containers/flat_map_inl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Wed Nov 27 12:59:20 CST 2013
 
 #ifndef BUTIL_FLAT_MAP_INL_H
diff --git a/src/butil/containers/pooled_map.h b/src/butil/containers/pooled_map.h
index ce2673d..dab4371 100644
--- a/src/butil/containers/pooled_map.h
+++ b/src/butil/containers/pooled_map.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sat Dec  3 13:11:32 CST 2016
 
 #ifndef BUTIL_POOLED_MAP_H
diff --git a/src/butil/endpoint.cpp b/src/butil/endpoint.cpp
index 8280931..43aa7a2 100644
--- a/src/butil/endpoint.cpp
+++ b/src/butil/endpoint.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #include "butil/build_config.h"                // OS_MACOSX
diff --git a/src/butil/endpoint.h b/src/butil/endpoint.h
index 8107499..ea16b25 100644
--- a/src/butil/endpoint.h
+++ b/src/butil/endpoint.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 // Wrappers of IP and port.
diff --git a/src/butil/errno.cpp b/src/butil/errno.cpp
index 9cd10f3..8b3eeb7 100644
--- a/src/butil/errno.cpp
+++ b/src/butil/errno.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Sep 10 13:34:25 CST 2010
 
 #include "butil/build_config.h"                        // OS_MACOSX
diff --git a/src/butil/errno.h b/src/butil/errno.h
index 7aa4429..0390a84 100644
--- a/src/butil/errno.h
+++ b/src/butil/errno.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
  
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Sep 10 13:34:25 CST 2010
 
 // Add customized errno.
diff --git a/src/butil/fast_rand.cpp b/src/butil/fast_rand.cpp
index 34ae06b..1bd80c9 100644
--- a/src/butil/fast_rand.cpp
+++ b/src/butil/fast_rand.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Dec 31 13:35:39 CST 2015
 
 #include <limits>          // numeric_limits
diff --git a/src/butil/fast_rand.h b/src/butil/fast_rand.h
index 6f0ed1b..ed941d6 100644
--- a/src/butil/fast_rand.h
+++ b/src/butil/fast_rand.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Dec 31 13:35:39 CST 2015
 
 #ifndef BUTIL_FAST_RAND_H
diff --git a/src/butil/fd_guard.h b/src/butil/fd_guard.h
index 439f509..69a5620 100644
--- a/src/butil/fd_guard.h
+++ b/src/butil/fd_guard.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #ifndef BUTIL_FD_GUARD_H
diff --git a/src/butil/fd_utility.cpp b/src/butil/fd_utility.cpp
index 3dc54fd..e1ca8cc 100644
--- a/src/butil/fd_utility.cpp
+++ b/src/butil/fd_utility.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #include <fcntl.h>                   // fcntl()
diff --git a/src/butil/fd_utility.h b/src/butil/fd_utility.h
index 72fa26e..8b4f789 100644
--- a/src/butil/fd_utility.h
+++ b/src/butil/fd_utility.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 // Utility functions on file descriptor.
diff --git a/src/butil/files/dir_reader_unix.h b/src/butil/files/dir_reader_unix.h
index 6ca4ff2..7e3c1e9 100644
--- a/src/butil/files/dir_reader_unix.h
+++ b/src/butil/files/dir_reader_unix.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: yinqiwen (yinqiwen@gmail.com)
 
 #ifndef BUTIL_FILES_DIR_READER_UNIX_H_
 #define BUTIL_FILES_DIR_READER_UNIX_H_
diff --git a/src/butil/files/file_watcher.cpp b/src/butil/files/file_watcher.cpp
index 7a1d6fc..5c69765 100644
--- a/src/butil/files/file_watcher.cpp
+++ b/src/butil/files/file_watcher.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2010/05/29
 
 #include <sys/stat.h>
diff --git a/src/butil/files/file_watcher.h b/src/butil/files/file_watcher.h
index b3e9cfd..548e70b 100644
--- a/src/butil/files/file_watcher.h
+++ b/src/butil/files/file_watcher.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2010/05/29
 
 // Watch timestamp of a file
diff --git a/src/butil/files/temp_file.cpp b/src/butil/files/temp_file.cpp
index 1c11eef..d48499a 100644
--- a/src/butil/files/temp_file.cpp
+++ b/src/butil/files/temp_file.cpp
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Yan,Lin (yanlin@baidu.com)
-//         Ge,Jun (gejun@baidu.com)
 // Date: Thu Oct 28 15:27:05 2010
 
 #include <fcntl.h>                                  // open
diff --git a/src/butil/files/temp_file.h b/src/butil/files/temp_file.h
index 8ad7615..028dfa3 100644
--- a/src/butil/files/temp_file.h
+++ b/src/butil/files/temp_file.h
@@ -15,8 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Yan,Lin (yanlin@baidu.com)
-//         Ge,Jun (gejun@baidu.com)
 // Date: Thu Oct 28 15:23:09 2010
 
 #ifndef BUTIL_FILES_TEMP_FILE_H
diff --git a/src/butil/find_cstr.cpp b/src/butil/find_cstr.cpp
index ef8dd51..afa16b5 100644
--- a/src/butil/find_cstr.cpp
+++ b/src/butil/find_cstr.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jun 23 15:03:24 CST 2015
 
 #include "butil/find_cstr.h"
diff --git a/src/butil/find_cstr.h b/src/butil/find_cstr.h
index 122f998..2a215a8 100644
--- a/src/butil/find_cstr.h
+++ b/src/butil/find_cstr.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jun 23 15:03:24 CST 2015
 
 #ifndef BUTIL_FIND_CSTR_H
diff --git a/src/butil/iobuf.cpp b/src/butil/iobuf.cpp
index 83c8086..382bcfb 100644
--- a/src/butil/iobuf.cpp
+++ b/src/butil/iobuf.cpp
@@ -17,7 +17,6 @@
 
 // iobuf - A non-continuous zero-copied buffer
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #include <openssl/ssl.h>                   // SSL_*
diff --git a/src/butil/iobuf.h b/src/butil/iobuf.h
index f689728..c274309 100644
--- a/src/butil/iobuf.h
+++ b/src/butil/iobuf.h
@@ -17,7 +17,6 @@
 
 // iobuf - A non-continuous zero-copied buffer
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #ifndef BUTIL_IOBUF_H
diff --git a/src/butil/iobuf_inl.h b/src/butil/iobuf_inl.h
index fc85922..072023e 100644
--- a/src/butil/iobuf_inl.h
+++ b/src/butil/iobuf_inl.h
@@ -17,7 +17,6 @@
 
 // iobuf - A non-continuous zero-copied buffer
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 // Inlined implementations of some methods defined in iobuf.h
diff --git a/src/butil/logging.cc b/src/butil/logging.cc
index bc5bbaf..39b2a37 100644
--- a/src/butil/logging.cc
+++ b/src/butil/logging.cc
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2012-10-08 23:53:50
 
 #include "butil/logging.h"
diff --git a/src/butil/logging.h b/src/butil/logging.h
index c959fff..2b60483 100644
--- a/src/butil/logging.h
+++ b/src/butil/logging.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2012-10-08 23:53:50
 
 // Merged chromium log and streaming log.
diff --git a/src/butil/memory/singleton_on_pthread_once.h b/src/butil/memory/singleton_on_pthread_once.h
index 75b4b71..378d708 100644
--- a/src/butil/memory/singleton_on_pthread_once.h
+++ b/src/butil/memory/singleton_on_pthread_once.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
  
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Dec 15 14:37:39 CST 2016
 
 #ifndef BUTIL_MEMORY_SINGLETON_ON_PTHREAD_ONCE_H
diff --git a/src/butil/object_pool.h b/src/butil/object_pool.h
index 3381d56..210e8ec 100644
--- a/src/butil/object_pool.h
+++ b/src/butil/object_pool.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Jul 13 15:04:18 CST 2014
 
 #ifndef BUTIL_OBJECT_POOL_H
diff --git a/src/butil/object_pool_inl.h b/src/butil/object_pool_inl.h
index 3c3b8ea..7a70da1 100644
--- a/src/butil/object_pool_inl.h
+++ b/src/butil/object_pool_inl.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Jul 13 15:04:18 CST 2014
 
 #ifndef BUTIL_OBJECT_POOL_INL_H
diff --git a/src/butil/popen.cpp b/src/butil/popen.cpp
index 47813c7..e806199 100644
--- a/src/butil/popen.cpp
+++ b/src/butil/popen.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2017/11/04 17:37:43
 
 #include <gflags/gflags.h>
diff --git a/src/butil/popen.h b/src/butil/popen.h
index 082ba45..a28442a 100644
--- a/src/butil/popen.h
+++ b/src/butil/popen.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2017/11/04 17:13:18
 
 #ifndef  PUBLIC_COMMON_POPEN_H
diff --git a/src/butil/process_util.cc b/src/butil/process_util.cc
index e348171..fcb41b9 100644
--- a/src/butil/process_util.cc
+++ b/src/butil/process_util.cc
@@ -17,7 +17,6 @@
 
 // Process-related Info
 
-// Author: Zhu,Jiashun (zhujiashun@baidu.com)
 // Date: Wed Apr 11 14:35:56 CST 2018
 
 #include <fcntl.h>                      // open
diff --git a/src/butil/process_util.h b/src/butil/process_util.h
index f4401fc..6dc9a7d 100644
--- a/src/butil/process_util.h
+++ b/src/butil/process_util.h
@@ -17,7 +17,6 @@
 
 // Process-related Info
 
-// Author: Zhu,Jiashun (zhujiashun@baidu.com)
 // Date: Wed Apr 11 14:35:56 CST 2018
 
 #ifndef BUTIL_PROCESS_UTIL_H
diff --git a/src/butil/reader_writer.h b/src/butil/reader_writer.h
index e830965..167cd8b 100644
--- a/src/butil/reader_writer.h
+++ b/src/butil/reader_writer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (jge666@gmail.com)
 // Date: Wed Aug  8 05:51:33 PDT 2018
 
 #ifndef BUTIL_READER_WRITER_H
diff --git a/src/butil/recordio.h b/src/butil/recordio.h
index 3541bdf..8605f59 100755
--- a/src/butil/recordio.h
+++ b/src/butil/recordio.h
@@ -12,7 +12,6 @@
 // See the License for the specific language governing permissions and
 // limitations under the License.
 
-// Author: Ge,Jun (jge666@gmail.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #ifndef BUTIL_RECORDIO_H
diff --git a/src/butil/resource_pool.h b/src/butil/resource_pool.h
index 1667a5d..0a04058 100644
--- a/src/butil/resource_pool.h
+++ b/src/butil/resource_pool.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Jul 13 15:04:18 CST 2014
 
 #ifndef BUTIL_RESOURCE_POOL_H
diff --git a/src/butil/resource_pool_inl.h b/src/butil/resource_pool_inl.h
index 9625c25..dc54967 100644
--- a/src/butil/resource_pool_inl.h
+++ b/src/butil/resource_pool_inl.h
@@ -17,7 +17,6 @@
 
 // bthread - A M:N threading library to make applications more concurrent.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Jul 13 15:04:18 CST 2014
 
 #ifndef BUTIL_RESOURCE_POOL_INL_H
diff --git a/src/butil/single_threaded_pool.h b/src/butil/single_threaded_pool.h
index fd91a28..e6d90fe 100644
--- a/src/butil/single_threaded_pool.h
+++ b/src/butil/single_threaded_pool.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #ifndef BUTIL_SINGLE_THREADED_POOL_H
diff --git a/src/butil/status.cpp b/src/butil/status.cpp
index 56982c4..bb2343e 100644
--- a/src/butil/status.cpp
+++ b/src/butil/status.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Feb  9 15:04:03 CST 2015
 
 #include <stdio.h>
diff --git a/src/butil/string_splitter.h b/src/butil/string_splitter.h
index 1da1eb4..b485c2a 100644
--- a/src/butil/string_splitter.h
+++ b/src/butil/string_splitter.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Apr. 18 19:52:34 CST 2011
 
 // Iteratively split a string by one or multiple separators.
diff --git a/src/butil/string_splitter_inl.h b/src/butil/string_splitter_inl.h
index 76e4d5e..79f3f92 100644
--- a/src/butil/string_splitter_inl.h
+++ b/src/butil/string_splitter_inl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Apr. 18 19:52:34 CST 2011
 
 #include <limits.h>
diff --git a/src/butil/synchronous_event.h b/src/butil/synchronous_event.h
index 70086bf..b0839e5 100644
--- a/src/butil/synchronous_event.h
+++ b/src/butil/synchronous_event.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Nov 7 21:43:34 CST 2010
 
 #ifndef BUTIL_SYNCHRONOUS_EVENT_H
diff --git a/src/butil/thread_local.cpp b/src/butil/thread_local.cpp
index 83eaf33..4dd8c9d 100644
--- a/src/butil/thread_local.cpp
+++ b/src/butil/thread_local.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
  
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #include <errno.h>                       // errno
diff --git a/src/butil/thread_local.h b/src/butil/thread_local.h
index f43675e..1c462b0 100644
--- a/src/butil/thread_local.h
+++ b/src/butil/thread_local.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon. Nov 7 14:47:36 CST 2011
 
 #ifndef BUTIL_THREAD_LOCAL_H
diff --git a/src/butil/thread_local_inl.h b/src/butil/thread_local_inl.h
index ab37883..12f10e3 100644
--- a/src/butil/thread_local_inl.h
+++ b/src/butil/thread_local_inl.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Sep 16 12:39:12 CST 2014
 
 #ifndef BUTIL_THREAD_LOCAL_INL_H
diff --git a/src/butil/time.cpp b/src/butil/time.cpp
index 864d11f..2c726d9 100644
--- a/src/butil/time.cpp
+++ b/src/butil/time.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Aug 29 15:01:15 CST 2014
 
 #include <unistd.h>                          // close
diff --git a/src/butil/time.h b/src/butil/time.h
index 0b22cb4..b288d8e 100644
--- a/src/butil/time.h
+++ b/src/butil/time.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Wed Aug 11 10:38:17 2010
 
 // Measuring time
diff --git a/src/butil/unix_socket.cpp b/src/butil/unix_socket.cpp
index 9a4291b..732a9f6 100644
--- a/src/butil/unix_socket.cpp
+++ b/src/butil/unix_socket.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Jiang,Rujie(jiangrujie@baidu.com)  
 // Date: Mon. Jan 27  23:08:35 CST 2014
 
 #include <sys/types.h>                          // socket
diff --git a/src/butil/unix_socket.h b/src/butil/unix_socket.h
index d405ee5..e2f6f32 100644
--- a/src/butil/unix_socket.h
+++ b/src/butil/unix_socket.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Jiang,Rujie(jiangrujie@baidu.com)
 // Date: Mon. Jan 27  23:08:35 CST 2014
 
 // Wrappers of unix domain sockets, mainly for unit-test of network stuff.
diff --git a/src/butil/zero_copy_stream_as_streambuf.cpp b/src/butil/zero_copy_stream_as_streambuf.cpp
index 0f873cb..540a5bc 100644
--- a/src/butil/zero_copy_stream_as_streambuf.cpp
+++ b/src/butil/zero_copy_stream_as_streambuf.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #include "butil/macros.h"
diff --git a/src/butil/zero_copy_stream_as_streambuf.h b/src/butil/zero_copy_stream_as_streambuf.h
index 884ab26..f6e86a4 100644
--- a/src/butil/zero_copy_stream_as_streambuf.h
+++ b/src/butil/zero_copy_stream_as_streambuf.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Nov 22 13:57:56 CST 2012
 
 #ifndef BUTIL_ZERO_COPY_STREAM_AS_STREAMBUF_H
diff --git a/src/bvar/bvar.h b/src/bvar/bvar.h
index d3a25e6..5a54a09 100644
--- a/src/bvar/bvar.h
+++ b/src/bvar/bvar.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2014/12/29 14:54:11
 
 #ifndef  BVAR_BVAR_H
diff --git a/src/bvar/collector.cpp b/src/bvar/collector.cpp
index f072556..c7844c1 100644
--- a/src/bvar/collector.cpp
+++ b/src/bvar/collector.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Dec 14 19:12:30 CST 2015
 
 #include <map>
diff --git a/src/bvar/collector.h b/src/bvar/collector.h
index 2d7ac35..a334f5d 100644
--- a/src/bvar/collector.h
+++ b/src/bvar/collector.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Dec 14 19:12:30 CST 2015
 
 #ifndef BVAR_COLLECTOR_H
diff --git a/src/bvar/default_variables.cpp b/src/bvar/default_variables.cpp
index ce80f97..be02c50 100644
--- a/src/bvar/default_variables.cpp
+++ b/src/bvar/default_variables.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Thu Jul 30 17:44:54 CST 2015
 
 #include <unistd.h>                        // getpagesize
diff --git a/src/bvar/detail/agent_group.h b/src/bvar/detail/agent_group.h
index 4ba8866..ceb7c05 100644
--- a/src/bvar/detail/agent_group.h
+++ b/src/bvar/detail/agent_group.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date 2014/09/24 19:34:24
 
 #ifndef  BVAR_DETAIL__AGENT_GROUP_H
diff --git a/src/bvar/detail/call_op_returning_void.h b/src/bvar/detail/call_op_returning_void.h
index a485384..e0b95bc 100644
--- a/src/bvar/detail/call_op_returning_void.h
+++ b/src/bvar/detail/call_op_returning_void.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date 2014/09/22 11:57:43
 
 #ifndef  BVAR_DETAIL_CALL_OP_RETURNING_VOID_H
diff --git a/src/bvar/detail/combiner.h b/src/bvar/detail/combiner.h
index bdf9907..6a6ab80 100644
--- a/src/bvar/detail/combiner.h
+++ b/src/bvar/detail/combiner.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date 2014/09/22 11:57:43
 
 #ifndef  BVAR_COMBINER_H
diff --git a/src/bvar/detail/percentile.cpp b/src/bvar/detail/percentile.cpp
index 23a6881..e0412cb 100644
--- a/src/bvar/detail/percentile.cpp
+++ b/src/bvar/detail/percentile.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/09/15 15:14:32
 
 #include "bvar/detail/percentile.h"
diff --git a/src/bvar/detail/percentile.h b/src/bvar/detail/percentile.h
index c7124f2..f04268d 100644
--- a/src/bvar/detail/percentile.h
+++ b/src/bvar/detail/percentile.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/09/15 10:44:17
 
 #ifndef  BVAR_DETAIL_PERCENTILE_H
diff --git a/src/bvar/detail/sampler.cpp b/src/bvar/detail/sampler.cpp
index 0b4465b..f2ca308 100644
--- a/src/bvar/detail/sampler.cpp
+++ b/src/bvar/detail/sampler.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 28 18:14:40 CST 2015
 
 #include "butil/time.h"
diff --git a/src/bvar/detail/sampler.h b/src/bvar/detail/sampler.h
index 1e42987..85ec237 100644
--- a/src/bvar/detail/sampler.h
+++ b/src/bvar/detail/sampler.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 28 18:15:57 CST 2015
 
 #ifndef  BVAR_DETAIL_SAMPLER_H
diff --git a/src/bvar/detail/series.h b/src/bvar/detail/series.h
index cc517a4..b12b7c6 100644
--- a/src/bvar/detail/series.h
+++ b/src/bvar/detail/series.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Tue Jul 28 18:15:57 CST 2015
 
 #ifndef  BVAR_DETAIL_SERIES_H
diff --git a/src/bvar/gflag.cpp b/src/bvar/gflag.cpp
index 3dd4d98..a4d11f8 100644
--- a/src/bvar/gflag.cpp
+++ b/src/bvar/gflag.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Aug  9 12:26:03 CST 2015
 
 #include <stdlib.h>
diff --git a/src/bvar/gflag.h b/src/bvar/gflag.h
index 8550763..17f1f33 100644
--- a/src/bvar/gflag.h
+++ b/src/bvar/gflag.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Aug  9 12:26:03 CST 2015
 
 #ifndef  BVAR_GFLAG_H
diff --git a/src/bvar/latency_recorder.cpp b/src/bvar/latency_recorder.cpp
index 52da5e6..ed91422 100644
--- a/src/bvar/latency_recorder.cpp
+++ b/src/bvar/latency_recorder.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2014/09/22 11:57:43
 
 #include <gflags/gflags.h>
diff --git a/src/bvar/latency_recorder.h b/src/bvar/latency_recorder.h
index 6e4359d..5e70299 100644
--- a/src/bvar/latency_recorder.h
+++ b/src/bvar/latency_recorder.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2014/09/22 11:57:43
 
 #ifndef  BVAR_LATENCY_RECORDER_H
diff --git a/src/bvar/passive_status.h b/src/bvar/passive_status.h
index ab2cbf3..eb4900d 100644
--- a/src/bvar/passive_status.h
+++ b/src/bvar/passive_status.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date 2014/09/22 11:57:43
 
 #ifndef  BVAR_PASSIVE_STATUS_H
diff --git a/src/bvar/recorder.h b/src/bvar/recorder.h
index f09ab0f..33bb65d 100644
--- a/src/bvar/recorder.h
+++ b/src/bvar/recorder.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: chenzhangyi01@baidu.com gejun@baidu.com
 // Date 2014/09/25 17:50:21
 
 #ifndef  BVAR_RECORDER_H
diff --git a/src/bvar/reducer.h b/src/bvar/reducer.h
index 19adf46..fbd4fa7 100644
--- a/src/bvar/reducer.h
+++ b/src/bvar/reducer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: chenzhangyi01@baidu.com, gejun@baidu.com
 // Date 2014/09/24 16:01:08
 
 #ifndef  BVAR_REDUCER_H
diff --git a/src/bvar/scoped_timer.h b/src/bvar/scoped_timer.h
index b3f1c5c..4f349f2 100644
--- a/src/bvar/scoped_timer.h
+++ b/src/bvar/scoped_timer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Jul 14 11:29:21 CST 2017
 
 #ifndef  BVAR_SCOPED_TIMER_H
diff --git a/src/bvar/status.h b/src/bvar/status.h
index f9af7ed..bf46d09 100644
--- a/src/bvar/status.h
+++ b/src/bvar/status.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date 2014/09/22 11:57:43
 
 #ifndef  BVAR_STATUS_H
diff --git a/src/bvar/utils/lock_timer.h b/src/bvar/utils/lock_timer.h
index 3dbf312..f41024a 100644
--- a/src/bvar/utils/lock_timer.h
+++ b/src/bvar/utils/lock_timer.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/03/06 17:13:17
 
 #ifndef  BVAR_LOCK_TIMER_H
diff --git a/src/bvar/variable.cpp b/src/bvar/variable.cpp
index e1bb8b8..17eeadc 100644
--- a/src/bvar/variable.cpp
+++ b/src/bvar/variable.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2014/09/22 19:04:47
 
 #include <pthread.h>
diff --git a/src/bvar/variable.h b/src/bvar/variable.h
index 57b9443..192484c 100644
--- a/src/bvar/variable.h
+++ b/src/bvar/variable.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: 2014/09/22 11:57:43
 
 #ifndef  BVAR_VARIABLE_H
diff --git a/src/bvar/vector.h b/src/bvar/vector.h
index 323a000..b76cee9 100644
--- a/src/bvar/vector.h
+++ b/src/bvar/vector.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Sep 20 12:25:11 CST 2015
 
 #ifndef  BVAR_VECTOR_H
diff --git a/src/bvar/window.h b/src/bvar/window.h
index 6d3af5b..a5780bf 100644
--- a/src/bvar/window.h
+++ b/src/bvar/window.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Wed Jul 29 23:25:43 CST 2015
 
 #ifndef  BVAR_WINDOW_H
diff --git a/src/mcpack2pb/field_type.cpp b/src/mcpack2pb/field_type.cpp
index e719082..a3c686e 100644
--- a/src/mcpack2pb/field_type.cpp
+++ b/src/mcpack2pb/field_type.cpp
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #include "mcpack2pb/field_type.h"
diff --git a/src/mcpack2pb/field_type.h b/src/mcpack2pb/field_type.h
index f35b9c1..7261f9a 100644
--- a/src/mcpack2pb/field_type.h
+++ b/src/mcpack2pb/field_type.h
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #ifndef MCPACK2PB_MCPACK_FIELD_TYPE_H
diff --git a/src/mcpack2pb/generator.cpp b/src/mcpack2pb/generator.cpp
index 0586cb0..0fb7893 100644
--- a/src/mcpack2pb/generator.cpp
+++ b/src/mcpack2pb/generator.cpp
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #include <set>
diff --git a/src/mcpack2pb/mcpack2pb.cpp b/src/mcpack2pb/mcpack2pb.cpp
index c16066f..c810a01 100644
--- a/src/mcpack2pb/mcpack2pb.cpp
+++ b/src/mcpack2pb/mcpack2pb.cpp
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #include <gflags/gflags.h>
diff --git a/src/mcpack2pb/mcpack2pb.h b/src/mcpack2pb/mcpack2pb.h
index 37d4bc0..4dc22a6 100644
--- a/src/mcpack2pb/mcpack2pb.h
+++ b/src/mcpack2pb/mcpack2pb.h
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #ifndef MCPACK2PB_MCPACK_MCPACK2PB_H
diff --git a/src/mcpack2pb/parser-inl.h b/src/mcpack2pb/parser-inl.h
index 09c46b4..76d03fe 100644
--- a/src/mcpack2pb/parser-inl.h
+++ b/src/mcpack2pb/parser-inl.h
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #ifndef MCPACK2PB_MCPACK_PARSER_INL_H
diff --git a/src/mcpack2pb/parser.cpp b/src/mcpack2pb/parser.cpp
index f076bf1..5c785dc 100644
--- a/src/mcpack2pb/parser.cpp
+++ b/src/mcpack2pb/parser.cpp
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #include "mcpack2pb/parser.h"
diff --git a/src/mcpack2pb/parser.h b/src/mcpack2pb/parser.h
index f5a606f..d897c5e 100644
--- a/src/mcpack2pb/parser.h
+++ b/src/mcpack2pb/parser.h
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #ifndef MCPACK2PB_MCPACK_PARSER_H
diff --git a/src/mcpack2pb/serializer-inl.h b/src/mcpack2pb/serializer-inl.h
index 098416d..9c5a262 100644
--- a/src/mcpack2pb/serializer-inl.h
+++ b/src/mcpack2pb/serializer-inl.h
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #ifndef MCPACK2PB_MCPACK_SERIALIZER_INL_H
diff --git a/src/mcpack2pb/serializer.cpp b/src/mcpack2pb/serializer.cpp
index 43ce5de..26fcbea 100644
--- a/src/mcpack2pb/serializer.cpp
+++ b/src/mcpack2pb/serializer.cpp
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #include "mcpack2pb/serializer.h"
diff --git a/src/mcpack2pb/serializer.h b/src/mcpack2pb/serializer.h
index c75f151..5e6a685 100644
--- a/src/mcpack2pb/serializer.h
+++ b/src/mcpack2pb/serializer.h
@@ -17,7 +17,6 @@
 
 // mcpack2pb - Make protobuf be front-end of mcpack/compack
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Mon Oct 19 17:17:36 CST 2015
 
 #ifndef MCPACK2PB_MCPACK_SERIALIZER_H
diff --git a/test/bounded_queue_unittest.cc b/test/bounded_queue_unittest.cc
index 6e1bc45..556e84e 100644
--- a/test/bounded_queue_unittest.cc
+++ b/test/bounded_queue_unittest.cc
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Sun Nov  3 19:16:50 PST 2019
 
 #include <iostream>
diff --git a/test/brpc_grpc_protocol_unittest.cpp b/test/brpc_grpc_protocol_unittest.cpp
index c835b6a..4818b31 100644
--- a/test/brpc_grpc_protocol_unittest.cpp
+++ b/test/brpc_grpc_protocol_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Jiashun Zhu(zhujiashun@bilibili.com)
 
 #include <gtest/gtest.h>
 #include <gflags/gflags.h>
diff --git a/test/bthread_countdown_event_unittest.cpp b/test/bthread_countdown_event_unittest.cpp
index db0cae7..bb018ee 100644
--- a/test/bthread_countdown_event_unittest.cpp
+++ b/test/bthread_countdown_event_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2016/06/03 13:25:44
 
 #include <gtest/gtest.h>
diff --git a/test/bvar_file_dumper_unittest.cpp b/test/bvar_file_dumper_unittest.cpp
index aed1d74..9e80cef 100644
--- a/test/bvar_file_dumper_unittest.cpp
+++ b/test/bvar_file_dumper_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/08/27 17:12:38
 
 #include "bvar/reducer.h"
diff --git a/test/bvar_lock_timer_unittest.cpp b/test/bvar_lock_timer_unittest.cpp
index 45dabb5..52b42f9 100644
--- a/test/bvar_lock_timer_unittest.cpp
+++ b/test/bvar_lock_timer_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/03/06 18:34:03
 
 #include <iostream>
diff --git a/test/bvar_percentile_unittest.cpp b/test/bvar_percentile_unittest.cpp
index 7aa67e6..696e2a5 100644
--- a/test/bvar_percentile_unittest.cpp
+++ b/test/bvar_percentile_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2015/09/15 15:42:55
 
 #include "bvar/detail/percentile.h"
diff --git a/test/bvar_recorder_unittest.cpp b/test/bvar_recorder_unittest.cpp
index 394850d..e1606b6 100644
--- a/test/bvar_recorder_unittest.cpp
+++ b/test/bvar_recorder_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date 2014/10/13 19:47:59
 
 #include <pthread.h>                                // pthread_*
diff --git a/test/bvar_status_unittest.cpp b/test/bvar_status_unittest.cpp
index 28553f7..0bce28b 100644
--- a/test/bvar_status_unittest.cpp
+++ b/test/bvar_status_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date 2014/10/13 19:47:59
 
 #include <pthread.h>                                // pthread_*
diff --git a/test/bvar_variable_unittest.cpp b/test/bvar_variable_unittest.cpp
index 941c9f1..0cdc32e 100644
--- a/test/bvar_variable_unittest.cpp
+++ b/test/bvar_variable_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (gejun@baidu.com)
 // Date: Fri Jul 24 17:19:40 CST 2015
 
 #include <pthread.h>                                // pthread_*
diff --git a/test/popen_unittest.cpp b/test/popen_unittest.cpp
index d272bc7..efd307e 100644
--- a/test/popen_unittest.cpp
+++ b/test/popen_unittest.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Zhangyi Chen (chenzhangyi01@baidu.com)
 // Date: 2017/11/06 10:57:08
 
 #include "butil/popen.h"
diff --git a/tools/parallel_http/parallel_http.cpp b/tools/parallel_http/parallel_http.cpp
index 46f418f..6b863e0 100644
--- a/tools/parallel_http/parallel_http.cpp
+++ b/tools/parallel_http/parallel_http.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 // Access many http servers in parallel, much faster than curl (even called in batch)
 
diff --git a/tools/rpc_replay/rpc_replay.cpp b/tools/rpc_replay/rpc_replay.cpp
index c97c1cd..eddec0e 100644
--- a/tools/rpc_replay/rpc_replay.cpp
+++ b/tools/rpc_replay/rpc_replay.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include <butil/logging.h>
diff --git a/tools/rpc_view/rpc_view.cpp b/tools/rpc_view/rpc_view.cpp
index 732a5f5..a3a7864 100644
--- a/tools/rpc_view/rpc_view.cpp
+++ b/tools/rpc_view/rpc_view.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 #include <gflags/gflags.h>
 #include <butil/logging.h>
diff --git a/tools/trackme_server/trackme_server.cpp b/tools/trackme_server/trackme_server.cpp
index c373344..22f96c5 100644
--- a/tools/trackme_server/trackme_server.cpp
+++ b/tools/trackme_server/trackme_server.cpp
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Ge,Jun (gejun@baidu.com)
 
 // A server to receive TrackMeRequest and send back TrackMeResponse.
 


---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@brpc.apache.org
For additional commands, e-mail: dev-help@brpc.apache.org


[incubator-brpc] 03/03: remove authors 2

Posted by ja...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

jamesge pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-brpc.git

commit aba2676d4be6bb713c1977ae1855ba55d2b26b1b
Author: jamesge <jg...@gmail.com>
AuthorDate: Fri Jan 3 13:02:37 2020 +0800

    remove authors 2
---
 src/butil/ptr_container.h | 1 -
 1 file changed, 1 deletion(-)

diff --git a/src/butil/ptr_container.h b/src/butil/ptr_container.h
index 16c3b5f..45fccc1 100644
--- a/src/butil/ptr_container.h
+++ b/src/butil/ptr_container.h
@@ -15,7 +15,6 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Author: Ge,Jun (jge666@gmail.com)
 // Date: Fri Sep  7 12:15:23 CST 2018
 
 #ifndef BUTIL_PTR_CONTAINER_H


---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@brpc.apache.org
For additional commands, e-mail: dev-help@brpc.apache.org


[incubator-brpc] 01/03: dos2unix

Posted by ja...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

jamesge pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-brpc.git

commit db210177b16f05ca2b2e424af9259e59b597bbad
Author: jamesge <jg...@gmail.com>
AuthorDate: Fri Jan 3 12:59:03 2020 +0800

    dos2unix
---
 .../policy/weighted_round_robin_load_balancer.cpp  | 513 ++++++++++-----------
 1 file changed, 256 insertions(+), 257 deletions(-)

diff --git a/src/brpc/policy/weighted_round_robin_load_balancer.cpp b/src/brpc/policy/weighted_round_robin_load_balancer.cpp
index c66ae58..1e6add5 100644
--- a/src/brpc/policy/weighted_round_robin_load_balancer.cpp
+++ b/src/brpc/policy/weighted_round_robin_load_balancer.cpp
@@ -15,260 +15,259 @@
 // specific language governing permissions and limitations
 // under the License.
 
-// Authors: Daojin Cai (caidaojin@qiyi.com)
-
-#include <algorithm>
-
-#include "butil/fast_rand.h"
-#include "brpc/socket.h"
-#include "brpc/policy/weighted_round_robin_load_balancer.h"
-#include "butil/strings/string_number_conversions.h"
-
-namespace {
-
-const std::vector<uint64_t> prime_stride = {
-2,3,5,11,17,29,47,71,107,137,163,251,307,379,569,683,857,1289,1543,1949,2617,
-2927,3407,4391,6599,9901,14867,22303,33457,50207,75323,112997,169501,254257,
-381389,572087,849083,1273637,1910471,2865727,4298629,6447943,9671923,14507903,
-21761863,32642861,48964297,73446469,110169743,165254623,247881989,371822987,
-557734537,836601847,1254902827,1882354259,2823531397,4235297173,6352945771,
-9529418671};
-
-bool IsCoprime(uint64_t num1, uint64_t num2) {
-    uint64_t temp;
-    if (num1 < num2) {
-        temp = num1;
-        num1 = num2;
-        num2 = temp;
-    }
-    while (true) {
-        temp = num1 % num2;
-        if (temp == 0) { 
-            break; 
-        } else {
-            num1 = num2;
-            num2 = temp;
-        }
-    }
-    return num2 == 1;
-}
-
-// Get a reasonable stride according to weights configured of servers. 
-uint64_t GetStride(const uint64_t weight_sum, const size_t num) {
-    if (weight_sum == 1) {
-      return 1;
-    } 
-    uint32_t average_weight = weight_sum / num;
-    auto iter = std::lower_bound(prime_stride.begin(), prime_stride.end(), 
-                                 average_weight);
-    while (iter != prime_stride.end()
-           && !IsCoprime(weight_sum, *iter)) {
-        ++iter;
-    }
-    CHECK(iter != prime_stride.end()) << "Failed to get stride";
-    return *iter > weight_sum ? *iter % weight_sum : *iter;  
-}
-
-}  // namespace
-
-namespace brpc {
-namespace policy {
-
-bool WeightedRoundRobinLoadBalancer::Add(Servers& bg, const ServerId& id) {
-    if (bg.server_list.capacity() < 128) {
-        bg.server_list.reserve(128);
-    }
-    uint32_t weight = 0;
-    if (butil::StringToUint(id.tag, &weight) && 
-        weight > 0) {
-        bool insert_server = 
-                 bg.server_map.emplace(id.id, bg.server_list.size()).second;
-        if (insert_server) {
-            bg.server_list.emplace_back(id.id, weight);
-            bg.weight_sum += weight;
-            return true;
-        }
-    } else {
-        LOG(ERROR) << "Invalid weight is set: " << id.tag;
-    }
-    return false;
-}
-
-bool WeightedRoundRobinLoadBalancer::Remove(Servers& bg, const ServerId& id) {
-    auto iter = bg.server_map.find(id.id);
-    if (iter != bg.server_map.end()) {
-        const size_t index = iter->second;
-        bg.weight_sum -= bg.server_list[index].weight;
-        bg.server_list[index] = bg.server_list.back();
-        bg.server_map[bg.server_list[index].id] = index;
-        bg.server_list.pop_back();
-        bg.server_map.erase(iter);
-        return true;
-    }
-    return false;
-}
-
-size_t WeightedRoundRobinLoadBalancer::BatchAdd(
-    Servers& bg, const std::vector<ServerId>& servers) {
-    size_t count = 0;
-    for (size_t i = 0; i < servers.size(); ++i) {
-        count += !!Add(bg, servers[i]);
-    }
-    return count;
-}
-
-size_t WeightedRoundRobinLoadBalancer::BatchRemove(
-    Servers& bg, const std::vector<ServerId>& servers) {
-    size_t count = 0;
-    for (size_t i = 0; i < servers.size(); ++i) {
-        count += !!Remove(bg, servers[i]);
-    }
-    return count;
-}
-
-bool WeightedRoundRobinLoadBalancer::AddServer(const ServerId& id) {
-    return _db_servers.Modify(Add, id);
-}
-
-bool WeightedRoundRobinLoadBalancer::RemoveServer(const ServerId& id) {
-    return _db_servers.Modify(Remove, id);
-}
-
-size_t WeightedRoundRobinLoadBalancer::AddServersInBatch(
-    const std::vector<ServerId>& servers) {
-    const size_t n = _db_servers.Modify(BatchAdd, servers);
-    LOG_IF(ERROR, n != servers.size())
-        << "Fail to AddServersInBatch, expected " << servers.size()
-        << " actually " << n;
-    return n;
-}
-
-size_t WeightedRoundRobinLoadBalancer::RemoveServersInBatch(
-    const std::vector<ServerId>& servers) {
-    const size_t n = _db_servers.Modify(BatchRemove, servers);
-    LOG_IF(ERROR, n != servers.size())
-        << "Fail to RemoveServersInBatch, expected " << servers.size()
-        << " actually " << n;
-    return n;
-}
-
-int WeightedRoundRobinLoadBalancer::SelectServer(const SelectIn& in, SelectOut* out) {
-    butil::DoublyBufferedData<Servers, TLS>::ScopedPtr s;
-    if (_db_servers.Read(&s) != 0) {
-        return ENOMEM;
-    }
-    if (s->server_list.empty()) {
-        return ENODATA;
-    }
-    TLS& tls = s.tls();
-    if (tls.IsNeededCaculateNewStride(s->weight_sum, s->server_list.size())) {
-      if (tls.stride == 0) {
-          tls.position = butil::fast_rand_less_than(s->server_list.size());
-      }
-      tls.stride = GetStride(s->weight_sum, s->server_list.size()); 
-    }
-    // If server list changed, the position may be out of range.
-    tls.position %= s->server_list.size();
-    // Check whether remain server was removed from server list.
-    if (tls.remain_server.weight > 0 && 
-        tls.remain_server.id != s->server_list[tls.position].id) {
-        tls.remain_server.weight = 0;
-    }
-    // The servers that can not be choosed.
-    std::unordered_set<SocketId> filter;
-    TLS tls_temp = tls;
-    uint64_t remain_weight = s->weight_sum;
-    size_t remain_servers = s->server_list.size();
-    while (remain_servers > 0) {
-        SocketId server_id = GetServerInNextStride(s->server_list, filter, tls_temp);
-        if (!ExcludedServers::IsExcluded(in.excluded, server_id)
-            && Socket::Address(server_id, out->ptr) == 0
-            && (*out->ptr)->IsAvailable()) {
-            // update tls.
-            tls.remain_server = tls_temp.remain_server;
-            tls.position = tls_temp.position;
-            return 0;
-        } else {
-            // Skip this invalid server. We need calculate a new stride for server selection.
-            if (--remain_servers == 0) {
-                break;
-            }
-            filter.emplace(server_id);
-            remain_weight -= (s->server_list[s->server_map.at(server_id)]).weight;
-            // Select from begining status.
-            tls_temp.stride = GetStride(remain_weight, remain_servers);
-            tls_temp.position = tls.position;
-            tls_temp.remain_server = tls.remain_server; 
-        }
-    }
-    return EHOSTDOWN;
-}
-
-SocketId WeightedRoundRobinLoadBalancer::GetServerInNextStride(
-        const std::vector<Server>& server_list,
-        const std::unordered_set<SocketId>& filter, 
-        TLS& tls) {
-    SocketId final_server = INVALID_SOCKET_ID;
-    uint64_t stride = tls.stride;
-    Server& remain = tls.remain_server;
-    if (remain.weight > 0) {
-        if (filter.count(remain.id) == 0) {
-            final_server = remain.id;
-            if (remain.weight > stride) { 
-                remain.weight -= stride;
-                return final_server;
-            } else {
-                stride -= remain.weight;
-            }
-        }
-        remain.weight = 0;
-        ++tls.position;
-        tls.position %= server_list.size(); 
-    }
-    while (stride > 0) {
-        final_server = server_list[tls.position].id;
-        if (filter.count(final_server) == 0) {
-            uint32_t configured_weight = server_list[tls.position].weight;
-            if (configured_weight > stride) {
-                remain.id = final_server;
-                remain.weight = configured_weight - stride;
-                return final_server;
-            }
-            stride -= configured_weight;
-        }
-        ++tls.position;
-        tls.position %= server_list.size(); 
-    }
-    return final_server;
-}
-
-LoadBalancer* WeightedRoundRobinLoadBalancer::New(
-    const butil::StringPiece&) const {
-    return new (std::nothrow) WeightedRoundRobinLoadBalancer;
-}
-
-void WeightedRoundRobinLoadBalancer::Destroy() {
-    delete this;
-}
-
-void WeightedRoundRobinLoadBalancer::Describe(
-    std::ostream &os, const DescribeOptions& options) {
-    if (!options.verbose) {
-        os << "wrr";
-        return;
-    }
-    os << "WeightedRoundRobin{";
-    butil::DoublyBufferedData<Servers, TLS>::ScopedPtr s;
-    if (_db_servers.Read(&s) != 0) {
-        os << "fail to read _db_servers";
-    } else {
-        os << "n=" << s->server_list.size() << ':';
-        for (const auto& server : s->server_list) {
-            os << ' ' << server.id << '(' << server.weight << ')';
-        }
-    }
-    os << '}';
-}
-
-}  // namespace policy
-} // namespace brpc
+
+#include <algorithm>
+
+#include "butil/fast_rand.h"
+#include "brpc/socket.h"
+#include "brpc/policy/weighted_round_robin_load_balancer.h"
+#include "butil/strings/string_number_conversions.h"
+
+namespace {
+
+const std::vector<uint64_t> prime_stride = {
+2,3,5,11,17,29,47,71,107,137,163,251,307,379,569,683,857,1289,1543,1949,2617,
+2927,3407,4391,6599,9901,14867,22303,33457,50207,75323,112997,169501,254257,
+381389,572087,849083,1273637,1910471,2865727,4298629,6447943,9671923,14507903,
+21761863,32642861,48964297,73446469,110169743,165254623,247881989,371822987,
+557734537,836601847,1254902827,1882354259,2823531397,4235297173,6352945771,
+9529418671};
+
+bool IsCoprime(uint64_t num1, uint64_t num2) {
+    uint64_t temp;
+    if (num1 < num2) {
+        temp = num1;
+        num1 = num2;
+        num2 = temp;
+    }
+    while (true) {
+        temp = num1 % num2;
+        if (temp == 0) {
+            break;
+        } else {
+            num1 = num2;
+            num2 = temp;
+        }
+    }
+    return num2 == 1;
+}
+
+// Get a reasonable stride according to weights configured of servers.
+uint64_t GetStride(const uint64_t weight_sum, const size_t num) {
+    if (weight_sum == 1) {
+      return 1;
+    }
+    uint32_t average_weight = weight_sum / num;
+    auto iter = std::lower_bound(prime_stride.begin(), prime_stride.end(),
+                                 average_weight);
+    while (iter != prime_stride.end()
+           && !IsCoprime(weight_sum, *iter)) {
+        ++iter;
+    }
+    CHECK(iter != prime_stride.end()) << "Failed to get stride";
+    return *iter > weight_sum ? *iter % weight_sum : *iter;
+}
+
+}  // namespace
+
+namespace brpc {
+namespace policy {
+
+bool WeightedRoundRobinLoadBalancer::Add(Servers& bg, const ServerId& id) {
+    if (bg.server_list.capacity() < 128) {
+        bg.server_list.reserve(128);
+    }
+    uint32_t weight = 0;
+    if (butil::StringToUint(id.tag, &weight) &&
+        weight > 0) {
+        bool insert_server =
+                 bg.server_map.emplace(id.id, bg.server_list.size()).second;
+        if (insert_server) {
+            bg.server_list.emplace_back(id.id, weight);
+            bg.weight_sum += weight;
+            return true;
+        }
+    } else {
+        LOG(ERROR) << "Invalid weight is set: " << id.tag;
+    }
+    return false;
+}
+
+bool WeightedRoundRobinLoadBalancer::Remove(Servers& bg, const ServerId& id) {
+    auto iter = bg.server_map.find(id.id);
+    if (iter != bg.server_map.end()) {
+        const size_t index = iter->second;
+        bg.weight_sum -= bg.server_list[index].weight;
+        bg.server_list[index] = bg.server_list.back();
+        bg.server_map[bg.server_list[index].id] = index;
+        bg.server_list.pop_back();
+        bg.server_map.erase(iter);
+        return true;
+    }
+    return false;
+}
+
+size_t WeightedRoundRobinLoadBalancer::BatchAdd(
+    Servers& bg, const std::vector<ServerId>& servers) {
+    size_t count = 0;
+    for (size_t i = 0; i < servers.size(); ++i) {
+        count += !!Add(bg, servers[i]);
+    }
+    return count;
+}
+
+size_t WeightedRoundRobinLoadBalancer::BatchRemove(
+    Servers& bg, const std::vector<ServerId>& servers) {
+    size_t count = 0;
+    for (size_t i = 0; i < servers.size(); ++i) {
+        count += !!Remove(bg, servers[i]);
+    }
+    return count;
+}
+
+bool WeightedRoundRobinLoadBalancer::AddServer(const ServerId& id) {
+    return _db_servers.Modify(Add, id);
+}
+
+bool WeightedRoundRobinLoadBalancer::RemoveServer(const ServerId& id) {
+    return _db_servers.Modify(Remove, id);
+}
+
+size_t WeightedRoundRobinLoadBalancer::AddServersInBatch(
+    const std::vector<ServerId>& servers) {
+    const size_t n = _db_servers.Modify(BatchAdd, servers);
+    LOG_IF(ERROR, n != servers.size())
+        << "Fail to AddServersInBatch, expected " << servers.size()
+        << " actually " << n;
+    return n;
+}
+
+size_t WeightedRoundRobinLoadBalancer::RemoveServersInBatch(
+    const std::vector<ServerId>& servers) {
+    const size_t n = _db_servers.Modify(BatchRemove, servers);
+    LOG_IF(ERROR, n != servers.size())
+        << "Fail to RemoveServersInBatch, expected " << servers.size()
+        << " actually " << n;
+    return n;
+}
+
+int WeightedRoundRobinLoadBalancer::SelectServer(const SelectIn& in, SelectOut* out) {
+    butil::DoublyBufferedData<Servers, TLS>::ScopedPtr s;
+    if (_db_servers.Read(&s) != 0) {
+        return ENOMEM;
+    }
+    if (s->server_list.empty()) {
+        return ENODATA;
+    }
+    TLS& tls = s.tls();
+    if (tls.IsNeededCaculateNewStride(s->weight_sum, s->server_list.size())) {
+      if (tls.stride == 0) {
+          tls.position = butil::fast_rand_less_than(s->server_list.size());
+      }
+      tls.stride = GetStride(s->weight_sum, s->server_list.size());
+    }
+    // If server list changed, the position may be out of range.
+    tls.position %= s->server_list.size();
+    // Check whether remain server was removed from server list.
+    if (tls.remain_server.weight > 0 &&
+        tls.remain_server.id != s->server_list[tls.position].id) {
+        tls.remain_server.weight = 0;
+    }
+    // The servers that can not be choosed.
+    std::unordered_set<SocketId> filter;
+    TLS tls_temp = tls;
+    uint64_t remain_weight = s->weight_sum;
+    size_t remain_servers = s->server_list.size();
+    while (remain_servers > 0) {
+        SocketId server_id = GetServerInNextStride(s->server_list, filter, tls_temp);
+        if (!ExcludedServers::IsExcluded(in.excluded, server_id)
+            && Socket::Address(server_id, out->ptr) == 0
+            && (*out->ptr)->IsAvailable()) {
+            // update tls.
+            tls.remain_server = tls_temp.remain_server;
+            tls.position = tls_temp.position;
+            return 0;
+        } else {
+            // Skip this invalid server. We need calculate a new stride for server selection.
+            if (--remain_servers == 0) {
+                break;
+            }
+            filter.emplace(server_id);
+            remain_weight -= (s->server_list[s->server_map.at(server_id)]).weight;
+            // Select from begining status.
+            tls_temp.stride = GetStride(remain_weight, remain_servers);
+            tls_temp.position = tls.position;
+            tls_temp.remain_server = tls.remain_server;
+        }
+    }
+    return EHOSTDOWN;
+}
+
+SocketId WeightedRoundRobinLoadBalancer::GetServerInNextStride(
+        const std::vector<Server>& server_list,
+        const std::unordered_set<SocketId>& filter,
+        TLS& tls) {
+    SocketId final_server = INVALID_SOCKET_ID;
+    uint64_t stride = tls.stride;
+    Server& remain = tls.remain_server;
+    if (remain.weight > 0) {
+        if (filter.count(remain.id) == 0) {
+            final_server = remain.id;
+            if (remain.weight > stride) {
+                remain.weight -= stride;
+                return final_server;
+            } else {
+                stride -= remain.weight;
+            }
+        }
+        remain.weight = 0;
+        ++tls.position;
+        tls.position %= server_list.size();
+    }
+    while (stride > 0) {
+        final_server = server_list[tls.position].id;
+        if (filter.count(final_server) == 0) {
+            uint32_t configured_weight = server_list[tls.position].weight;
+            if (configured_weight > stride) {
+                remain.id = final_server;
+                remain.weight = configured_weight - stride;
+                return final_server;
+            }
+            stride -= configured_weight;
+        }
+        ++tls.position;
+        tls.position %= server_list.size();
+    }
+    return final_server;
+}
+
+LoadBalancer* WeightedRoundRobinLoadBalancer::New(
+    const butil::StringPiece&) const {
+    return new (std::nothrow) WeightedRoundRobinLoadBalancer;
+}
+
+void WeightedRoundRobinLoadBalancer::Destroy() {
+    delete this;
+}
+
+void WeightedRoundRobinLoadBalancer::Describe(
+    std::ostream &os, const DescribeOptions& options) {
+    if (!options.verbose) {
+        os << "wrr";
+        return;
+    }
+    os << "WeightedRoundRobin{";
+    butil::DoublyBufferedData<Servers, TLS>::ScopedPtr s;
+    if (_db_servers.Read(&s) != 0) {
+        os << "fail to read _db_servers";
+    } else {
+        os << "n=" << s->server_list.size() << ':';
+        for (const auto& server : s->server_list) {
+            os << ' ' << server.id << '(' << server.weight << ')';
+        }
+    }
+    os << '}';
+}
+
+}  // namespace policy
+} // namespace brpc


---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@brpc.apache.org
For additional commands, e-mail: dev-help@brpc.apache.org