pipeline_server.py 11.9 KB
Newer Older
1 2 3 4 5 6 7 8 9 10 11 12 13 14
#   Copyright (c) 2020 PaddlePaddle Authors. All Rights Reserved.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
#     http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
# pylint: disable=doc-string-missing
15 16 17
from concurrent import futures
import grpc
import logging
18
import json
B
barrierye 已提交
19
import socket
B
barrierye 已提交
20
import contextlib
B
barrierye 已提交
21
from contextlib import closing
B
barrierye 已提交
22
import multiprocessing
B
barrierye 已提交
23
import yaml
24

B
barrierye 已提交
25
from .proto import pipeline_service_pb2_grpc
B
barriery 已提交
26
from .operator import ResponseOp, RequestOp
27
from .dag import DAGExecutor, DAG
B
barriery 已提交
28
from .util import AvailablePortGenerator
29

30
_LOGGER = logging.getLogger(__name__)
31 32


B
barriery 已提交
33
class PipelineServicer(pipeline_service_pb2_grpc.PipelineServiceServicer):
34
    def __init__(self, response_op, dag_conf, worker_idx=-1):
B
barriery 已提交
35
        super(PipelineServicer, self).__init__()
B
barrierye 已提交
36
        # init dag executor
37
        self._dag_executor = DAGExecutor(response_op, dag_conf, worker_idx)
B
barrierye 已提交
38
        self._dag_executor.start()
B
barriery 已提交
39
        _LOGGER.info("[PipelineServicer] succ init")
40 41

    def inference(self, request, context):
42
        resp = self._dag_executor.call(request)
43 44
        return resp

B
barrierye 已提交
45

B
barrierye 已提交
46 47 48 49 50 51 52 53 54 55 56 57 58 59
@contextlib.contextmanager
def _reserve_port(port):
    """Find and reserve a port for all subprocesses to use."""
    sock = socket.socket(socket.AF_INET6, socket.SOCK_STREAM)
    sock.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEPORT, 1)
    if sock.getsockopt(socket.SOL_SOCKET, socket.SO_REUSEPORT) == 0:
        raise RuntimeError("Failed to set SO_REUSEPORT.")
    sock.bind(('', port))
    try:
        yield sock.getsockname()[1]
    finally:
        sock.close()


60
class PipelineServer(object):
B
barrierye 已提交
61
    def __init__(self):
62 63
        self._port = None
        self._worker_num = None
B
barrierye 已提交
64
        self._response_op = None
B
barriery 已提交
65 66
        self._proxy_server = None

B
barriery 已提交
67
    def _grpc_gateway(self, grpc_port, http_port):
B
barriery 已提交
68 69 70 71 72 73
        import os
        from ctypes import cdll
        from . import gateway
        lib_path = os.path.join(
            os.path.dirname(gateway.__file__), "libproxy_server.so")
        proxy_server = cdll.LoadLibrary(lib_path)
B
barriery 已提交
74
        proxy_server.run_proxy_server(grpc_port, http_port)
B
barriery 已提交
75

B
barriery 已提交
76 77
    def _run_grpc_gateway(self, grpc_port, http_port):
        if http_port <= 0:
B
barriery 已提交
78 79
            _LOGGER.info("Ignore grpc_gateway configuration.")
            return
B
barriery 已提交
80
        if not AvailablePortGenerator.port_is_available(http_port):
B
barriery 已提交
81
            raise SystemExit("Failed to run grpc-gateway: prot {} "
B
barriery 已提交
82
                             "is already used".format(http_port))
B
barriery 已提交
83 84 85
        if self._proxy_server is not None:
            raise RuntimeError("Proxy server has been started.")
        self._proxy_server = multiprocessing.Process(
B
barriery 已提交
86 87 88
            target=self._grpc_gateway, args=(
                grpc_port,
                http_port, ))
B
barriery 已提交
89 90
        self._proxy_server.daemon = True
        self._proxy_server.start()
91

B
barrierye 已提交
92
    def set_response_op(self, response_op):
B
barrierye 已提交
93
        if not isinstance(response_op, ResponseOp):
B
barriery 已提交
94 95
            raise Exception("Failed to set response_op: response_op "
                            "must be ResponseOp type.")
B
barrierye 已提交
96
        if len(response_op.get_input_ops()) != 1:
B
barriery 已提交
97 98
            raise Exception("Failed to set response_op: response_op "
                            "can only have one previous op.")
B
barrierye 已提交
99 100
        self._response_op = response_op

B
barriery 已提交
101 102 103
    def prepare_server(self, yml_file=None, yml_dict=None):
        conf = ServerYamlConfChecker.load_server_yaml_conf(
            yml_file=yml_file, yml_dict=yml_dict)
B
barriery 已提交
104

105
        self._port = conf["port"]
B
barriery 已提交
106
        if not AvailablePortGenerator.port_is_available(self._port):
B
barriery 已提交
107 108
            raise SystemExit("Failed to prepare_server: prot {} "
                             "is already used".format(self._port))
109
        self._worker_num = conf["worker_num"]
B
barriery 已提交
110
        self._grpc_gateway_port = conf["grpc_gateway_port"]
111
        self._build_dag_each_worker = conf["build_dag_each_worker"]
B
barriery 已提交
112

B
barrierye 已提交
113
        _LOGGER.info("============= PIPELINE SERVER =============")
114 115 116
        _LOGGER.info("\n{}".format(
            json.dumps(
                conf, indent=4, separators=(',', ':'))))
117
        if self._build_dag_each_worker is True:
B
bug fix  
barrierye 已提交
118 119 120
            _LOGGER.warning(
                "(Make sure that install grpcio whl with --no-binary flag: "
                "pip install grpcio --no-binary grpcio)")
B
barrierye 已提交
121
        _LOGGER.info("-------------------------------------------")
122

B
barriery 已提交
123
        self._conf = conf
B
barrierye 已提交
124

125 126 127 128
    def start_local_rpc_service(self):
        # only brpc now
        used_op, _ = DAG.get_use_ops(self._response_op)
        for op in used_op:
B
barriery 已提交
129 130
            if not isinstance(op, RequestOp):
                op.launch_local_rpc_service()
131

132
    def run_server(self):
133
        if self._build_dag_each_worker:
B
barrierye 已提交
134 135 136 137 138 139 140
            with _reserve_port(self._port) as port:
                bind_address = 'localhost:{}'.format(port)
                workers = []
                for i in range(self._worker_num):
                    show_info = (i == 0)
                    worker = multiprocessing.Process(
                        target=self._run_server_func,
141
                        args=(bind_address, self._response_op, self._conf, i))
B
barrierye 已提交
142 143
                    worker.start()
                    workers.append(worker)
B
barriery 已提交
144
                self._run_grpc_gateway(
B
barriery 已提交
145 146
                    grpc_port=self._port,
                    http_port=self._grpc_gateway_port)  # start grpc_gateway
B
barrierye 已提交
147 148 149 150
                for worker in workers:
                    worker.join()
        else:
            server = grpc.server(
B
bug fix  
barrierye 已提交
151 152
                futures.ThreadPoolExecutor(max_workers=self._worker_num),
                options=[('grpc.max_send_message_length', 256 * 1024 * 1024),
B
barriery 已提交
153 154
                         ('grpc.max_receive_message_length', 256 * 1024 * 1024)
                         ])
B
barrierye 已提交
155
            pipeline_service_pb2_grpc.add_PipelineServiceServicer_to_server(
B
barriery 已提交
156
                PipelineServicer(self._response_op, self._conf), server)
B
barrierye 已提交
157 158
            server.add_insecure_port('[::]:{}'.format(self._port))
            server.start()
B
barriery 已提交
159
            self._run_grpc_gateway(
B
barriery 已提交
160 161
                grpc_port=self._port,
                http_port=self._grpc_gateway_port)  # start grpc_gateway
B
barrierye 已提交
162 163
            server.wait_for_termination()

164
    def _run_server_func(self, bind_address, response_op, dag_conf, worker_idx):
B
bug fix  
barrierye 已提交
165
        options = [('grpc.so_reuseport', 1),
B
barriery 已提交
166 167
                   ('grpc.max_send_message_length', 256 * 1024 * 1024),
                   ('grpc.max_send_message_length', 256 * 1024 * 1024)]
168
        server = grpc.server(
B
barrierye 已提交
169
            futures.ThreadPoolExecutor(
B
barrierye 已提交
170
                max_workers=1, ), options=options)
B
barrierye 已提交
171
        pipeline_service_pb2_grpc.add_PipelineServiceServicer_to_server(
172
            PipelineServicer(response_op, dag_conf, worker_idx), server)
B
barrierye 已提交
173
        server.add_insecure_port(bind_address)
174 175
        server.start()
        server.wait_for_termination()
176 177 178 179 180 181 182


class ServerYamlConfChecker(object):
    def __init__(self):
        pass

    @staticmethod
B
barriery 已提交
183 184 185 186 187 188 189 190 191 192 193 194
    def load_server_yaml_conf(yml_file=None, yml_dict=None):
        if yml_file is not None and yml_dict is not None:
            raise SystemExit("Failed to prepare_server: only one of yml_file"
                             " or yml_dict can be selected as the parameter.")
        if yml_file is not None:
            with open(yml_file) as f:
                conf = yaml.load(f.read())
        elif yml_dict is not None:
            conf = yml_dict
        else:
            raise SystemExit("Failed to prepare_server: yml_file or yml_dict"
                             " can not be None.")
195 196
        ServerYamlConfChecker.check_server_conf(conf)
        ServerYamlConfChecker.check_dag_conf(conf["dag"])
B
barriery 已提交
197
        ServerYamlConfChecker.check_tracer_conf(conf["dag"]["tracer"])
198 199
        return conf

B
barriery 已提交
200 201 202 203 204 205
    @staticmethod
    def check_conf(conf, default_conf, conf_type, conf_qualification):
        ServerYamlConfChecker.fill_with_default_conf(conf, default_conf)
        ServerYamlConfChecker.check_conf_type(conf, conf_type)
        ServerYamlConfChecker.check_conf_qualification(conf, conf_qualification)

206 207 208 209 210 211
    @staticmethod
    def check_server_conf(conf):
        default_conf = {
            "port": 9292,
            "worker_num": 1,
            "build_dag_each_worker": False,
B
barriery 已提交
212
            "grpc_gateway_port": 0,
213 214 215 216 217 218 219
            "dag": {},
        }

        conf_type = {
            "port": int,
            "worker_num": int,
            "build_dag_each_worker": bool,
B
barriery 已提交
220
            "grpc_gateway_port": int,
221 222 223 224 225 226 227
        }

        conf_qualification = {
            "port": [(">=", 1024), ("<=", 65535)],
            "worker_num": (">=", 1),
        }

B
barriery 已提交
228 229 230 231 232
        ServerYamlConfChecker.check_conf(conf, default_conf, conf_type,
                                         conf_qualification)

    @staticmethod
    def check_tracer_conf(conf):
B
bug fix  
barrierye 已提交
233
        default_conf = {"interval_s": -1, }
B
barriery 已提交
234 235 236 237 238 239 240

        conf_type = {"interval_s": int, }

        conf_qualification = {}

        ServerYamlConfChecker.check_conf(conf, default_conf, conf_type,
                                         conf_qualification)
241 242 243 244 245 246 247 248

    @staticmethod
    def check_dag_conf(conf):
        default_conf = {
            "retry": 1,
            "client_type": "brpc",
            "use_profile": False,
            "channel_size": 0,
B
barriery 已提交
249 250
            "is_thread_op": True,
            "tracer": {},
251 252 253 254 255 256 257 258 259 260 261 262 263 264 265 266
        }

        conf_type = {
            "retry": int,
            "client_type": str,
            "use_profile": bool,
            "channel_size": int,
            "is_thread_op": bool,
        }

        conf_qualification = {
            "retry": (">=", 1),
            "client_type": ("in", ["brpc", "grpc"]),
            "channel_size": (">=", 0),
        }

B
barriery 已提交
267 268
        ServerYamlConfChecker.check_conf(conf, default_conf, conf_type,
                                         conf_qualification)
269 270 271 272 273 274 275 276 277 278 279 280 281 282 283 284 285 286 287 288 289 290 291 292 293 294 295 296 297 298 299 300 301 302 303 304 305 306 307 308 309 310 311 312 313 314 315 316 317 318 319 320 321

    @staticmethod
    def fill_with_default_conf(conf, default_conf):
        for key, val in default_conf.items():
            if conf.get(key) is None:
                _LOGGER.warning("[CONF] {} not set, use default: {}"
                                .format(key, val))
                conf[key] = val

    @staticmethod
    def check_conf_type(conf, conf_type):
        for key, val in conf_type.items():
            if not isinstance(conf[key], val):
                raise SystemExit("[CONF] {} must be {} type, but get {}."
                                 .format(key, val, type(conf[key])))

    @staticmethod
    def check_conf_qualification(conf, conf_qualification):
        for key, qualification in conf_qualification.items():
            if not isinstance(qualification, list):
                qualification = [qualification]
            if not ServerYamlConfChecker.qualification_check(conf[key],
                                                             qualification):
                raise SystemExit("[CONF] {} must be {}, but get {}."
                                 .format(key, ", ".join([
                                     "{} {}"
                                     .format(q[0], q[1]) for q in qualification
                                 ]), conf[key]))

    @staticmethod
    def qualification_check(value, qualifications):
        if not isinstance(qualifications, list):
            qualifications = [qualifications]
        ok = True
        for q in qualifications:
            operator, limit = q
            if operator == "<":
                ok = value < limit
            elif operator == "==":
                ok = value == limit
            elif operator == ">":
                ok = value > limit
            elif operator == "<=":
                ok = value <= limit
            elif operator == ">=":
                ok = value >= limit
            elif operator == "in":
                ok = value in limit
            else:
                raise SystemExit("unknow operator: {}".format(operator))
            if ok == False:
                break
        return ok