Modifier and Type | Method and Description |
---|---|
void |
SingleServerInventoryView.registerSegmentCallback(Executor exec,
ServerView.SegmentCallback callback,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> filter)
Deprecated.
|
void |
HttpServerInventoryView.registerSegmentCallback(Executor exec,
ServerView.SegmentCallback callback,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> filter) |
void |
FilteredServerInventoryView.registerSegmentCallback(Executor exec,
ServerView.SegmentCallback callback,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> filter) |
void |
BatchServerInventoryView.registerSegmentCallback(Executor exec,
ServerView.SegmentCallback callback,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> filter)
Deprecated.
|
Constructor and Description |
---|
BatchServerInventoryView(ZkPathsConfig zkPaths,
org.apache.curator.framework.CuratorFramework curator,
com.fasterxml.jackson.databind.ObjectMapper jsonMapper,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> defaultFilter)
Deprecated.
|
HttpServerInventoryView(com.fasterxml.jackson.databind.ObjectMapper smileMapper,
HttpClient httpClient,
DruidNodeDiscoveryProvider druidNodeDiscoveryProvider,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> defaultFilter,
HttpServerInventoryViewConfig config) |
SingleServerInventoryView(ZkPathsConfig zkPaths,
org.apache.curator.framework.CuratorFramework curator,
com.fasterxml.jackson.databind.ObjectMapper jsonMapper,
com.google.common.base.Predicate<Pair<DruidServerMetadata,DataSegment>> defaultFilter)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
SerializablePair<T1,T2> |
Modifier and Type | Method and Description |
---|---|
Pair<SUBJECT,ID> |
SubjectAndIdConverter.getSubjectAndId(ByteBuffer payload) |
Pair<String,Integer> |
Avro1124SubjectAndIdConverter.getSubjectAndId(ByteBuffer payload) |
Modifier and Type | Method and Description |
---|---|
static Pair<Bucket,byte[]> |
Bucket.fromGroupKey(byte[] keyBytes) |
Modifier and Type | Method and Description |
---|---|
Pair<Integer,Integer> |
PortFinder.findTwoConsecutiveUnusedPorts() |
Pair<org.joda.time.DateTime,String> |
TaskStorage.getCreatedDateTimeAndDataSource(String taskId) |
Pair<org.joda.time.DateTime,String> |
MetadataTaskStorage.getCreatedDateTimeAndDataSource(String taskId) |
Pair<org.joda.time.DateTime,String> |
HeapMemoryTaskStorage.getCreatedDateTimeAndDataSource(String taskId) |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
static void |
TaskRunnerUtils.notifyLocationChanged(Iterable<Pair<TaskRunnerListener,Executor>> listeners,
String taskId,
TaskLocation location) |
static void |
TaskRunnerUtils.notifyStatusChanged(Iterable<Pair<TaskRunnerListener,Executor>> listeners,
String taskId,
TaskStatus status) |
Modifier and Type | Method and Description |
---|---|
static <T1,T2> Pair<T1,T2> |
Pair.of(T1 lhs,
T2 rhs) |
Modifier and Type | Method and Description |
---|---|
static <T1> Comparator<Pair<T1,?>> |
Pair.lhsComparator(Comparator<T1> comparator) |
static <T1,T2> com.google.common.base.Function<Pair<T1,T2>,T1> |
Pair.lhsFn() |
static <T1,T2> com.google.common.base.Function<Pair<T1,T2>,T2> |
Pair.rhsFn() |
Modifier and Type | Method and Description |
---|---|
Pair<org.joda.time.DateTime,String> |
MetadataStorageActionHandler.getCreatedDateAndDataSource(String entryId)
Return createdDate and dataSource for the given id
|
Pair<org.joda.time.DateTime,String> |
SQLMetadataStorageActionHandler.getCreatedDateAndDataSource(String entryId) |
Modifier and Type | Method and Description |
---|---|
List<Pair<EntryType,StatusType>> |
MetadataStorageActionHandler.getActiveEntriesWithStatus()
Return all active entries with their respective status
|
List<Pair<EntryType,StatusType>> |
SQLMetadataStorageActionHandler.getActiveEntriesWithStatus() |
Modifier and Type | Method and Description |
---|---|
static Pair<List<AggregatorFactory>,List<PostAggregator>> |
AggregatorUtil.condensedAggregators(List<AggregatorFactory> aggList,
List<PostAggregator> postAggList,
String metric) |
Modifier and Type | Method and Description |
---|---|
static <T> Pair<Queue,Accumulator<Queue,T>> |
GroupByQueryHelper.createBySegmentAccumulatorPair() |
static <T> Pair<IncrementalIndex,Accumulator<IncrementalIndex,T>> |
GroupByQueryHelper.createIndexAccumulatorPair(GroupByQuery query,
GroupByQueryConfig config,
NonBlockingPool<ByteBuffer> bufferPool,
boolean combine) |
Modifier and Type | Method and Description |
---|---|
static Pair<Grouper<io.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey>,Accumulator<AggregateResult,Row>> |
RowBasedGrouperHelper.createGrouperAccumulatorPair(GroupByQuery query,
boolean isInputRaw,
Map<String,ValueType> rawInputRowSignature,
GroupByQueryConfig config,
com.google.common.base.Supplier<ByteBuffer> bufferSupplier,
LimitedTemporaryStorage temporaryStorage,
com.fasterxml.jackson.databind.ObjectMapper spillMapper,
AggregatorFactory[] aggregatorFactories,
int mergeBufferSize)
Create a single-threaded grouper and accumulator.
|
static Pair<Grouper<io.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey>,Accumulator<AggregateResult,Row>> |
RowBasedGrouperHelper.createGrouperAccumulatorPair(GroupByQuery query,
boolean isInputRaw,
Map<String,ValueType> rawInputRowSignature,
GroupByQueryConfig config,
com.google.common.base.Supplier<ByteBuffer> bufferSupplier,
com.google.common.base.Supplier<ResourceHolder<ByteBuffer>> combineBufferSupplier,
int concurrencyHint,
LimitedTemporaryStorage temporaryStorage,
com.fasterxml.jackson.databind.ObjectMapper spillMapper,
AggregatorFactory[] aggregatorFactories,
com.google.common.util.concurrent.ListeningExecutorService grouperSorter,
int priority,
boolean hasQueryTimeout,
long queryTimeoutAt,
int mergeBufferSize)
If isInputRaw is true, transformations such as timestamp truncation and extraction functions have not
been applied to the input rows yet, for example, in a nested query, if an extraction function is being
applied in the outer query to a field of the inner query.
|
Modifier and Type | Method and Description |
---|---|
protected Pair<Integer,Integer> |
BaseTopNAlgorithm.BaseArrayProvider.computeStartEnd(int cardinality) |
Modifier and Type | Field and Description |
---|---|
protected List<Pair<ByteBuffer,Integer>> |
IndexMerger.DictionaryMergeIterator.directBufferAllocations |
protected PriorityQueue<Pair<Integer,com.google.common.collect.PeekingIterator<String>>> |
IndexMerger.DictionaryMergeIterator.pQueue |
Modifier and Type | Method and Description |
---|---|
static Pair<String,String> |
VirtualColumns.splitColumnName(String columnName)
Split a dot-style columnName into the "main" columnName and the subColumn name after the dot.
|
Modifier and Type | Method and Description |
---|---|
Pair<Segment,Closeable> |
FireHydrant.getAndIncrementSegment() |
Modifier and Type | Method and Description |
---|---|
List<InputRow> |
IrcInputRowParser.parseBatch(Pair<org.joda.time.DateTime,com.ircclouds.irc.api.domain.messages.ChannelPrivMsg> msg) |
Modifier and Type | Method and Description |
---|---|
Firehose |
IrcFirehoseFactory.connect(InputRowParser<Pair<org.joda.time.DateTime,com.ircclouds.irc.api.domain.messages.ChannelPrivMsg>> firehoseParser,
File temporaryDirectory) |
Modifier and Type | Method and Description |
---|---|
protected Pair<Double,ServerHolder> |
CostBalancerStrategy.chooseBestServer(DataSegment proposalSegment,
Iterable<ServerHolder> serverHolders,
boolean includeCurrentServer)
For assignment, we want to move to the lowest cost server that isn't already serving the segment.
|
Modifier and Type | Method and Description |
---|---|
Pair<String,Server> |
TieredBrokerHostSelector.getDefaultLookup() |
Pair<String,Server> |
TieredBrokerHostSelector.select(Query<T> query) |
Copyright © 2011–2018. All rights reserved.