Modifier and Type | Method and Description |
---|---|
TaskToolbox |
TaskToolboxFactory.build(Task task) |
Constructor and Description |
---|
TaskToolbox(TaskConfig config,
Task task,
TaskActionClientFactory taskActionClientFactory,
com.metamx.emitter.service.ServiceEmitter emitter,
io.druid.segment.loading.DataSegmentPusher segmentPusher,
io.druid.segment.loading.DataSegmentKiller dataSegmentKiller,
io.druid.segment.loading.DataSegmentMover dataSegmentMover,
io.druid.segment.loading.DataSegmentArchiver dataSegmentArchiver,
DataSegmentAnnouncer segmentAnnouncer,
FilteredServerView newSegmentServerView,
QueryRunnerFactoryConglomerate queryRunnerFactoryConglomerate,
ExecutorService queryExecutorService,
com.metamx.metrics.MonitorScheduler monitorScheduler,
SegmentLoader segmentLoader,
com.fasterxml.jackson.databind.ObjectMapper objectMapper,
File taskWorkDir) |
Modifier and Type | Method and Description |
---|---|
Task |
TaskActionHolder.getTask() |
Modifier and Type | Method and Description |
---|---|
TaskActionClient |
TaskActionClientFactory.create(Task task) |
TaskActionClient |
RemoteTaskActionClientFactory.create(Task task) |
TaskActionClient |
LocalTaskActionClientFactory.create(Task task) |
RetType |
TaskAction.perform(Task task,
TaskActionToolbox toolbox) |
Void |
SegmentNukeAction.perform(Task task,
TaskActionToolbox toolbox) |
Void |
SegmentMetadataUpdateAction.perform(Task task,
TaskActionToolbox toolbox) |
List<io.druid.timeline.DataSegment> |
SegmentListUsedAction.perform(Task task,
TaskActionToolbox toolbox) |
List<io.druid.timeline.DataSegment> |
SegmentListUnusedAction.perform(Task task,
TaskActionToolbox toolbox) |
Set<io.druid.timeline.DataSegment> |
SegmentInsertAction.perform(Task task,
TaskActionToolbox toolbox) |
com.google.common.base.Optional<TaskLock> |
LockTryAcquireAction.perform(Task task,
TaskActionToolbox toolbox) |
Void |
LockReleaseAction.perform(Task task,
TaskActionToolbox toolbox) |
List<TaskLock> |
LockListAction.perform(Task task,
TaskActionToolbox toolbox) |
TaskLock |
LockAcquireAction.perform(Task task,
TaskActionToolbox toolbox) |
boolean |
TaskActionToolbox.taskLockCoversSegments(Task task,
Set<io.druid.timeline.DataSegment> segments,
boolean allowOlderVersions) |
void |
TaskActionToolbox.verifyTaskLocksAndSinglePartitionSettitude(Task task,
Set<io.druid.timeline.DataSegment> segments,
boolean allowOlderVersions) |
Constructor and Description |
---|
LocalTaskActionClient(Task task,
TaskStorage storage,
TaskActionToolbox toolbox) |
RemoteTaskActionClient(Task task,
com.metamx.http.client.HttpClient httpClient,
ServerDiscoverySelector selector,
RetryPolicyFactory retryPolicyFactory,
com.fasterxml.jackson.databind.ObjectMapper jsonMapper) |
TaskActionHolder(Task task,
TaskAction action) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractFixedIntervalTask |
class |
AbstractTask |
class |
AppendTask |
class |
ArchiveTask |
class |
ConvertSegmentTask
This task takes a segment and attempts to reindex it in the latest version with the specified indexSpec.
|
static class |
ConvertSegmentTask.SubTask |
class |
HadoopConverterTask |
static class |
HadoopConverterTask.ConverterSubTask |
class |
HadoopIndexTask |
class |
HadoopTask |
class |
IndexTask |
class |
KillTask |
class |
MergeTask |
class |
MergeTaskBase |
class |
MoveTask |
class |
NoopTask |
class |
RealtimeIndexTask |
class |
RestoreTask |
Modifier and Type | Method and Description |
---|---|
protected Iterable<Task> |
HadoopConverterTask.generateSubTasks(String groupId,
Iterable<io.druid.timeline.DataSegment> segments,
IndexSpec indexSpec,
boolean force,
boolean validate) |
protected Iterable<Task> |
ConvertSegmentTask.generateSubTasks(String groupId,
Iterable<io.druid.timeline.DataSegment> segments,
IndexSpec indexSpec,
boolean force,
boolean validate) |
Constructor and Description |
---|
RealtimeIndexTask.TaskActionSegmentPublisher(Task task,
TaskToolbox taskToolbox) |
Modifier and Type | Method and Description |
---|---|
List<Task> |
TaskStorageQueryAdapter.getActiveTasks() |
List<Task> |
TaskStorage.getActiveTasks()
Returns a list of currently running or pending tasks as stored in the storage facility.
|
List<Task> |
MetadataTaskStorage.getActiveTasks() |
List<Task> |
HeapMemoryTaskStorage.getActiveTasks() |
com.google.common.base.Optional<Task> |
TaskStorageQueryAdapter.getTask(String taskid) |
com.google.common.base.Optional<Task> |
TaskStorage.getTask(String taskid)
Returns task as stored in the storage facility.
|
com.google.common.base.Optional<Task> |
MetadataTaskStorage.getTask(String taskId) |
com.google.common.base.Optional<Task> |
HeapMemoryTaskStorage.getTask(String taskid) |
Modifier and Type | Method and Description |
---|---|
boolean |
TaskQueue.add(Task task)
Adds some work to the queue and the underlying task storage facility with a generic "running" status.
|
<T> void |
TaskStorage.addAuditLog(Task task,
TaskAction<T> taskAction)
Add an action taken by a task to the audit log.
|
<T> void |
MetadataTaskStorage.addAuditLog(Task task,
TaskAction<T> taskAction) |
<T> void |
HeapMemoryTaskStorage.addAuditLog(Task task,
TaskAction<T> taskAction) |
boolean |
ImmutableZkWorker.canRunTask(Task task) |
List<TaskLock> |
TaskLockbox.findLocksForTask(Task task)
Return the currently-active locks for some task.
|
com.google.common.base.Optional<TaskActionClient> |
TaskMaster.getTaskActionClient(Task task) |
void |
TaskStorage.insert(Task task,
TaskStatus status)
Adds a task to the storage facility with a particular status.
|
void |
MetadataTaskStorage.insert(Task task,
TaskStatus status) |
void |
HeapMemoryTaskStorage.insert(Task task,
TaskStatus status) |
TaskLock |
TaskLockbox.lock(Task task,
org.joda.time.Interval interval)
Acquires a lock on behalf of a task.
|
com.google.common.util.concurrent.ListenableFuture<TaskStatus> |
ThreadPoolTaskRunner.run(Task task) |
com.google.common.util.concurrent.ListenableFuture<TaskStatus> |
TaskRunner.run(Task task)
Run a task.
|
com.google.common.util.concurrent.ListenableFuture<TaskStatus> |
RemoteTaskRunner.run(Task task)
A task will be run only if there is no current knowledge in the RemoteTaskRunner of the task.
|
com.google.common.util.concurrent.ListenableFuture<TaskStatus> |
ForkingTaskRunner.run(Task task) |
com.google.common.base.Optional<TaskLock> |
TaskLockbox.tryLock(Task task,
org.joda.time.Interval interval)
Attempt to lock a task, without removing it from the queue.
|
void |
TaskLockbox.unlock(Task task)
Release all locks for a task.
|
void |
TaskLockbox.unlock(Task task,
org.joda.time.Interval interval)
Release lock held for a task on a particular interval.
|
Modifier and Type | Method and Description |
---|---|
javax.ws.rs.core.Response |
OverlordResource.taskPost(Task task) |
Modifier and Type | Method and Description |
---|---|
String |
JavaScriptWorkerSelectStrategy.SelectorFunction.apply(RemoteTaskRunnerConfig config,
com.google.common.collect.ImmutableMap<String,ImmutableZkWorker> zkWorkers,
Task task) |
com.google.common.base.Optional<ImmutableZkWorker> |
WorkerSelectStrategy.findWorkerForTask(RemoteTaskRunnerConfig config,
com.google.common.collect.ImmutableMap<String,ImmutableZkWorker> zkWorkers,
Task task)
Customizable logic for selecting a worker to run a task.
|
com.google.common.base.Optional<ImmutableZkWorker> |
JavaScriptWorkerSelectStrategy.findWorkerForTask(RemoteTaskRunnerConfig config,
com.google.common.collect.ImmutableMap<String,ImmutableZkWorker> zkWorkers,
Task task) |
com.google.common.base.Optional<ImmutableZkWorker> |
FillCapacityWorkerSelectStrategy.findWorkerForTask(RemoteTaskRunnerConfig config,
com.google.common.collect.ImmutableMap<String,ImmutableZkWorker> zkWorkers,
Task task) |
com.google.common.base.Optional<ImmutableZkWorker> |
FillCapacityWithAffinityWorkerSelectStrategy.findWorkerForTask(RemoteTaskRunnerConfig config,
com.google.common.collect.ImmutableMap<String,ImmutableZkWorker> zkWorkers,
Task task) |
com.google.common.base.Optional<ImmutableZkWorker> |
EqualDistributionWorkerSelectStrategy.findWorkerForTask(RemoteTaskRunnerConfig config,
com.google.common.collect.ImmutableMap<String,ImmutableZkWorker> zkWorkers,
Task task) |
Modifier and Type | Method and Description |
---|---|
static TaskAnnouncement |
TaskAnnouncement.create(Task task,
TaskStatus status) |
Modifier and Type | Method and Description |
---|---|
String |
OverlordResourceTestClient.submitTask(Task task) |
Copyright © 2011–2015. All rights reserved.