基于Redis-5.0.4版本,进行基础的源码分析,主要就是分析一些平常使用过程中的内容。仅作为相关内容的学习记录,有关Redis源码学习阅读比较广泛的便是《Redis设计与实现》一书,浏览学习该书之后,觉得相关内容还是觉得抽象的高度比较高,故对照着代码再阅读学习一下。
官网上的数据结构的介绍
这基本上就是官网上介绍的八种数据结构,其中流这种数据结构是版本5开始添加进来的主要就是完善对日志流的相关操作的补充。
Redis服务端的工作模式,主要都是Reactor模式,该模式主要就是被称为文件事件处理方式,主线程通过使用IO多路复用技术来同事监听多个套接字,并根据套接字目前执行的任务来为套接字处理不同的事件处理器,当被监听的套接字准备好接受连接(accept)、读取(read)、写入(write)或者关闭(close)时都会操作相对应的文件事件,这样就达到了单线程来处理大量客户端请求的情况,Redis服务端选择了单线程的Reactor模式,即所有的业务的处理都在一个线程中来进行,单线程的响应模式也保证了Redis执行某些命令所需要的原子操作,但是Redis服务器本身中也会出现会需要一些其他线程或者进程来做的事情,但是这些都是为了支持一些服务器本身的如备份等其他功能操作。
接下来就通过Redis服务端的初始化过程简单的概述一下Redis的工作模式。
int main(int argc, char **argv) {
struct timeval tv;
int j;
#ifdef REDIS_TEST // 是否是测试
if (argc == 3 && !strcasecmp(argv[1], "test")) {
if (!strcasecmp(argv[2], "ziplist")) {
return ziplistTest(argc, argv);
} else if (!strcasecmp(argv[2], "quicklist")) {
quicklistTest(argc, argv);
} else if (!strcasecmp(argv[2], "intset")) {
return intsetTest(argc, argv);
} else if (!strcasecmp(argv[2], "zipmap")) {
return zipmapTest(argc, argv);
} else if (!strcasecmp(argv[2], "sha1test")) {
return sha1Test(argc, argv);
} else if (!strcasecmp(argv[2], "util")) {
return utilTest(argc, argv);
} else if (!strcasecmp(argv[2], "sds")) {
return sdsTest(argc, argv);
} else if (!strcasecmp(argv[2], "endianconv")) {
return endianconvTest(argc, argv);
} else if (!strcasecmp(argv[2], "crc64")) {
return crc64Test(argc, argv);
} else if (!strcasecmp(argv[2], "zmalloc")) {
return zmalloc_test(argc, argv);
}
return -1; /* test not found */
}
#endif
/* We need to initialize our libraries, and the server configuration. */
#ifdef INIT_SETPROCTITLE_REPLACEMENT
spt_init(argc, argv);
#endif
setlocale(LC_COLLATE,""); // 设置地域信息
tzset(); /* Populates 'timezone' global. */
zmalloc_set_oom_handler(redisOutOfMemoryHandler); // 设置超过内存处理函数
srand(time(NULL)^getpid()); // 随机数产生器的初始值
gettimeofday(&tv,NULL); // 获取时间
char hashseed[16];
getRandomHexChars(hashseed,sizeof(hashseed));
dictSetHashFunctionSeed((uint8_t*)hashseed); // 设置hash函数的值
server.sentinel_mode = checkForSentinelMode(argc,argv); // 检查是否启动的是哨兵模式
initServerConfig(); // 初始化服务器配置
moduleInitModulesSystem(); // 加载扩展的模块
/* Store the executable path and arguments in a safe place in order
* to be able to restart the server later. */
server.executable = getAbsolutePath(argv[0]); // 保存可执行文件
server.exec_argv = zmalloc(sizeof(char*)*(argc+1)); // 申请内存保存输入的参数
server.exec_argv[argc] = NULL;
for (j = 0; j < argc; j++) server.exec_argv[j] = zstrdup(argv[j]); // 保存输入的参数,
/* We need to init sentinel right now as parsing the configuration file
* in sentinel mode will have the effect of populating the sentinel
* data structures with master nodes to monitor. */
if (server.sentinel_mode) { // 如果是哨兵模式则初始化哨兵模式配置
initSentinelConfig();
initSentinel();
}
/* Check if we need to start in redis-check-rdb/aof mode. We just execute
* the program main. However the program is part of the Redis executable
* so that we can easily execute an RDB check on loading errors. */
if (strstr(argv[0],"redis-check-rdb") != NULL) // 检查是否包含了redis-check-rdb参数 如果有则检查rdb文件是否正确
redis_check_rdb_main(argc,argv,NULL);
else if (strstr(argv[0],"redis-check-aof") != NULL) // 检查是否包括了aof文件的检查 如果有则检查aof文件
redis_check_aof_main(argc,argv);
if (argc >= 2) { // 如果输入参数多余等于两个 则检查是否包含如下的输入参数
j = 1; /* First option to parse in argv[] */
sds options = sdsempty();
char *configfile = NULL;
/* Handle special options --help and --version */
if (strcmp(argv[1], "-v") == 0 ||
strcmp(argv[1], "--version") == 0) version();
if (strcmp(argv[1], "--help") == 0 ||
strcmp(argv[1], "-h") == 0) usage();
if (strcmp(argv[1], "--test-memory") == 0) {
if (argc == 3) {
memtest(atoi(argv[2]),50);
exit(0);
} else {
fprintf(stderr,"Please specify the amount of memory to test in megabytes.\n");
fprintf(stderr,"Example: ./redis-server --test-memory 4096\n\n");
exit(1);
}
}
/* First argument is the config file name? */
if (argv[j][0] != '-' || argv[j][1] != '-') {
configfile = argv[j];
server.configfile = getAbsolutePath(configfile);
/* Replace the config file in server.exec_argv with
* its absolute path. */
zfree(server.exec_argv[j]);
server.exec_argv[j] = zstrdup(server.configfile);
j++;
}
/* All the other options are parsed and conceptually appended to the
* configuration file. For instance --port 6380 will generate the
* string "port 6380\n" to be parsed after the actual file name
* is parsed, if any. */
while(j != argc) {
if (argv[j][0] == '-' && argv[j][1] == '-') {
/* Option name */
if (!strcmp(argv[j], "--check-rdb")) {
/* Argument has no options, need to skip for parsing. */
j++;
continue;
}
if (sdslen(options)) options = sdscat(options,"\n");
options = sdscat(options,argv[j]+2);
options = sdscat(options," ");
} else {
/* Option argument */
options = sdscatrepr(options,argv[j],strlen(argv[j]));
options = sdscat(options," ");
}
j++;
}
if (server.sentinel_mode && configfile && *configfile == '-') {
serverLog(LL_WARNING,
"Sentinel config from STDIN not allowed.");
serverLog(LL_WARNING,
"Sentinel needs config file on disk to save state. Exiting...");
exit(1);
}
resetServerSaveParams();
loadServerConfig(configfile,options);
sdsfree(options);
}
serverLog(LL_WARNING, "oO0OoO0OoO0Oo Redis is starting oO0OoO0OoO0Oo");
serverLog(LL_WARNING,
"Redis version=%s, bits=%d, commit=%s, modified=%d, pid=%d, just started",
REDIS_VERSION,
(sizeof(long) == 8) ? 64 : 32,
redisGitSHA1(),
strtol(redisGitDirty(),NULL,10) > 0,
(int)getpid()); // 输出运行的基本信息
if (argc == 1) {
serverLog(LL_WARNING, "Warning: no config file specified, using the default config. In order to specify a config file use %s /path/to/%s.conf", argv[0], server.sentinel_mode ? "sentinel" : "redis");
} else {
serverLog(LL_WARNING, "Configuration loaded"); // 检查是否输入指定的输入参数
}
server.supervised = redisIsSupervised(server.supervised_mode); // 是否是supervised模式
int background = server.daemonize && !server.supervised; // 是否是守护进程模式
if (background) daemonize(); // 如果是守护进程模式则启动守护进程模式
initServer(); // 初始化服务端
if (background || server.pidfile) createPidFile(); // 是否是后台启动 并且是否配置了Pid文件路径 如果有则创建Pid文件
redisSetProcTitle(argv[0]);
redisAsciiArt();
checkTcpBacklogSettings(); // 检查tcp相关配置
if (!server.sentinel_mode) { // 是否是哨兵模式
/* Things not needed when running in Sentinel mode. */
serverLog(LL_WARNING,"Server initialized");
#ifdef __linux__
linuxMemoryWarnings();
#endif
moduleLoadFromQueue();
loadDataFromDisk();
if (server.cluster_enabled) {
if (verifyClusterConfigWithData() == C_ERR) {
serverLog(LL_WARNING,
"You can't have keys in a DB different than DB 0 when in "
"Cluster mode. Exiting.");
exit(1);
}
}
if (server.ipfd_count > 0)
serverLog(LL_NOTICE,"Ready to accept connections");
if (server.sofd > 0)
serverLog(LL_NOTICE,"The server is now ready to accept connections at %s", server.unixsocket);
} else {
sentinelIsRunning();
}
/* Warning the user about suspicious maxmemory setting. */
if (server.maxmemory > 0 && server.maxmemory < 1024*1024) { // 检查最大内容的大小 是否打印警告信息
serverLog(LL_WARNING,"WARNING: You specified a maxmemory value that is less than 1MB (current value is %llu bytes). Are you sure this is what you really want?", server.maxmemory);
}
aeSetBeforeSleepProc(server.el,beforeSleep); // 设置beforeSleep的回调函数
aeSetAfterSleepProc(server.el,afterSleep); // 设置afterSleep的回调函数
aeMain(server.el); // 启动事件循环
aeDeleteEventLoop(server.el); // 事件循环结束删除配置文件中的事件
return 0;
}
从main函数的执行流程可知,主要就是进行了相关的输入参数的检查与服务器端的启动模式之间的检查,根据不同的输入参数启动不同的方式来工作,在整个流程中的启动流程中,比较主要的过程就是initServer的初始化流程与aeMain函数的执行过程。
void initServer(void) {
int j;
signal(SIGHUP, SIG_IGN);
signal(SIGPIPE, SIG_IGN);
setupSignalHandlers(); // 注册信号处理函数
if (server.syslog_enabled) { // 是否打开syslog
openlog(server.syslog_ident, LOG_PID | LOG_NDELAY | LOG_NOWAIT,
server.syslog_facility);
}
server.hz = server.config_hz;
server.pid = getpid(); // 获取当前运行的进程号
server.current_client = NULL; // 记录当前执行命令的客户端
server.clients = listCreate(); // 当前所有连接的客户端 通过一个列表来保存
server.clients_index = raxNew();
server.clients_to_close = listCreate(); // 获取一个需要关闭的clients列表
server.slaves = listCreate(); // 生成一个从节点的列表
server.monitors = listCreate(); // 生成一个监视器的列表
server.clients_pending_write = listCreate();
server.slaveseldb = -1; /* Force to emit the first SELECT command. */
server.unblocked_clients = listCreate(); // 生成一个不阻塞的客户端列表
server.ready_keys = listCreate();
server.clients_waiting_acks = listCreate();
server.get_ack_from_slaves = 0;
server.clients_paused = 0;
server.system_memory_size = zmalloc_get_memory_size(); // 系统的内存大小
createSharedObjects(); // 创建objects
adjustOpenFilesLimit();
server.el = aeCreateEventLoop(server.maxclients+CONFIG_FDSET_INCR); // 创建事件循环
if (server.el == NULL) {
serverLog(LL_WARNING,
"Failed creating the event loop. Error message: '%s'",
strerror(errno));
exit(1);
}
server.db = zmalloc(sizeof(redisDb)*server.dbnum); // 初始化数据库数量
/* Open the TCP listening socket for the user commands. */
if (server.port != 0 &&
listenToPort(server.port,server.ipfd,&server.ipfd_count) == C_ERR) // 监听端口
exit(1);
/* Open the listening Unix domain socket. */
if (server.unixsocket != NULL) { // 如果unix套接字配置不为空则创建原始套接字接口
unlink(server.unixsocket); /* don't care if this fails */
server.sofd = anetUnixServer(server.neterr,server.unixsocket,
server.unixsocketperm, server.tcp_backlog);
if (server.sofd == ANET_ERR) {
serverLog(LL_WARNING, "Opening Unix socket: %s", server.neterr);
exit(1);
}
anetNonBlock(NULL,server.sofd);
}
/* Abort if there are no listening sockets at all. */
if (server.ipfd_count == 0 && server.sofd < 0) {
serverLog(LL_WARNING, "Configured to not listen anywhere, exiting.");
exit(1);
}
/* Create the Redis databases, and initialize other internal state. */ // 初始化每个数据库
for (j = 0; j < server.dbnum; j++) {
server.db[j].dict = dictCreate(&dbDictType,NULL); // 数据库的字典
server.db[j].expires = dictCreate(&keyptrDictType,NULL); // 过期字典
server.db[j].blocking_keys = dictCreate(&keylistDictType,NULL); // 阻塞的key列表
server.db[j].ready_keys = dictCreate(&objectKeyPointerValueDictType,NULL);
server.db[j].watched_keys = dictCreate(&keylistDictType,NULL); // 观察的key字典
server.db[j].id = j;
server.db[j].avg_ttl = 0;
server.db[j].defrag_later = listCreate();
}
evictionPoolAlloc(); /* Initialize the LRU keys pool. */ // 注册LRU缓冲池
server.pubsub_channels = dictCreate(&keylistDictType,NULL); // 初始化发布订阅的字典
server.pubsub_patterns = listCreate(); // 发布订阅的列表
listSetFreeMethod(server.pubsub_patterns,freePubsubPattern); // 注册相关的释放与匹配函数
listSetMatchMethod(server.pubsub_patterns,listMatchPubsubPattern);
server.cronloops = 0;
server.rdb_child_pid = -1; // rdb子进程
server.aof_child_pid = -1; // aof子进程
server.rdb_child_type = RDB_CHILD_TYPE_NONE;
server.rdb_bgsave_scheduled = 0;
server.child_info_pipe[0] = -1; // 通信管道
server.child_info_pipe[1] = -1;
server.child_info_data.magic = 0;
aofRewriteBufferReset();
server.aof_buf = sdsempty(); // aof缓存
server.lastsave = time(NULL); /* At startup we consider the DB saved. */
server.lastbgsave_try = 0; /* At startup we never tried to BGSAVE. */
server.rdb_save_time_last = -1;
server.rdb_save_time_start = -1;
server.dirty = 0;
resetServerStats();
/* A few stats we don't want to reset: server startup time, and peak mem. */
server.stat_starttime = time(NULL); // 开始时间
server.stat_peak_memory = 0;
server.stat_rdb_cow_bytes = 0;
server.stat_aof_cow_bytes = 0;
server.cron_malloc_stats.zmalloc_used = 0;
server.cron_malloc_stats.process_rss = 0;
server.cron_malloc_stats.allocator_allocated = 0;
server.cron_malloc_stats.allocator_active = 0;
server.cron_malloc_stats.allocator_resident = 0;
server.lastbgsave_status = C_OK;
server.aof_last_write_status = C_OK;
server.aof_last_write_errno = 0;
server.repl_good_slaves_count = 0;
/* Create the timer callback, this is our way to process many background
* operations incrementally, like clients timeout, eviction of unaccessed
* expired keys and so forth. */
if (aeCreateTimeEvent(server.el, 1, serverCron, NULL, NULL) == AE_ERR) { // 创建事件事件
serverPanic("Can't create event loop timers.");
exit(1);
}
/* Create an event handler for accepting new connections in TCP and Unix
* domain sockets. */
for (j = 0; j < server.ipfd_count; j++) {
if (aeCreateFileEvent(server.el, server.ipfd[j], AE_READABLE,
acceptTcpHandler,NULL) == AE_ERR) // 创建事件监听的接受事件,回调函数为acceptTcpHandler
{
serverPanic(
"Unrecoverable error creating server.ipfd file event.");
}
}
if (server.sofd > 0 && aeCreateFileEvent(server.el,server.sofd,AE_READABLE, // 创建接受unix原始套接字的接受事件
acceptUnixHandler,NULL) == AE_ERR) serverPanic("Unrecoverable error creating server.sofd file event.");
/* Register a readable event for the pipe used to awake the event loop
* when a blocked client in a module needs attention. */
if (aeCreateFileEvent(server.el, server.module_blocked_pipe[0], AE_READABLE,
moduleBlockedClientPipeReadable,NULL) == AE_ERR) { // 创建模块的管道沟通的回调事件
serverPanic(
"Error registering the readable event for the module "
"blocked clients subsystem.");
}
/* Open the AOF file if needed. */
if (server.aof_state == AOF_ON) { // 是否打开aof文件
server.aof_fd = open(server.aof_filename,
O_WRONLY|O_APPEND|O_CREAT,0644);
if (server.aof_fd == -1) {
serverLog(LL_WARNING, "Can't open the append-only file: %s",
strerror(errno));
exit(1);
}
}
/* 32 bit instances are limited to 4GB of address space, so if there is
* no explicit limit in the user provided configuration we set a limit
* at 3 GB using maxmemory with 'noeviction' policy'. This avoids
* useless crashes of the Redis instance for out of memory. */
if (server.arch_bits == 32 && server.maxmemory == 0) {
serverLog(LL_WARNING,"Warning: 32 bit instance detected but no memory limit set. Setting 3 GB maxmemory limit with 'noeviction' policy now.");
server.maxmemory = 3072LL*(1024*1024); /* 3 GB */
server.maxmemory_policy = MAXMEMORY_NO_EVICTION;
}
if (server.cluster_enabled) clusterInit(); // 是否集群模式
replicationScriptCacheInit();
scriptingInit(1);
slowlogInit(); // 慢日志初始化
latencyMonitorInit(); // 监控初始化
bioInit();
server.initial_memory_usage = zmalloc_used_memory(); // 可以使用的内存大小
}
该函数主要就是根据传入的配置文件的参数,初始化数据库大小,创建时间事件,并且创建客户端连接请求的事件,接着再初始化对应的一些脚本监控等初始化函数即完成了初始化过程。
void aeMain(aeEventLoop *eventLoop) {
eventLoop->stop = 0;
while (!eventLoop->stop) {
if (eventLoop->beforesleep != NULL)
eventLoop->beforesleep(eventLoop);
aeProcessEvents(eventLoop, AE_ALL_EVENTS|AE_CALL_AFTER_SLEEP);
}
}
该函数主要就是通过一个while循环,每次都先检查一下beforesleep是否设置了回调函数,如果设置了则调用该函数执行该函数主要做了一些集群相关的操作和aof相关的检查等操作后续可以详细分析一下该函数,执行完成之后就执行aeProcessEvents。
int aeProcessEvents(aeEventLoop *eventLoop, int flags)
{
int processed = 0, numevents;
/* Nothing to do? return ASAP */
if (!(flags & AE_TIME_EVENTS) && !(flags & AE_FILE_EVENTS)) return 0; // 如果没有可以处理的事件则返回
/* Note that we want call select() even if there are no
* file events to process as long as we want to process time
* events, in order to sleep until the next time event is ready
* to fire. */
if (eventLoop->maxfd != -1 ||
((flags & AE_TIME_EVENTS) && !(flags & AE_DONT_WAIT))) {
int j;
aeTimeEvent *shortest = NULL;
struct timeval tv, *tvp;
if (flags & AE_TIME_EVENTS && !(flags & AE_DONT_WAIT))
shortest = aeSearchNearestTimer(eventLoop); // 查找最近的时间事件
if (shortest) {
long now_sec, now_ms;
aeGetTime(&now_sec, &now_ms);
tvp = &tv;
/* How many milliseconds we need to wait for the next
* time event to fire? */
long long ms =
(shortest->when_sec - now_sec)*1000 +
shortest->when_ms - now_ms; // 检查还需要多久可以执行该事件 或者时间已经到了可以执行该事件
if (ms > 0) {
tvp->tv_sec = ms/1000;
tvp->tv_usec = (ms % 1000)*1000;
} else {
tvp->tv_sec = 0;
tvp->tv_usec = 0;
}
} else {
/* If we have to check for events but need to return
* ASAP because of AE_DONT_WAIT we need to set the timeout
* to zero */
if (flags & AE_DONT_WAIT) {
tv.tv_sec = tv.tv_usec = 0;
tvp = &tv;
} else {
/* Otherwise we can block */
tvp = NULL; /* wait forever */
}
}
/* Call the multiplexing API, will return only on timeout or when
* some event fires. */
numevents = aeApiPoll(eventLoop, tvp); // 事件处理函数 即 select epoll等
/* After sleep callback. */
if (eventLoop->aftersleep != NULL && flags & AE_CALL_AFTER_SLEEP)
eventLoop->aftersleep(eventLoop); // 是否需要执行aftersleep的回调函数
for (j = 0; j < numevents; j++) { // 获取有多少个已经响应的事件
aeFileEvent *fe = &eventLoop->events[eventLoop->fired[j].fd];
int mask = eventLoop->fired[j].mask;
int fd = eventLoop->fired[j].fd;
int fired = 0; /* Number of events fired for current fd. */
/* Normally we execute the readable event first, and the writable
* event laster. This is useful as sometimes we may be able
* to serve the reply of a query immediately after processing the
* query.
*
* However if AE_BARRIER is set in the mask, our application is
* asking us to do the reverse: never fire the writable event
* after the readable. In such a case, we invert the calls.
* This is useful when, for instance, we want to do things
* in the beforeSleep() hook, like fsynching a file to disk,
* before replying to a client. */
int invert = fe->mask & AE_BARRIER;
/* Note the "fe->mask & mask & ..." code: maybe an already
* processed event removed an element that fired and we still
* didn't processed, so we check if the event is still valid.
*
* Fire the readable event if the call sequence is not
* inverted. */
if (!invert && fe->mask & mask & AE_READABLE) { // 是否是可读事件 如果是可读事件则调用该事件的回调方法并传入当前的数据
fe->rfileProc(eventLoop,fd,fe->clientData,mask);
fired++;
}
/* Fire the writable event. */
if (fe->mask & mask & AE_WRITABLE) { // 如果是科协时间 则处理可写事件的回调方法
if (!fired || fe->wfileProc != fe->rfileProc) {
fe->wfileProc(eventLoop,fd,fe->clientData,mask);
fired++;
}
}
/* If we have to invert the call, fire the readable event now
* after the writable one. */
if (invert && fe->mask & mask & AE_READABLE) {
if (!fired || fe->wfileProc != fe->rfileProc) {
fe->rfileProc(eventLoop,fd,fe->clientData,mask);
fired++;
}
}
processed++;
}
}
/* Check time events */
if (flags & AE_TIME_EVENTS)
processed += processTimeEvents(eventLoop); // 如果当前有时间事件需要执行则调用时间事件执行
return processed; /* return the number of processed file/time events */
}
主要就是分层级执行了不同的任务,首先先检查是否有时间到期的时间事件需要执行,然后再检查是否有响应的任务事件需要回调执行,如果有响应任务需要执行则先执行响应任务,然后再执行时间事件。
/* Process time events */
static int processTimeEvents(aeEventLoop *eventLoop) {
int processed = 0;
aeTimeEvent *te;
long long maxId;
time_t now = time(NULL); // 获取当前时间
/* If the system clock is moved to the future, and then set back to the
* right value, time events may be delayed in a random way. Often this
* means that scheduled operations will not be performed soon enough.
*
* Here we try to detect system clock skews, and force all the time
* events to be processed ASAP when this happens: the idea is that
* processing events earlier is less dangerous than delaying them
* indefinitely, and practice suggests it is. */
if (now < eventLoop->lastTime) { // 检查当前时间是否小于最后调用的时间
te = eventLoop->timeEventHead;
while(te) { // 一次循环将when_sec置空
te->when_sec = 0;
te = te->next;
}
}
eventLoop->lastTime = now; // 时间置为当前时间
te = eventLoop->timeEventHead; // 获取事件的头部
maxId = eventLoop->timeEventNextId-1;
while(te) {
long now_sec, now_ms;
long long id;
/* Remove events scheduled for deletion. */
if (te->id == AE_DELETED_EVENT_ID) { // 是否执行完成之后移除该任务
aeTimeEvent *next = te->next; // 移除该任务
if (te->prev)
te->prev->next = te->next;
else
eventLoop->timeEventHead = te->next;
if (te->next)
te->next->prev = te->prev;
if (te->finalizerProc)
te->finalizerProc(eventLoop, te->clientData); // 执行该任务
zfree(te);
te = next;
continue;
}
/* Make sure we don't process time events created by time events in
* this iteration. Note that this check is currently useless: we always
* add new timers on the head, however if we change the implementation
* detail, this check may be useful again: we keep it here for future
* defense. */
if (te->id > maxId) {
te = te->next;
continue;
}
aeGetTime(&now_sec, &now_ms);
if (now_sec > te->when_sec ||
(now_sec == te->when_sec && now_ms >= te->when_ms)) // 更精确的时间对比
{
int retval;
id = te->id;
retval = te->timeProc(eventLoop, id, te->clientData); // 执行任务 根据任务的执行返回来判断是否继续加入时间循环
processed++;
if (retval != AE_NOMORE) { // 继续延长该任务时间来继续执行
aeAddMillisecondsToNow(retval,&te->when_sec,&te->when_ms);
} else {
te->id = AE_DELETED_EVENT_ID; // 设置删除任务id
}
}
te = te->next; // 下一个
}
return processed;
}
处理时间事件,也分为定时执行即执行完成之后继续延长指定时间之后还会再执行,也分为执行当次任务执行就不再继续执行,时间事件主要是通过时间的比较判断来进行并进行事件的回调处理。
本文主要就是概述了Redis相关的基础的数据结构,5.0.4版本的Redis的启动流程除了增加了许多新功能外,基本的启动流程与以前整理的redis源码分析(beta版本)的启动流程基本一致,都是单线程的事件驱动模式,事件中包括了连接的文件描述符事件,也包括了时间事件的处理。后续会再深入探讨5.0.4版本的Redis的其他的功能实现。由于本人才疏学浅,如有错误请批评指正。