• strom DRPC LinearDRPCTopologyBuilder 源码 的巧妙之处


    前段时间公司做接口封装。 领导推荐一种封装规范。
    
    processor : 传入string[]  params, 实现逻辑自己去根据processor接口规范实现
    init(params) 和 execute()
    
    对于每个接口形成参数模板,初始化,执行之后,返回实体,得到有效实体,保存到数据库。
    
    相当于对processor 的方法体进行参数化。
    与storm drpc 的LinearDRPCTopologyBuilder 非常相似。
    
    源码
    package backtype.storm.drpc;
    @Deprecated
    public class LinearDRPCTopologyBuilder {    
        String _function;
        List<Component> _components = new ArrayList<Component>();
        
        
        public LinearDRPCTopologyBuilder(String function) {
            _function = function;
        }
        .............    
    }
    
    
    
    开发人员调用
    /**
     * Licensed to the Apache Software Foundation (ASF) under one
     * or more contributor license agreements.  See the NOTICE file
     * distributed with this work for additional information
     * regarding copyright ownership.  The ASF licenses this file
     * to you under the Apache License, Version 2.0 (the
     * "License"); you may not use this file except in compliance
     * with the License.  You may obtain a copy of the License at
     *
     * http://www.apache.org/licenses/LICENSE-2.0
     *
     * Unless required by applicable law or agreed to in writing, software
     * distributed under the License is distributed on an "AS IS" BASIS,
     * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
     * See the License for the specific language governing permissions and
     * limitations under the License.
     */
    package com.sxt.storm.drpc;
    
    import backtype.storm.Config;
    import backtype.storm.LocalCluster;
    import backtype.storm.LocalDRPC;
    import backtype.storm.StormSubmitter;
    import backtype.storm.drpc.LinearDRPCTopologyBuilder;
    import backtype.storm.topology.BasicOutputCollector;
    import backtype.storm.topology.OutputFieldsDeclarer;
    import backtype.storm.topology.base.BaseBasicBolt;
    import backtype.storm.tuple.Fields;
    import backtype.storm.tuple.Tuple;
    import backtype.storm.tuple.Values;
    
    /**
     * This topology is a basic example of doing distributed RPC on top of Storm. It
     * implements a function that appends a "!" to any string you send the DRPC
     * function.
     * <p/>
     * See https://github.com/nathanmarz/storm/wiki/Distributed-RPC for more
     * information on doing distributed RPC on top of Storm.
     */
    public class BasicDRPCTopology {
    	public static class ExclaimBolt extends BaseBasicBolt {
    		@Override
    		public void execute(Tuple tuple, BasicOutputCollector collector) {
    			String input = tuple.getString(1);
    			collector.emit(new Values(tuple.getValue(0), input + "!"));
    		}
    
    		@Override
    		public void declareOutputFields(OutputFieldsDeclarer declarer) {
    			declarer.declare(new Fields("id", "result"));
    		}
    
    	}
    
    	public static void main(String[] args) throws Exception {
    		LinearDRPCTopologyBuilder builder = new LinearDRPCTopologyBuilder("exclamation");
    		builder.addBolt(new ExclaimBolt(), 3);
    
    		Config conf = new Config();
    
    		if (args == null || args.length == 0) {
    			LocalDRPC drpc = new LocalDRPC();
    			LocalCluster cluster = new LocalCluster();
    
    			cluster.submitTopology("drpc-demo", conf, builder.createLocalTopology(drpc));
    
    			for (String word : new String[] { "hello", "goodbye" }) {
    				System.err.println("Result for "" + word + "": " + drpc.execute("exclamation", word));
    			}
    
    			cluster.shutdown();
    			drpc.shutdown();
    		} else {
    			conf.setNumWorkers(3);
    			StormSubmitter.submitTopologyWithProgressBar(args[0], conf, builder.createRemoteTopology());
    		}
    	}
    }
    

     

    /**
     * Licensed to the Apache Software Foundation (ASF) under one
     * or more contributor license agreements.  See the NOTICE file
     * distributed with this work for additional information
     * regarding copyright ownership.  The ASF licenses this file
     * to you under the Apache License, Version 2.0 (the
     * "License"); you may not use this file except in compliance
     * with the License.  You may obtain a copy of the License at
     *
     * http://www.apache.org/licenses/LICENSE-2.0
     *
     * Unless required by applicable law or agreed to in writing, software
     * distributed under the License is distributed on an "AS IS" BASIS,
     * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
     * See the License for the specific language governing permissions and
     * limitations under the License.
     */
    package backtype.storm.drpc;
    
    import backtype.storm.Config;
    import backtype.storm.ILocalDRPC;
    import backtype.storm.generated.DRPCRequest;
    import backtype.storm.generated.DistributedRPCInvocations;
    import backtype.storm.spout.SpoutOutputCollector;
    import backtype.storm.task.TopologyContext;
    import backtype.storm.topology.OutputFieldsDeclarer;
    import backtype.storm.topology.base.BaseRichSpout;
    import backtype.storm.tuple.Fields;
    import backtype.storm.tuple.Values;
    import backtype.storm.utils.ServiceRegistry;
    import backtype.storm.utils.Utils;
    import java.util.ArrayList;
    import java.util.HashMap;
    import java.util.List;
    import java.util.Map;
    import org.slf4j.Logger;
    import org.slf4j.LoggerFactory;
    import org.apache.thrift.TException;
    import org.json.simple.JSONValue;
    
    public class DRPCSpout extends BaseRichSpout {
        public static Logger LOG = LoggerFactory.getLogger(DRPCSpout.class);
        
        SpoutOutputCollector _collector;
        List<DRPCInvocationsClient> _clients = new ArrayList<DRPCInvocationsClient>();
        String _function;
        String _local_drpc_id = null;
        
        private static class DRPCMessageId {
            String id;
            int index;
            
            public DRPCMessageId(String id, int index) {
                this.id = id;
                this.index = index;
            }
        }
        
        
        public DRPCSpout(String function) {
            _function = function;
        }
    
        public DRPCSpout(String function, ILocalDRPC drpc) {
            _function = function;
            _local_drpc_id = drpc.getServiceId();
        }
        
        @Override
        public void open(Map conf, TopologyContext context, SpoutOutputCollector collector) {
            _collector = collector;
            if(_local_drpc_id==null) {
                int numTasks = context.getComponentTasks(context.getThisComponentId()).size();
                int index = context.getThisTaskIndex();
    
                int port = Utils.getInt(conf.get(Config.DRPC_INVOCATIONS_PORT));
                List<String> servers = (List<String>) conf.get(Config.DRPC_SERVERS);
                if(servers == null || servers.isEmpty()) {
                    throw new RuntimeException("No DRPC servers configured for topology");   
                }
                if(numTasks < servers.size()) {
                    for(String s: servers) {
                        _clients.add(new DRPCInvocationsClient(s, port));
                    }
                } else {
                    int i = index % servers.size();
                    _clients.add(new DRPCInvocationsClient(servers.get(i), port));
                }
            }
            
        }
    
        @Override
        public void close() {
            for(DRPCInvocationsClient client: _clients) {
                client.close();
            }
        }
    
        @Override
        public void nextTuple() {
            boolean gotRequest = false;
            if(_local_drpc_id==null) {
                for(int i=0; i<_clients.size(); i++) {
                    DRPCInvocationsClient client = _clients.get(i);
                    try {
                        DRPCRequest req = client.fetchRequest(_function);
                        if(req.get_request_id().length() > 0) {
                            Map returnInfo = new HashMap();
                            returnInfo.put("id", req.get_request_id());
                            returnInfo.put("host", client.getHost());
                            returnInfo.put("port", client.getPort());
                            gotRequest = true;
                            _collector.emit(new Values(req.get_func_args(), JSONValue.toJSONString(returnInfo)), new DRPCMessageId(req.get_request_id(), i));
                            break;
                        }
                    } catch (Exception e) {
                        LOG.error("Failed to fetch DRPC result from DRPC server", e);
                    }
                }
            } else {
                DistributedRPCInvocations.Iface drpc = (DistributedRPCInvocations.Iface) ServiceRegistry.getService(_local_drpc_id);
                if(drpc!=null) { // can happen during shutdown of drpc while topology is still up
                    try {
                        DRPCRequest req = drpc.fetchRequest(_function);
                        if(req.get_request_id().length() > 0) {
                            Map returnInfo = new HashMap();
                            returnInfo.put("id", req.get_request_id());
                            returnInfo.put("host", _local_drpc_id);
                            returnInfo.put("port", 0);
                            gotRequest = true;
                            _collector.emit(new Values(req.get_func_args(), JSONValue.toJSONString(returnInfo)), new DRPCMessageId(req.get_request_id(), 0));
                        }
                    } catch (TException e) {
                        throw new RuntimeException(e);
                    }
                }
            }
            if(!gotRequest) {
                Utils.sleep(1);
            }
        }
    
        @Override
        public void ack(Object msgId) {
        }
    
        @Override
        public void fail(Object msgId) {
            DRPCMessageId did = (DRPCMessageId) msgId;
            DistributedRPCInvocations.Iface client;
            
            if(_local_drpc_id == null) {
                client = _clients.get(did.index);
            } else {
                client = (DistributedRPCInvocations.Iface) ServiceRegistry.getService(_local_drpc_id);
            }
            try {
                client.failRequest(did.id);
            } catch (TException e) {
                LOG.error("Failed to fail request", e);
            }
        }
    
        @Override
        public void declareOutputFields(OutputFieldsDeclarer declarer) {
            declarer.declare(new Fields("args", "return-info"));
        }    
    }
    

      

    /**
     * Licensed to the Apache Software Foundation (ASF) under one
     * or more contributor license agreements.  See the NOTICE file
     * distributed with this work for additional information
     * regarding copyright ownership.  The ASF licenses this file
     * to you under the Apache License, Version 2.0 (the
     * "License"); you may not use this file except in compliance
     * with the License.  You may obtain a copy of the License at
     *
     * http://www.apache.org/licenses/LICENSE-2.0
     *
     * Unless required by applicable law or agreed to in writing, software
     * distributed under the License is distributed on an "AS IS" BASIS,
     * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
     * See the License for the specific language governing permissions and
     * limitations under the License.
     */
    package backtype.storm.drpc;
    
    import backtype.storm.task.TopologyContext;
    import backtype.storm.topology.BasicOutputCollector;
    import backtype.storm.topology.OutputFieldsDeclarer;
    import backtype.storm.topology.base.BaseBasicBolt;
    import backtype.storm.tuple.Fields;
    import backtype.storm.tuple.Tuple;
    import backtype.storm.tuple.Values;
    import java.util.Map;
    import java.util.Random;
    import backtype.storm.utils.Utils;
    
    
    public class PrepareRequest extends BaseBasicBolt {
        public static final String ARGS_STREAM = Utils.DEFAULT_STREAM_ID;
        public static final String RETURN_STREAM = "ret";
        public static final String ID_STREAM = "id";
    
        Random rand;
    
        @Override
        public void prepare(Map map, TopologyContext context) {
            rand = new Random();
        }
    
        @Override
        public void execute(Tuple tuple, BasicOutputCollector collector) {
            String args = tuple.getString(0);
            String returnInfo = tuple.getString(1);
            long requestId = rand.nextLong();
            collector.emit(ARGS_STREAM, new Values(requestId, args));
            collector.emit(RETURN_STREAM, new Values(requestId, returnInfo));
            collector.emit(ID_STREAM, new Values(requestId));
        }
    
        public void declareOutputFields(OutputFieldsDeclarer declarer) {
            declarer.declareStream(ARGS_STREAM, new Fields("request", "args"));
            declarer.declareStream(RETURN_STREAM, new Fields("request", "return"));
            declarer.declareStream(ID_STREAM, new Fields("request"));
        }
    }
    

      

     

  • 相关阅读:
    K3/Cloud点按钮打开单据,列表,动态表单,简单账表和直接Sql报表示例
    K3/Cloud点击按钮打开第三方URL
    List排序
    ClientScriptManager与ScriptManager向客户端注册脚本的区别
    NameValueCollection详解
    Delegate。。
    asp.net gridview ...
    asp json
    合并两个rs结果输出
    asp 数组
  • 原文地址:https://www.cnblogs.com/xhzd/p/11616032.html
Copyright © 2020-2023  润新知