| Modifier and Type | Method and Description | 
|---|---|
TaskToolbox | 
TaskToolboxFactory.build(Task task)  | 
| 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)  | 
SegmentPublishResult | 
SegmentTransactionalInsertAction.perform(Task task,
       TaskActionToolbox toolbox)
 | 
Void | 
SegmentNukeAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
Void | 
SegmentMetadataUpdateAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
List<DataSegment> | 
SegmentListUsedAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
List<DataSegment> | 
SegmentListUnusedAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
Set<DataSegment> | 
SegmentInsertAction.perform(Task task,
       TaskActionToolbox toolbox)
Behaves similarly to
  
IndexerMetadataStorageCoordinator.announceHistoricalSegments(java.util.Set<io.druid.timeline.DataSegment>),
 with startMetadata and endMetadata both null. | 
SegmentIdentifier | 
SegmentAllocateAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
Boolean | 
ResetDataSourceMetadataAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
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 | 
CheckPointDataSourceMetadataAction.perform(Task task,
       TaskActionToolbox toolbox)  | 
| Constructor and Description | 
|---|
LocalTaskActionClient(Task task,
                     TaskStorage storage,
                     TaskActionToolbox toolbox)  | 
RemoteTaskActionClient(Task task,
                      DruidLeaderClient druidLeaderClient,
                      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  | 
CompactionTask  | 
class  | 
ConvertSegmentBackwardsCompatibleTask
Deprecated.  
 | 
static class  | 
ConvertSegmentBackwardsCompatibleTask.SubTask
Deprecated.  
 | 
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  | 
class  | 
SameIntervalMergeTask  | 
static class  | 
SameIntervalMergeTask.SubTask  | 
| Modifier and Type | Method and Description | 
|---|---|
protected Iterable<Task> | 
HadoopConverterTask.generateSubTasks(String groupId,
                Iterable<DataSegment> segments,
                IndexSpec indexSpec,
                boolean force,
                boolean validate,
                Map<String,Object> context)  | 
protected Iterable<Task> | 
ConvertSegmentTask.generateSubTasks(String groupId,
                Iterable<DataSegment> segments,
                IndexSpec indexSpec,
                boolean force,
                boolean validate,
                Map<String,Object> context)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
KafkaIndexTask  | 
| 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()  | 
Collection<Task> | 
WorkerTaskRunner.getPendingTaskPayloads()  | 
Collection<Task> | 
RemoteTaskRunner.getPendingTaskPayloads()  | 
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)  | 
List<Pair<Task,com.google.common.util.concurrent.ListenableFuture<TaskStatus>>> | 
ThreadPoolTaskRunner.restore()  | 
List<Pair<Task,com.google.common.util.concurrent.ListenableFuture<TaskStatus>>> | 
TaskRunner.restore()
Some task runners can restart previously-running tasks after being bounced. 
 | 
List<Pair<Task,com.google.common.util.concurrent.ListenableFuture<TaskStatus>>> | 
RemoteTaskRunner.restore()  | 
List<Pair<Task,com.google.common.util.concurrent.ListenableFuture<TaskStatus>>> | 
ForkingTaskRunner.restore()  | 
| 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. 
 | 
void | 
TaskLockbox.add(Task task)  | 
<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 | 
ImmutableWorkerInfo.canRunTask(Task task)  | 
<T> T | 
TaskLockbox.doInCriticalSection(Task task,
                   List<org.joda.time.Interval> intervals,
                   CriticalAction<T> action)
Perform the given action with a guarantee that the locks of the task are not revoked in the middle of action. 
 | 
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)  | 
LockResult | 
TaskLockbox.lock(TaskLockType lockType,
    Task task,
    org.joda.time.Interval interval)
Acquires a lock on behalf of a task. 
 | 
LockResult | 
TaskLockbox.lock(TaskLockType lockType,
    Task task,
    org.joda.time.Interval interval,
    long timeoutMs)
Acquires a lock on behalf of a task, waiting up to the specified wait time if necessary. 
 | 
void | 
TaskLockbox.remove(Task task)
Release all locks for a task and remove task from set of active tasks. 
 | 
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)  | 
LockResult | 
TaskLockbox.tryLock(TaskLockType lockType,
       Task task,
       org.joda.time.Interval interval)
Attempt to acquire a lock for a task, without removing it from the queue. 
 | 
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,
        javax.servlet.http.HttpServletRequest req)  | 
| Modifier and Type | Method and Description | 
|---|---|
String | 
JavaScriptWorkerSelectStrategy.SelectorFunction.apply(WorkerTaskRunnerConfig config,
     com.google.common.collect.ImmutableMap<String,ImmutableWorkerInfo> zkWorkers,
     Task task)  | 
ImmutableWorkerInfo | 
WorkerSelectStrategy.findWorkerForTask(WorkerTaskRunnerConfig config,
                 com.google.common.collect.ImmutableMap<String,ImmutableWorkerInfo> zkWorkers,
                 Task task)
Customizable logic for selecting a worker to run a task. 
 | 
ImmutableWorkerInfo | 
JavaScriptWorkerSelectStrategy.findWorkerForTask(WorkerTaskRunnerConfig config,
                 com.google.common.collect.ImmutableMap<String,ImmutableWorkerInfo> zkWorkers,
                 Task task)  | 
ImmutableWorkerInfo | 
FillCapacityWorkerSelectStrategy.findWorkerForTask(WorkerTaskRunnerConfig config,
                 com.google.common.collect.ImmutableMap<String,ImmutableWorkerInfo> zkWorkers,
                 Task task)  | 
ImmutableWorkerInfo | 
EqualDistributionWorkerSelectStrategy.findWorkerForTask(WorkerTaskRunnerConfig config,
                 com.google.common.collect.ImmutableMap<String,ImmutableWorkerInfo> zkWorkers,
                 Task task)  | 
static ImmutableWorkerInfo | 
WorkerSelectUtils.selectWorker(Task task,
            Map<String,ImmutableWorkerInfo> allWorkers,
            WorkerTaskRunnerConfig workerTaskRunnerConfig,
            AffinityConfig affinityConfig,
            Function<com.google.common.collect.ImmutableMap<String,ImmutableWorkerInfo>,ImmutableWorkerInfo> workerSelector)
Helper for  
WorkerSelectStrategy implementations. | 
| Modifier and Type | Method and Description | 
|---|---|
static TaskAnnouncement | 
TaskAnnouncement.create(Task task,
      TaskStatus status,
      TaskLocation location)  | 
Copyright © 2011–2018. All rights reserved.