Use consistent names for the task variables (change from next_update_task_handle to merge_selecting_handle) (reverted from commit 50992843c6)

This commit is contained in:
Silviu Caragea 2018-03-26 23:12:17 +03:00
parent 438121e45b
commit 0aa9b9efbe
4 changed files with 10 additions and 10 deletions

View File

@ -252,7 +252,7 @@ bool ReplicatedMergeTreeQueue::remove(zkutil::ZooKeeperPtr zookeeper, const Stri
}
bool ReplicatedMergeTreeQueue::pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper, BackgroundSchedulePool::TaskHandle merge_selecting_handle)
bool ReplicatedMergeTreeQueue::pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper, BackgroundSchedulePool::TaskHandle next_update_task_handle)
{
std::lock_guard<std::mutex> lock(pull_logs_to_queue_mutex);
@ -400,10 +400,10 @@ bool ReplicatedMergeTreeQueue::pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper, B
}
}
if (merge_selecting_handle)
if (next_update_task_handle)
{
if (zookeeper->existsWatch(zookeeper_path + "/log/log-" + padIndex(index), nullptr, merge_selecting_handle->getWatchCallback()))
merge_selecting_handle->schedule();
if (zookeeper->existsWatch(zookeeper_path + "/log/log-" + padIndex(index), nullptr, next_update_task_handle->getWatchCallback()))
next_update_task_handle->schedule();
}
return dirty_entries_loaded || !log_entries.empty();

View File

@ -161,10 +161,10 @@ public:
bool remove(zkutil::ZooKeeperPtr zookeeper, const String & part_name);
/** Copy the new entries from the shared log to the queue of this replica. Set the log_pointer to the appropriate value.
* If merge_selecting_handle != nullptr, will schedule this task when new entries appear in the log.
* If next_update_task_handle != nullptr, will schedule this task when new entries appear in the log.
* Returns true if new entries have been.
*/
bool pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper, BackgroundSchedulePool::TaskHandle merge_selecting_handle);
bool pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper, BackgroundSchedulePool::TaskHandle next_update_task_handle);
/** Remove the action from the queue with the parts covered by part_name (from ZK and from the RAM).
* And also wait for the completion of their execution, if they are now being executed.

View File

@ -953,9 +953,9 @@ void StorageReplicatedMergeTree::checkPartAndAddToZooKeeper(
}
void StorageReplicatedMergeTree::pullLogsToQueue(BackgroundSchedulePool::TaskHandle merge_selecting_handle)
void StorageReplicatedMergeTree::pullLogsToQueue(BackgroundSchedulePool::TaskHandle next_update_task_handle)
{
if (queue.pullLogsToQueue(getZooKeeper(), merge_selecting_handle))
if (queue.pullLogsToQueue(getZooKeeper(), next_update_task_handle))
{
if (queue_task_handle)
queue_task_handle->wake();

View File

@ -341,9 +341,9 @@ private:
/// Running jobs from the queue.
/** Copies the new entries from the logs of all replicas to the queue of this replica.
* If merge_selecting_handle != nullptr, schedules this task when new entries appear in the log.
* If next_update_task_handle != nullptr, schedules this task when new entries appear in the log.
*/
void pullLogsToQueue(BackgroundSchedulePool::TaskHandle merge_selecting_handle = nullptr);
void pullLogsToQueue(BackgroundSchedulePool::TaskHandle next_update_task_handle = nullptr);
/** Execute the action from the queue. Throws an exception if something is wrong.
* Returns whether or not it succeeds. If it did not work, write it to the end of the queue.