Better method name

This commit is contained in:
alesapin 2020-10-15 10:43:50 +03:00
parent 3394c22c03
commit c5419083e3
6 changed files with 9 additions and 9 deletions

View File

@ -138,7 +138,7 @@ void IBackgroundJobExecutor::finish()
}
}
void IBackgroundJobExecutor::triggerDataProcessing()
void IBackgroundJobExecutor::triggerTask()
{
std::lock_guard lock(task_mutex);
if (scheduling_task)

View File

@ -76,7 +76,7 @@ public:
const std::vector<PoolConfig> & pools_configs_);
void start();
void triggerDataProcessing();
void triggerTask();
void finish();
virtual ~IBackgroundJobExecutor();

View File

@ -28,7 +28,7 @@ void MergeTreeBlockOutputStream::write(const Block & block)
PartLog::addNewPart(storage.global_context, part, watch.elapsed());
/// Initiate async merge - it will be done if it's good time for merge and if there are space in 'background_pool'.
storage.background_executor.triggerDataProcessing();
storage.background_executor.triggerTask();
}
}

View File

@ -584,7 +584,7 @@ int32_t ReplicatedMergeTreeQueue::pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper
LOG_DEBUG(log, "Pulled {} entries to queue.", copied_entries.size());
}
storage.background_executor.triggerDataProcessing();
storage.background_executor.triggerTask();
}
return stat.version;
@ -668,7 +668,7 @@ void ReplicatedMergeTreeQueue::updateMutations(zkutil::ZooKeeperPtr zookeeper, C
}
if (some_active_mutations_were_killed)
storage.background_executor.triggerDataProcessing();
storage.background_executor.triggerTask();
if (!entries_to_load.empty())
{
@ -792,7 +792,7 @@ ReplicatedMergeTreeMutationEntryPtr ReplicatedMergeTreeQueue::removeMutation(
}
if (mutation_was_active)
storage.background_executor.triggerDataProcessing();
storage.background_executor.triggerTask();
return entry;
}

View File

@ -362,7 +362,7 @@ Int64 StorageMergeTree::startMutation(const MutationCommands & commands, String
current_mutations_by_version.emplace(version, insertion.first->second);
LOG_INFO(log, "Added mutation: {}", mutation_file_name);
background_executor.triggerDataProcessing();
background_executor.triggerTask();
return version;
}
@ -580,7 +580,7 @@ CancellationCode StorageMergeTree::killMutation(const String & mutation_id)
}
/// Maybe there is another mutation that was blocked by the killed one. Try to execute it immediately.
background_executor.triggerDataProcessing();
background_executor.triggerTask();
return CancellationCode::CancelSent;
}

View File

@ -5868,7 +5868,7 @@ bool StorageReplicatedMergeTree::waitForShrinkingQueueSize(size_t queue_size, UI
{
auto lock = queue.lockQueue();
background_executor.triggerDataProcessing();
background_executor.triggerTask();
/// This is significant, because the execution of this task could be delayed at BackgroundPool.
/// And we force it to be executed.
}