记一次异步转同步的经历

         工作中会经常遇到一些对数据进行加工的场景,这些数据来自很多地方,一般通过HTTP、RPC等方式去调用,数据源返回的报文也一般都是JSON、XML等格式。其中大部分数据源是同步返回,但有些数据源是异步返回的(也就是说数据源的数据是数据源提供方回调给你的)。

        此时如果你的加工逻辑是必须要等到所有的数据都加载完毕才能开始加工的话,就会比较麻烦,因为有些数据是异步数据源回调给你的(需要你的程序有回调接口),但是处理程序并不知道异步数据源何时回调给你数据。那么如何处理这种情况呢?

方式一:利用循环:

  1. 调用外部数据源的结束后,如果调用成功,则 设置缓存(Map、Redis、Mysql),缓存key:为 当前流水号+数据源编码,缓存Value:Null
  2. 设置完缓存Key,程序开始循环查询该Key下是否有数据,如果有数据,则跳出循环执行后续程序,如果没有数据则继续执行循环。
  3. 异步数据源回调接口接收到异步数据源的请求,将请求报文设置到第一步的缓存中

       虽然上面的方案容易实现也容易理解,但是实现效果并不优雅,循环会比较耗费性能,即使可以在循环的过程中设置一定的休眠时间,但在时效性比较高的场景下,也并不合适。

      除了方式一之外,还有其他更优雅的实现方式吗?答案是肯定的,那么回到问题本身,程序无非是希望可以同步获取到数据,以方便后续对数据进行加工,但是异步数据源调用时同步返回的并不是你想要的数据,而是该数据源调用是否成功,真正的数据是数据源回调给你的,数据入口也随之改变了,因此问题就变成了:如果异步数据源调用成功,如何在当前线程等待异步数据源把程序需要的数据给回调(注意程序的回调接口是另外的线程了)回来,并由当前线程来获取呢?  其中方式一的解决方案就是循环等待取缓存。所以这里面重点关注的其实就是:等待和消息  

    等待也即阻塞一般第一时间想到的是锁,也就是说调用完异步数据源是否可以马上进行加锁等待,答案是可以的,但是随之的问题就是异步数据源回调之后怎么解开这个锁,以目前Java来说并没有较好的实现形式,可能需要借助一些工具才能实现。同时需要考虑的是即使数据源的回调接口可以解锁,那么回调接口又怎么把数据传递给加锁的线程呢?

    因此这个场景的最优解就是找到既有阻塞功能又有消息获取的一种形式,此时答案就已经呼之欲出了,消息队列

方式二:消息队列

  1. 调用外部数据源的结束后,如果调用成功,则创建队列:队列名:当前流水号+数据源编码
  2. 当前线程开启监听该队列(阻塞)
  3. 异步数据源回调接口接收到异步数据源的请求,将报文推送到步骤1的队列中去
  4. 当前线程获取到该队列的消息,结束阻塞继续执行

    以上就是使用队列实现异步转同步的形式,简单来说就是利用队列来实现阻塞和获取消息的目的,当然一提到队列,可能首先想到的是RabbitMq、Kafka之类的消息中间件

    但我们一般使用RabbitMq、Kafka都是用来监听一些预设的队列,这些队列用来处理固定的几种业务,通常会有多个生产者和多个消费者,消费者和生产者的数量一般都是固定的,消费的逻辑也大致相同,但该场景的情况是,消费者都是临时的、一次性的(线程维度,消费者获取到消息后,就会停止监听),比如线程A调用完异步接口,接着线程A就开始监听队列,接收到属于自己的消息后(可以判断消息是否是自己的消息,比如通过判断消息头里的属性(生产者设置)),断开监听,继续执行代码。因此该场景的消费者、生产者的数量是由请求频率决定的。不过在使用Mq时还会遇到一个问题那就是,假如有多个线程都在监听同一个队列,由于每个线程需要的信息时不同的(因为有可能是多条请求),那么此时就会造成很多消费失败的情况(消费者获取到的消息不是本线程需要的消息),消息可能会重新入队。最终导致mq的性能下降。因此使用预设队列的形式是有些问题的。

    上面描述的是使用预设队列的形式,还有一种形式就是动态队列:也即每笔请求,都会有相应的流水号,比如线程A调用完异步接口,根据流水号和数据源编码动态创建队列,接着线程A就开始监听该队列,然后回调接口接收到外部数据的回调信息,往相应的队列中插入数据,此时线程A接收到消息,断开监听,继续执行代码。

   如何实现动态队列呢?

   首先队列的两个主要功能要实现,即监听队列和推送消息。

/**
 * 消息管道接口
 */
public interface MessageChannel {

    /**
     * 发布消息
     * @param channelName 管道名
     * @param message  消息内容
     */
    void publishMessage(String channelName, String message);

    /**
     * 订阅消息
     * @param channelName 管道名
     * @return
     */
    String subscribeMessage(String channelName);

    /**
     * 生成管道名称
     * @param serialNumber 请求流水号(该流水号应该是透传的,即异步请求时,该流水号传递给数据源,数据源回调时,该流水号再回传回来)
     * @param dataSourceCode  数据源编码
     * @return
     */
    default String generateChannelName(String serialNumber,String dataSourceCode) {
        return serialNumber + ":" + dataSourceCode;
    }
}

实现一:

import org.springframework.stereotype.Component;

import java.util.HashMap;
import java.util.concurrent.BlockingQueue;
import java.util.concurrent.SynchronousQueue;

/**
 * Jvm级别的消息管道
 */
@Component
public class LocalMessageChannel implements MessageChannel{

    /**
     * 队列集合,一个时间段内的请求可能会比较大
     */
    private static HashMap<String, BlockingQueue<String>> CHANNEL_COLLECTION = new HashMap<>();

    @Override
    public void publishMessage(String channelName, String message) {
        CHANNEL_COLLECTION.get(channelName).add(message);
    }

    @Override
    public String subscribeMessage(String channelName) {
        createChannel(channelName);
        BlockingQueue<String> blockingQueue = CHANNEL_COLLECTION.get(channelName);
//        阻塞获取消息
        String message = null;
        try {
//              可设置阻塞时间,避免回调时间过长
//            message = blockingQueue.poll(60, TimeUnit.SECONDS);
            message = blockingQueue.take();
        } catch (InterruptedException e) {
            e.printStackTrace();
        }
//        获取到消息后,移除该队列
        CHANNEL_COLLECTION.remove(channelName);
        return message;
    }

    /**
     * 创建管道
     * @param channelName
     */
    private void createChannel(String channelName) {
//        SynchronousQueue队列内部仅允许容纳一个元素。当一个线程插入一个元素后会被阻塞,除非这个元素被另一个线程消费
//        由于业务的特殊性,采用临时队列(消费一次,队列即可删除),该队列只需容纳一条消息即可
        SynchronousQueue synchronousQueue = new SynchronousQueue();
        CHANNEL_COLLECTION.put(channelName, synchronousQueue);

    }
}

伪代码:

订阅消息:

import com.alibaba.fastjson.JSONObject;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.beans.factory.annotation.Qualifier;
import org.springframework.web.bind.annotation.RequestMapping;
import org.springframework.web.bind.annotation.RestController;
import org.springframework.web.client.RestTemplate;

import java.net.URI;

@RequestMapping("dataSource")
@RestController
public class UserInfoController {

    @Autowired
    private RestTemplate restTemplate;

    @Autowired
    @Qualifier("localMessageChannel")
    private MessageChannel messageChannel;

    /**
     * 请求异步数据源,并等待异步数据源的回调,等待机制使用队列
     * 注意流水号需要透传
     * @param serialNumber 流水号
     * @return
     */
    @RequestMapping("/userInfo")
    public String userInfo(String serialNumber) {
//        注意该请求是异步请求(流水号透传)
        String forObject = restTemplate.getForObject(URI.create("http://xxxx?serialNumber=" + serialNumber), String.class);
        JSONObject jsonObject = JSONObject.parseObject(forObject);
//        todo 判断异步请求是否成功,省略
//        如果成功 (数据源编码是常量)
        String channelName = messageChannel.generateChannelName(serialNumber, "USERINFO");
//        阻塞获取消息(直到管道中被推送了消息)
        String message = messageChannel.subscribeMessage(channelName);
        return message;
    }
}

推送消息:

import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.beans.factory.annotation.Qualifier;
import org.springframework.web.bind.annotation.RequestMapping;
import org.springframework.web.bind.annotation.RestController;
import org.springframework.web.client.RestTemplate;

@RequestMapping("callback")
@RestController
public class CallBackController {

    @Autowired
    private RestTemplate restTemplate;

    @Autowired
    @Qualifier("localMessageChannel")
    private MessageChannel messageChannel;

    /**
     * 异步数据源回调
     * @param serialNumber  流水号(透传)
     * @param dataSourceCode 数据源编码
     * @param request 回调内容
     * @return
     */
    @RequestMapping("/dataSource")
    public String userInfo(String serialNumber,String dataSourceCode,String request) {
//        根据回调的请求体,生成需要推送的管道名称
        String channelName = messageChannel.generateChannelName(serialNumber, dataSourceCode);
//        推送消息
        messageChannel.publishMessage(channelName,request);
        return "SUCCESS";
    }
}

     上面的代码是实现动态队列的方式之一,但是有一个问题那就是他是JVM级别的,也就是说不能跨进程,实际生产环境中,每个服务可能不止一个实例,因此如果发起请求的服务实例,与接收回调的服务实例不是同一个时,就会造成队列永远订阅不到消息的情况,那有没有全局的订阅消息的方案呢?答案是有的,这里可以借助一下Redis

实现二:

import org.springframework.context.annotation.Bean;
import org.springframework.context.annotation.Configuration;
import redis.clients.jedis.*;

import java.util.HashSet;
import java.util.Set;

@Configuration
public class JedisConfig {
    @Bean
    public JedisPoolConfig jedisPoolConfig() {
        JedisPoolConfig jedisPoolConfig = new JedisPoolConfig();
        //最大连接数,控制一个pool可分配多少个jedis实例,通过pool.getResource()来获取,-1不限制
        jedisPoolConfig.setMaxTotal(-1);
        //最大空闲连接
        jedisPoolConfig.setMaxIdle(10);
        //最小空闲连接
        jedisPoolConfig.setMinIdle(2);
        //在borrow一个jedis实例时,是否提前进行validate操作;如果为true,则得到的jedis实例均是可用的
        jedisPoolConfig.setTestOnBorrow(true);
        return jedisPoolConfig;
    }
    @Bean
    public JedisPool jedisPool(JedisPoolConfig jedisPoolConfig) {
        JedisPool jedisPool = new JedisPool(jedisPoolConfig, "127.0.0.1", 6379, 1000, null);
        return jedisPool;
    }
    /**
     * 这里为什么不把Jedis配置为一个Bean呢?
     * 这里因为将Jedis配置为Bean后,Jedis对象就是单例的,此时Jedis对象先监听队列
     * 然后再使用Jedis去发布队列消息时会报错:redis.clients.jedis.exceptions.JedisDataException: ERR only (P)SUBSCRIBE / (P)UNSUBSCRIBE / QUIT allowed in this context
     * 因此实际使用时,注入JedisPool即可
     * @param jedisPool
     * @return
     */
//    @Bean
    public Jedis jedis(JedisPool jedisPool) {
        return jedisPool.getResource();
    }

    /**
     * 需要确保你的redis服务支持集群模式,否则报错
     * @param jedisPoolConfig
     * @return
     */
//    @Bean
    public JedisCluster jedisCluster(JedisPoolConfig jedisPoolConfig) {
        Set<HostAndPort> hostAndPortSet = new HashSet<HostAndPort>();
        hostAndPortSet.add(new HostAndPort("127.0.0.1", 6379));
        JedisCluster jedisCluster = new JedisCluster(hostAndPortSet, jedisPoolConfig);
        return jedisCluster;
    }
}
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.stereotype.Component;
import redis.clients.jedis.Jedis;
import redis.clients.jedis.JedisPool;
import redis.clients.jedis.JedisPubSub;

@Component
public class RedisMessageChannel implements MessageChannel {

    /**
     * 注入JedisPool,使用时 jedisPoll.getResource()
     * 保证可以获取到不同的jedis对象
     */
    @Autowired
    private JedisPool jedisPool;

    @Override
    public void publishMessage(String channelName, String message) {
        jedisPool.getResource().publish(channelName, message);
    }

    @Override
    public String subscribeMessage(String channelName) {
        StringBuffer msgBuffer = new StringBuffer();
        Jedis jedis = jedisPool.getResource();
//        监听队列(阻塞操作)
        jedis.subscribe(new JedisPubSub() {
            Thread thread;
            @Override
            public void onMessage(String channel, String message) {
                msgBuffer.append(message);
//                取消订阅,不取消的话,会一直阻塞
                unsubscribe(channelName);
                if (thread != null) {
//                    停止线程
                    thread.interrupt();
                }
            }

            @Override
            public void onSubscribe(String channel, int subscribedChannels) {
                System.out.println("已开始监听队列");
//                由于Jedis监听没有超时时间设置,因此可以在开始监听时开启一个线程设置休眠时间,时间到了之后取消订阅
                thread = new Thread(() -> {
                    try {
                        Thread.sleep(10 * 1000);
                        if (isSubscribed()) {
                            unsubscribe(channelName);
                        }
                    } catch (InterruptedException e) {
//                        如果在超时时间之前,已经接收到了消息,就会停止线程,此处会报错,不影响
                        throw new RuntimeException(e);
                    }
                });
                thread.start();
            }
        }, channelName);
        System.out.println("阻塞结束");
        return msgBuffer.toString();
    }
}

     以上便是使用Reids来实现的动态队列,它是跨进程的,同时由于Redis的PubSub队列实现并不存储数据,因此是一个比较轻量且优雅的实现方式。

    需要注意的是,这里我使用的Redis客户端是Jedis,如果使用RedisTemplate、Redisson作为客户端则默认情况下,监听队列并不会产生阻塞效果。

代码如下:

import org.redisson.api.RTopic;
import org.redisson.api.RedissonClient;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.data.redis.connection.Message;
import org.springframework.data.redis.connection.MessageListener;
import org.springframework.data.redis.connection.RedisConnection;
import org.springframework.data.redis.connection.RedisConnectionFactory;
import org.springframework.data.redis.core.RedisTemplate;
import org.springframework.stereotype.Component;

import java.nio.charset.StandardCharsets;

@Component
public class RedisMessageChannel implements MessageChannel {

    @Autowired
    private RedisTemplate redisTemplate;

    @Autowired
    private RedissonClient redissonClient;

    @Override
    public void publishMessage(String channelName, String message) {
        redisTemplate.convertAndSend(channelName, message);
    }

    @Override
    public String subscribeMessage(String channelName) {
        StringBuffer msgBuffer = new StringBuffer();
        RedisConnectionFactory connectionFactory = redisTemplate.getConnectionFactory();
//        获取Redis连接
//        RedisClusterConnection clusterConnection = connectionFactory.getClusterConnection();
//        RedisSentinelConnection sentinelConnection = connectionFactory.getSentinelConnection();
        RedisConnection connection = connectionFactory.getConnection();

//        监听队列(使用redisTemplate默认情况下此步骤不产生阻塞效果)
        connection.subscribe(new MessageListener() {
            @Override
            public void onMessage(Message message, byte[] pattern) {
                msgBuffer.append(new String(message.getBody()));
//                取消订阅(将跳出该方法)
                connection.getSubscription().unsubscribe(channelName.getBytes(StandardCharsets.UTF_8));
            }
        }, channelName.getBytes(StandardCharsets.UTF_8));

        RTopic topic = redissonClient.getTopic(channelName);
//        监听队列(使用Redisson默认情况下此步骤不产生阻塞效果)
        topic.addListener(String.class, new org.redisson.api.listener.MessageListener<String>() {
            @Override
            public void onMessage(CharSequence channel, String msg) {
                msgBuffer.append(msg);
                topic.removeAllListeners();
            }
        });
        System.out.println("###############");
        return msgBuffer.toString();
    }
}

   最后的最后,需要注意的是,那些数据源的异步接口,回调的时间要尽可能短毕竟服务线程都在那里卡着,如果回调时间很长(虽然可以设置监听的超时时间)就会导致等待的线程过多,从而造成服务器资源耗尽。

  另外对于存在依赖关系的数据加工来说,如果数据加工需要依赖一些异步数据源,那么对于上游系统来说,最好的方式是调用本系统的异步计算接口。这种情况下,上游系统调用了本系统的异步接口,可以等待本系统的回调,而本系统调用了外部的异步数据源之后,也可以不用等待异步回调了,而是在回调中再进行处理,那么资源问题就可以得到解决了。不过这样就不符合文章的标题了。

评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值