A B C D E F G H I L M N O P Q R S T Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- ACCESS_CONTROL_CLASS_CONFIG - Static variable in class org.apache.pinot.broker.broker.AccessControlFactory
- AccessControl - Interface in org.apache.pinot.broker.api
- AccessControlFactory - Class in org.apache.pinot.broker.broker
- AccessControlFactory() - Constructor for class org.apache.pinot.broker.broker.AccessControlFactory
- acquire(String) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
-
Try to acquire a quota for the given table.
- acquire(String) - Method in interface org.apache.pinot.broker.queryquota.QueryQuotaManager
-
Try to acquire a quota for the given table.
- AdaptiveServerSelector - Interface in org.apache.pinot.broker.routing.adaptiveserverselector
-
The
AdaptiveServerSelector
intelligently selects the best available server for a segment during query processing. - AdaptiveServerSelectorFactory - Class in org.apache.pinot.broker.routing.adaptiveserverselector
-
The
AdaptiveServerSelectorFactory
determines the adaptive server selection strategy to use. - addExternalViewChangeHandler(ClusterChangeHandler) - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
-
Adds an external view change handler to handle Helix external view change callbacks.
- addIdealStateChangeHandler(ClusterChangeHandler) - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
-
Adds an ideal state change handler to handle Helix ideal state change callbacks.
- addInstanceConfigChangeHandler(ClusterChangeHandler) - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
-
Adds an instance config change handler to handle Helix instance config change callbacks.
- addLiveInstanceChangeHandler(ClusterChangeHandler) - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
-
Adds a live instance change handler to handle Helix live instance change callbacks.
- AllowAllAccessControlFactory - Class in org.apache.pinot.broker.broker
- AllowAllAccessControlFactory() - Constructor for class org.apache.pinot.broker.broker.AllowAllAccessControlFactory
- augmentStatistics(RequestContext, BrokerResponse) - Static method in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- AuthenticationFilter - Class in org.apache.pinot.broker.broker
-
A container filter class responsible for automatic authentication of REST endpoints.
- AuthenticationFilter() - Constructor for class org.apache.pinot.broker.broker.AuthenticationFilter
- authorize(RequesterIdentity) - Method in interface org.apache.pinot.broker.api.AccessControl
-
First-step access control when processing broker requests.
- authorize(RequesterIdentity, Set<String>) - Method in interface org.apache.pinot.broker.api.AccessControl
-
Verify access control on pinot tables.
- authorize(RequesterIdentity, BrokerRequest) - Method in interface org.apache.pinot.broker.api.AccessControl
-
Verify access control on parsed broker request.
B
- BalancedInstanceSelector - Class in org.apache.pinot.broker.routing.instanceselector
-
Instance selector to balance the number of segments served by each selected server instance.
- BalancedInstanceSelector(String, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, AdaptiveServerSelector, Clock, boolean) - Constructor for class org.apache.pinot.broker.routing.instanceselector.BalancedInstanceSelector
- BaseBrokerRequestHandler - Class in org.apache.pinot.broker.requesthandler
- BaseBrokerRequestHandler(PinotConfiguration, String, BrokerRoutingManager, AccessControlFactory, QueryQuotaManager, TableCache) - Constructor for class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- BaseBrokerStarter - Class in org.apache.pinot.broker.broker.helix
-
Base class for broker startable implementations
- BaseBrokerStarter() - Constructor for class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- BaseExponentialBackoffRetryFailureDetector - Class in org.apache.pinot.broker.failuredetector
-
The
BaseExponentialBackoffRetryFailureDetector
is a base failure detector implementation that retries the unhealthy servers with exponential increasing delays. - BaseExponentialBackoffRetryFailureDetector() - Constructor for class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- BaseExponentialBackoffRetryFailureDetector.RetryInfo - Class in org.apache.pinot.broker.failuredetector
-
Encapsulates the retry related information.
- BaseSingleStageBrokerRequestHandler - Class in org.apache.pinot.broker.requesthandler
- BaseSingleStageBrokerRequestHandler(PinotConfiguration, String, BrokerRoutingManager, AccessControlFactory, QueryQuotaManager, TableCache) - Constructor for class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- BaseSingleStageBrokerRequestHandler.ServerStats - Class in org.apache.pinot.broker.requesthandler
-
Helper class to pass the per server statistics.
- BasicAuthAccessControlFactory - Class in org.apache.pinot.broker.broker
-
Basic Authentication based on http headers.
- BasicAuthAccessControlFactory() - Constructor for class org.apache.pinot.broker.broker.BasicAuthAccessControlFactory
- BROKER_INSTANCE_ID - Static variable in class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- BrokerAdminApiApplication - Class in org.apache.pinot.broker.broker
- BrokerAdminApiApplication(BrokerRoutingManager, BrokerRequestHandler, BrokerMetrics, PinotConfiguration, SqlQueryExecutor, ServerRoutingStatsManager, AccessControlFactory, HelixManager) - Constructor for class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- BrokerCommonExceptionMapper - Class in org.apache.pinot.broker.api.resources
- BrokerCommonExceptionMapper() - Constructor for class org.apache.pinot.broker.api.resources.BrokerCommonExceptionMapper
- BrokerManagedAsyncExecutorProvider - Class in org.apache.pinot.broker.broker
-
BrokerManagedAsyncExecutorProvider provides a bounded thread pool.
- BrokerManagedAsyncExecutorProvider(int, int, int, BrokerMetrics) - Constructor for class org.apache.pinot.broker.broker.BrokerManagedAsyncExecutorProvider
- BrokerRequestHandler - Interface in org.apache.pinot.broker.requesthandler
- BrokerRequestHandlerDelegate - Class in org.apache.pinot.broker.requesthandler
-
BrokerRequestHandlerDelegate
delegates the inbound broker request to one of the enabledBrokerRequestHandler
based on the requested handle type. - BrokerRequestHandlerDelegate(BaseSingleStageBrokerRequestHandler, MultiStageBrokerRequestHandler) - Constructor for class org.apache.pinot.broker.requesthandler.BrokerRequestHandlerDelegate
- BrokerRequestIdGenerator - Class in org.apache.pinot.broker.requesthandler
-
An ID generator to produce a global unique identifier for each query, used in v1/v2 engine for tracking and inter-stage communication(v2 only).
- BrokerRequestIdGenerator(String) - Constructor for class org.apache.pinot.broker.requesthandler.BrokerRequestIdGenerator
- BrokerResourceOnlineOfflineStateModel() - Constructor for class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel
- BrokerResourceOnlineOfflineStateModelFactory - Class in org.apache.pinot.broker.broker.helix
-
Broker Resource layer state model to take over how to operate on: Adding an external view to routing table.
- BrokerResourceOnlineOfflineStateModelFactory(ZkHelixPropertyStore<ZNRecord>, HelixDataAccessor, BrokerRoutingManager, HelixExternalViewBasedQueryQuotaManager) - Constructor for class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory
- BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel - Class in org.apache.pinot.broker.broker.helix
- BrokerRoutingManager - Class in org.apache.pinot.broker.routing
-
The
RoutingManager
manages the routing of all tables hosted by the broker instance. - BrokerRoutingManager(BrokerMetrics, ServerRoutingStatsManager, PinotConfiguration) - Constructor for class org.apache.pinot.broker.routing.BrokerRoutingManager
- BrokerUserDefinedMessageHandlerFactory - Class in org.apache.pinot.broker.broker.helix
-
Broker message handler factory for Helix user-define messages.
- BrokerUserDefinedMessageHandlerFactory(BrokerRoutingManager, HelixExternalViewBasedQueryQuotaManager) - Constructor for class org.apache.pinot.broker.broker.helix.BrokerUserDefinedMessageHandlerFactory
- buildRouting(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Builds/rebuilds the routing for the given table.
- buildRouting(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerRouting
C
- cancelQuery(long, int, boolean) - Method in class org.apache.pinot.broker.api.resources.PinotClientRequest
- cancelQuery(long, int, Executor, HttpClientConnectionManager, Map<String, Integer>) - Method in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- cancelQuery(long, int, Executor, HttpClientConnectionManager, Map<String, Integer>) - Method in interface org.apache.pinot.broker.requesthandler.BrokerRequestHandler
-
Cancel a query as identified by the queryId.
- cancelQuery(long, int, Executor, HttpClientConnectionManager, Map<String, Integer>) - Method in class org.apache.pinot.broker.requesthandler.BrokerRequestHandlerDelegate
- cancelQuery(long, int, Executor, HttpClientConnectionManager, Map<String, Integer>) - Method in class org.apache.pinot.broker.requesthandler.MultiStageBrokerRequestHandler
- cleanUpRateLimiterMap() - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- ClusterChangeHandler - Interface in org.apache.pinot.broker.broker.helix
-
Handles cluster changes such as external view changes, instance config changes, live instance changes etc.
- ClusterChangeMediator - Class in org.apache.pinot.broker.broker.helix
-
The
ClusterChangeMediator
handles the changes from Helix cluster. - ClusterChangeMediator(Map<HelixConstants.ChangeType, List<ClusterChangeHandler>>, BrokerMetrics) - Constructor for class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
- compareTo(Delayed) - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector.RetryInfo
- compareTo(Interval) - Method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- ConnectionFailureDetector - Class in org.apache.pinot.broker.failuredetector
-
The
ConnectionFailureDetector
marks failed server (connection failure) from query response as unhealthy, and retries the unhealthy servers with exponential increasing delays. - ConnectionFailureDetector() - Constructor for class org.apache.pinot.broker.failuredetector.ConnectionFailureDetector
- create() - Method in class org.apache.pinot.broker.broker.AccessControlFactory
- create() - Method in class org.apache.pinot.broker.broker.AllowAllAccessControlFactory
- create() - Method in class org.apache.pinot.broker.broker.BasicAuthAccessControlFactory
- create() - Method in class org.apache.pinot.broker.broker.ZkBasicAuthAccessControlFactory
- createBrokerAdminApp() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- createHandler(Message, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.BrokerUserDefinedMessageHandlerFactory
- createNewStateModel(String, String) - Method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory
D
- DefaultSegmentSelector - Class in org.apache.pinot.broker.routing.segmentselector
- DefaultSegmentSelector() - Constructor for class org.apache.pinot.broker.routing.segmentselector.DefaultSegmentSelector
- downloadLogFile(String) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerLogger
- dropTableQueryQuota(String) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
-
Drop table query quota.
E
- EmptySegmentPruner - Class in org.apache.pinot.broker.routing.segmentpruner
-
The
EmptySegmentPruner
prunes segments if they have 0 total docs. - EmptySegmentPruner(TableConfig) - Constructor for class org.apache.pinot.broker.routing.segmentpruner.EmptySegmentPruner
- equals(Object) - Method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- excludeServerFromRouting(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Excludes a server from the routing.
- extractPartitionInfo(String, String, String, ZNRecord) - Static method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionUtils
-
Returns the partition info for a given segment with single partition column.
- extractPartitionInfoMap(String, Set<String>, String, ZNRecord) - Static method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionUtils
-
Returns a map from partition column name to partition info for a given segment with multiple partition columns.
F
- FailureDetector - Interface in org.apache.pinot.broker.failuredetector
-
The
FailureDetector
detects unhealthy servers based on the query responses. - FailureDetector.Listener - Interface in org.apache.pinot.broker.failuredetector
-
Listener for the failure detector.
- FailureDetectorFactory - Class in org.apache.pinot.broker.failuredetector
- fetchAllServerRankingsWithScores() - Method in interface org.apache.pinot.broker.routing.adaptiveserverselector.AdaptiveServerSelector
-
Returns the ranking of servers ordered from best to worst along with the absolute scores based on which the servers are ranked.
- fetchAllServerRankingsWithScores() - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.HybridSelector
- fetchAllServerRankingsWithScores() - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.LatencySelector
- fetchAllServerRankingsWithScores() - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.NumInFlightReqSelector
- fetchServerRankingsWithScores(List<String>) - Method in interface org.apache.pinot.broker.routing.adaptiveserverselector.AdaptiveServerSelector
-
Same as above but fetches ranking only for the list of serverCandidates provided in the parameter.
- fetchServerRankingsWithScores(List<String>) - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.HybridSelector
- fetchServerRankingsWithScores(List<String>) - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.LatencySelector
- fetchServerRankingsWithScores(List<String>) - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.NumInFlightReqSelector
- filter(ContainerRequestContext) - Method in class org.apache.pinot.broker.broker.AuthenticationFilter
- fromRequest(Request) - Static method in class org.apache.pinot.broker.api.HttpRequesterIdentity
G
- get() - Method in class org.apache.pinot.broker.requesthandler.BrokerRequestIdGenerator
- getAccessControlFactory() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getAdaptiveServerSelector(ServerRoutingStatsManager, PinotConfiguration) - Static method in class org.apache.pinot.broker.routing.adaptiveserverselector.AdaptiveServerSelectorFactory
- getAppConfigs() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerAppConfigs
- getBrokerHealth() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerHealthCheck
- getBrokerMetrics() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getBrokerRequestHandler() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getCandidates() - Method in class org.apache.pinot.broker.routing.instanceselector.NewSegmentState
- getCandidates(String) - Method in class org.apache.pinot.broker.routing.instanceselector.SegmentStates
- getClientIp() - Method in class org.apache.pinot.broker.api.HttpRequesterIdentity
-
If reverse proxy is used X-Forwarded-For will be populated If X-Forwarded-For is not present, check if x-real-ip is present Since X-Forwarded-For can contain comma separated list of values, we convert it to ";" delimiter to avoid downstream parsing errors for other fields where "," is being used
- getClientIp() - Method in class org.apache.pinot.broker.api.RequesterIdentity
- getConfig() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getCorePoolSize() - Method in class org.apache.pinot.broker.broker.BrokerManagedAsyncExecutorProvider
- getCreationTimeMs() - Method in class org.apache.pinot.broker.routing.instanceselector.NewSegmentState
- getDefault() - Static method in class org.apache.pinot.broker.broker.helix.HelixBrokerStarter
- getDefaultTimeRangeMs() - Method in class org.apache.pinot.broker.queryquota.MaxHitRateTracker
- getDelay(TimeUnit) - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector.RetryInfo
- getEnabledServerInstanceMap() - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
- getEndpointUrl() - Method in class org.apache.pinot.broker.api.HttpRequesterIdentity
- getFailureDetector(PinotConfiguration, BrokerMetrics) - Static method in class org.apache.pinot.broker.failuredetector.FailureDetectorFactory
- getHitCount() - Method in class org.apache.pinot.broker.queryquota.HitCounter
-
Get the total hit count within a time range.
- getHttpHeaders() - Method in class org.apache.pinot.broker.api.HttpRequesterIdentity
- getHttpServer() - Method in class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- getInstance() - Method in class org.apache.pinot.broker.routing.instanceselector.SegmentInstanceCandidate
- getInstanceId() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getInstancePartitions() - Method in class org.apache.pinot.broker.routing.instanceselector.MultiStageReplicaGroupSelector
- getInstanceSelector(TableConfig, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, AdaptiveServerSelector, Clock, PinotConfiguration) - Static method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelectorFactory
- getInstanceSelector(TableConfig, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, AdaptiveServerSelector, PinotConfiguration) - Static method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelectorFactory
- getInstanceSelector(TableConfig, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, PinotConfiguration) - Static method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelectorFactory
- getInstanceTags() - Method in class org.apache.pinot.broker.api.resources.InstanceResource
- getIntersection(Interval, Interval) - Static method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- getListeners() - Method in class org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetcher
- getLocalLogFiles() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerLogger
- getLogger(String) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerLogger
- getLoggers() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerLogger
- getLogRateLimit() - Method in class org.apache.pinot.broker.querylog.QueryLogger
- getMaxCountPerBucket() - Method in class org.apache.pinot.broker.queryquota.MaxHitRateTracker
-
Get the maximum count among the buckets
- getMaximumPoolSize() - Method in class org.apache.pinot.broker.broker.BrokerManagedAsyncExecutorProvider
- getMaxQpsTracker() - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- getMaxQueryLengthToLog() - Method in class org.apache.pinot.broker.querylog.QueryLogger
- getMessageType() - Method in class org.apache.pinot.broker.broker.helix.BrokerUserDefinedMessageHandlerFactory
- getMetricsRegistry() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getNumOnlineBrokers() - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- getNumPrunedSegments() - Method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelector.SelectionResult
-
Returns the number of segments pruned by the broker
- getOptionalSegmentToInstanceMap() - Method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelector.SelectionResult
-
Returns the map from optional segment to selected server instance hosting the optional segment.
- getOverallRate() - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- getPartitionColumn() - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionInfo
- getPartitionColumns() - Method in class org.apache.pinot.broker.routing.segmentpruner.MultiPartitionColumnsSegmentPruner
- getPartitionFunction() - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionInfo
- getPartitions() - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionInfo
- getPort() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getQpsTracker() - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- getQueryTimeoutMs(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Returns the table-level query timeout in milliseconds for the given table, or
null
if the timeout is not configured in the table config. - getRateLimiter() - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- getRateLimiterForTable(String) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- getRateLimiterMapSize() - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- getRejectedExecutionHandler() - Method in class org.apache.pinot.broker.broker.BrokerManagedAsyncExecutorProvider
- getRoutingManager() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getRoutingTable(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerDebug
- getRoutingTable(BrokerRequest, long) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Returns the routing table (a map from server instance to list of segments hosted by the server, and a list of unavailable segments) based on the broker request, or
null
if the routing does not exist. - getRoutingTableForQuery(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerDebug
- getRoutingTableForQueryWithOptionalSegments(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerDebug
- getRoutingTableWithOptionalSegments(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerDebug
- getRunningQueries() - Method in class org.apache.pinot.broker.api.resources.PinotClientRequest
- getRunningQueries() - Method in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- getRunningQueries() - Method in interface org.apache.pinot.broker.requesthandler.BrokerRequestHandler
- getRunningQueries() - Method in class org.apache.pinot.broker.requesthandler.BrokerRequestHandlerDelegate
- getRunningQueries() - Method in class org.apache.pinot.broker.requesthandler.MultiStageBrokerRequestHandler
- getSegmentPreSelector(TableConfig, ZkHelixPropertyStore<ZNRecord>) - Static method in class org.apache.pinot.broker.routing.segmentpreselector.SegmentPreSelectorFactory
- getSegmentPruners(TableConfig, ZkHelixPropertyStore<ZNRecord>) - Static method in class org.apache.pinot.broker.routing.segmentpruner.SegmentPrunerFactory
- getSegmentSelector(TableConfig) - Static method in class org.apache.pinot.broker.routing.segmentselector.SegmentSelectorFactory
- getSegmentToInstanceMap() - Method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelector.SelectionResult
-
Returns the map from segment to selected server instance hosting the segment.
- getServerRoutingStats() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerDebug
-
API to get a snapshot of ServerRoutingStatsEntry for all the servers.
- getServerStats() - Method in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler.ServerStats
- getServiceRole() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getServingInstances() - Method in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
-
Returns the enabled server instances currently serving the table.
- getServingInstances() - Method in class org.apache.pinot.broker.routing.instanceselector.SegmentStates
- getServingInstances(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
- getSpectatorHelixManager() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- getStartTime() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerHealthCheck
- getStateModelDef() - Static method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory
- getTableConfigStatVersion() - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- getTablePartitionInfo() - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionMetadataManager
- getTablePartitionInfo(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
- getTimeBoundary(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerDebug
- getTimeBoundaryInfo() - Method in class org.apache.pinot.broker.routing.timeboundary.TimeBoundaryManager
- getTimeBoundaryInfo(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Returns the time boundary info for the given offline table, or
null
if the routing or time boundary does not exist. - getUnavailableSegments() - Method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelector.SelectionResult
-
Returns the unavailable segments (no enabled instance or all enabled instances are in ERROR state).
- getUnavailableSegments() - Method in class org.apache.pinot.broker.routing.instanceselector.SegmentStates
- getUnhealthyServers() - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- getUnhealthyServers() - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Returns all the unhealthy servers.
- getUnhealthyServers() - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- getUnion(Interval, Interval) - Static method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- getUptime() - Method in class org.apache.pinot.broker.api.resources.PinotBrokerHealthCheck
- getWorkQueue() - Method in class org.apache.pinot.broker.broker.BrokerManagedAsyncExecutorProvider
- GrpcBrokerRequestHandler - Class in org.apache.pinot.broker.requesthandler
-
The
GrpcBrokerRequestHandler
class communicates query request via GRPC. - GrpcBrokerRequestHandler(PinotConfiguration, String, BrokerRoutingManager, AccessControlFactory, QueryQuotaManager, TableCache) - Constructor for class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler
- GrpcBrokerRequestHandler.PinotStreamingQueryClient - Class in org.apache.pinot.broker.requesthandler
H
- handleRequest(long, String, SqlNodeAndOptions, JsonNode, RequesterIdentity, RequestContext, HttpHeaders, AccessControl) - Method in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- handleRequest(long, String, SqlNodeAndOptions, JsonNode, RequesterIdentity, RequestContext, HttpHeaders, AccessControl) - Method in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- handleRequest(long, String, SqlNodeAndOptions, JsonNode, RequesterIdentity, RequestContext, HttpHeaders, AccessControl) - Method in class org.apache.pinot.broker.requesthandler.MultiStageBrokerRequestHandler
- handleRequest(JsonNode, SqlNodeAndOptions, RequesterIdentity, RequestContext, HttpHeaders) - Method in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- handleRequest(JsonNode, SqlNodeAndOptions, RequesterIdentity, RequestContext, HttpHeaders) - Method in interface org.apache.pinot.broker.requesthandler.BrokerRequestHandler
- handleRequest(JsonNode, SqlNodeAndOptions, RequesterIdentity, RequestContext, HttpHeaders) - Method in class org.apache.pinot.broker.requesthandler.BrokerRequestHandlerDelegate
- handleRequest(String) - Method in interface org.apache.pinot.broker.requesthandler.BrokerRequestHandler
- hasAccess(RequesterIdentity) - Method in interface org.apache.pinot.broker.api.AccessControl
-
Deprecated.
- hasAccess(RequesterIdentity, Set<String>) - Method in interface org.apache.pinot.broker.api.AccessControl
-
Deprecated.
- hasAccess(RequesterIdentity, BrokerRequest) - Method in interface org.apache.pinot.broker.api.AccessControl
-
Deprecated.
- hashCode() - Method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- HelixBrokerStarter - Class in org.apache.pinot.broker.broker.helix
-
Startable implementation for Pinot broker.
- HelixBrokerStarter() - Constructor for class org.apache.pinot.broker.broker.helix.HelixBrokerStarter
- HelixBrokerStarter(PinotConfiguration) - Constructor for class org.apache.pinot.broker.broker.helix.HelixBrokerStarter
-
Deprecated.
- HelixBrokerStarter(PinotConfiguration, String, String) - Constructor for class org.apache.pinot.broker.broker.helix.HelixBrokerStarter
-
Deprecated.
- HelixBrokerStarter(PinotConfiguration, String, String, String) - Constructor for class org.apache.pinot.broker.broker.helix.HelixBrokerStarter
-
Deprecated.
- HelixExternalViewBasedQueryQuotaManager - Class in org.apache.pinot.broker.queryquota
-
This class is to support the qps quota feature.
- HelixExternalViewBasedQueryQuotaManager(BrokerMetrics, String) - Constructor for class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- hit() - Method in class org.apache.pinot.broker.queryquota.HitCounter
-
Increase the hit count in the current bucket.
- HitCounter - Class in org.apache.pinot.broker.queryquota
-
This hit counter is for counting the number of hits within a range of time.
- HitCounter(int) - Constructor for class org.apache.pinot.broker.queryquota.HitCounter
- HitCounter(int, int) - Constructor for class org.apache.pinot.broker.queryquota.HitCounter
- HttpRequesterIdentity - Class in org.apache.pinot.broker.api
-
Identity container for HTTP requests with (optional) authorization headers
- HttpRequesterIdentity() - Constructor for class org.apache.pinot.broker.api.HttpRequesterIdentity
- HybridSelector - Class in org.apache.pinot.broker.routing.adaptiveserverselector
-
The
HybridSelector
is an AdaptiveServerSelector implementation that picks the best server based on the following parameters: 1. - HybridSelector(ServerRoutingStatsManager) - Constructor for class org.apache.pinot.broker.routing.adaptiveserverselector.HybridSelector
I
- includeServerToRouting(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Includes a previous excluded server to the routing.
- init(Set<String>, IdealState, ExternalView, Set<String>) - Method in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
-
Initializes the instance selector with the enabled instances, ideal state, external view and online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - init(Set<String>, IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.instanceselector.MultiStageReplicaGroupSelector
- init(HelixManager) - Method in interface org.apache.pinot.broker.broker.helix.ClusterChangeHandler
-
Initializes the cluster change handler with the given connected Helix manager.
- init(HelixManager) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- init(HelixManager) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
- init(IdealState, ExternalView, List<String>, List<ZNRecord>) - Method in interface org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetchListener
-
Initializes the segment pruner with the ideal state, external view and online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - init(IdealState, ExternalView, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionMetadataManager
- init(IdealState, ExternalView, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.EmptySegmentPruner
- init(IdealState, ExternalView, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.MultiPartitionColumnsSegmentPruner
- init(IdealState, ExternalView, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.SinglePartitionColumnSegmentPruner
- init(IdealState, ExternalView, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.TimeSegmentPruner
- init(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetcher
- init(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentselector.DefaultSegmentSelector
- init(IdealState, ExternalView, Set<String>) - Method in interface org.apache.pinot.broker.routing.segmentselector.SegmentSelector
-
Initializes the segment selector with the ideal state, external view and online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - init(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.timeboundary.TimeBoundaryManager
-
Initializes the time boundary manager with the ideal state, external view and online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - init(PinotConfiguration) - Method in class org.apache.pinot.broker.broker.AccessControlFactory
- init(PinotConfiguration) - Method in class org.apache.pinot.broker.broker.AllowAllAccessControlFactory
- init(PinotConfiguration) - Method in class org.apache.pinot.broker.broker.BasicAuthAccessControlFactory
- init(PinotConfiguration) - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- init(PinotConfiguration, ZkHelixPropertyStore<ZNRecord>) - Method in class org.apache.pinot.broker.broker.AccessControlFactory
-
Extend original init method inorder to support Zookeeper BasicAuthAccessControlFactory Because ZKBasicAuthAccessControlFactory need to acquire users info from HelixPropertyStore
- init(PinotConfiguration, ZkHelixPropertyStore<ZNRecord>) - Method in class org.apache.pinot.broker.broker.ZkBasicAuthAccessControlFactory
- init(PinotConfiguration, BrokerMetrics) - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- init(PinotConfiguration, BrokerMetrics) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Initializes the failure detector.
- init(PinotConfiguration, BrokerMetrics) - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- initOrUpdateTableQueryQuota(String) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- initOrUpdateTableQueryQuota(TableConfig, ExternalView) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
-
Initialize or update dynamic rate limiter with table query quota.
- InstanceResource - Class in org.apache.pinot.broker.api.resources
-
This resource API can be used to retrieve instance level information like instance tags.
- InstanceResource() - Constructor for class org.apache.pinot.broker.api.resources.InstanceResource
- InstanceSelector - Interface in org.apache.pinot.broker.routing.instanceselector
-
The instance selector selects server instances to serve the query based on the selected segments.
- InstanceSelector.SelectionResult - Class in org.apache.pinot.broker.routing.instanceselector
- InstanceSelectorFactory - Class in org.apache.pinot.broker.routing.instanceselector
- intersects(Interval) - Method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- Interval - Class in org.apache.pinot.broker.routing.segmentpruner.interval
-
The
Interval
class represents an one-dimensional closed interval which contains both ends. - Interval(long, long) - Constructor for class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- IntervalTree<VALUE> - Class in org.apache.pinot.broker.routing.segmentpruner.interval
-
The
IntervalTree
class represents read-only balanced binary interval tree map (from intervals to values) - IntervalTree(Map<VALUE, Interval>) - Constructor for class org.apache.pinot.broker.routing.segmentpruner.interval.IntervalTree
- INVALID_COLUMN_PARTITION_INFO_MAP - Static variable in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionUtils
- INVALID_PARTITION_INFO - Static variable in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionUtils
- isNewSegment(long, long) - Static method in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
- isOnline() - Method in class org.apache.pinot.broker.routing.instanceselector.SegmentInstanceCandidate
- isQueryRateLimitDisabled() - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- isShuttingDown() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- isStarting() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
L
- LatencySelector - Class in org.apache.pinot.broker.routing.adaptiveserverselector
-
The
LatencySelector
is an AdaptiveServerSelector implementation that picks the best server based on the exponential weighted moving average (EMA) of query latencies seen by the server. - LatencySelector(ServerRoutingStatsManager) - Constructor for class org.apache.pinot.broker.routing.adaptiveserverselector.LatencySelector
- LEGACY_PARTITION_AWARE_OFFLINE_ROUTING - Static variable in class org.apache.pinot.broker.routing.segmentpruner.SegmentPrunerFactory
- LEGACY_PARTITION_AWARE_REALTIME_ROUTING - Static variable in class org.apache.pinot.broker.routing.segmentpruner.SegmentPrunerFactory
- LEGACY_REPLICA_GROUP_OFFLINE_ROUTING - Static variable in class org.apache.pinot.broker.routing.instanceselector.InstanceSelectorFactory
- LEGACY_REPLICA_GROUP_REALTIME_ROUTING - Static variable in class org.apache.pinot.broker.routing.instanceselector.InstanceSelectorFactory
- loadFactory(PinotConfiguration, ZkHelixPropertyStore<ZNRecord>) - Static method in class org.apache.pinot.broker.broker.AccessControlFactory
- log(QueryLogger.QueryLogParams) - Method in class org.apache.pinot.broker.querylog.QueryLogger
- LOGGER - Static variable in class org.apache.pinot.broker.broker.AccessControlFactory
M
- main(String[]) - Static method in class org.apache.pinot.broker.broker.helix.HelixBrokerStarter
- markServerHealthy(String) - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- markServerHealthy(String) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Marks a server as healthy.
- markServerHealthy(String) - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- markServerUnhealthy(String) - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- markServerUnhealthy(String) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Marks a server as unhealthy.
- markServerUnhealthy(String) - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- MaxHitRateTracker - Class in org.apache.pinot.broker.queryquota
-
A stateful version of hit counter.
- MaxHitRateTracker(int) - Constructor for class org.apache.pinot.broker.queryquota.MaxHitRateTracker
- MultiPartitionColumnsSegmentPruner - Class in org.apache.pinot.broker.routing.segmentpruner
-
The
MultiPartitionColumnsSegmentPruner
prunes segments based on their partition metadata stored in ZK. - MultiPartitionColumnsSegmentPruner(String, Set<String>) - Constructor for class org.apache.pinot.broker.routing.segmentpruner.MultiPartitionColumnsSegmentPruner
- MultiStageBrokerRequestHandler - Class in org.apache.pinot.broker.requesthandler
- MultiStageBrokerRequestHandler(PinotConfiguration, String, BrokerRoutingManager, AccessControlFactory, QueryQuotaManager, TableCache) - Constructor for class org.apache.pinot.broker.requesthandler.MultiStageBrokerRequestHandler
- MultiStageReplicaGroupSelector - Class in org.apache.pinot.broker.routing.instanceselector
-
Instance selector for multi-stage queries which can ensure that Colocated Tables always leverage Colocated Join whenever possible.
- MultiStageReplicaGroupSelector(String, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, AdaptiveServerSelector, Clock, boolean) - Constructor for class org.apache.pinot.broker.routing.instanceselector.MultiStageReplicaGroupSelector
N
- NEW_SEGMENT_EXPIRATION_MILLIS - Static variable in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
- NewSegmentState - Class in org.apache.pinot.broker.routing.instanceselector
-
Contains the push time and candidate instances for a new segment.
- NewSegmentState(long, List<SegmentInstanceCandidate>) - Constructor for class org.apache.pinot.broker.routing.instanceselector.NewSegmentState
- NoOpFailureDetector - Class in org.apache.pinot.broker.failuredetector
- NoOpFailureDetector() - Constructor for class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- notifyHealthyServer(String, FailureDetector) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector.Listener
-
Notifies the listener of a previous unhealthy server turning healthy.
- notifyHealthyServer(String, FailureDetector) - Method in class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- notifyQueryFinished(QueryResponse) - Method in class org.apache.pinot.broker.failuredetector.ConnectionFailureDetector
- notifyQueryFinished(QueryResponse) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Notifies the failure detector that a query is finished (COMPLETED, FAILED or TIMED_OUT).
- notifyQueryFinished(QueryResponse) - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- notifyQuerySubmitted(QueryResponse) - Method in class org.apache.pinot.broker.failuredetector.ConnectionFailureDetector
- notifyQuerySubmitted(QueryResponse) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Notifies the failure detector that a query is submitted.
- notifyQuerySubmitted(QueryResponse) - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- notifyUnhealthyServer(String, FailureDetector) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector.Listener
-
Notifies the listener of an unhealthy server.
- notifyUnhealthyServer(String, FailureDetector) - Method in class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- NumInFlightReqSelector - Class in org.apache.pinot.broker.routing.adaptiveserverselector
-
The
NumInFlightReqSelector
is an AdaptiveServerSelector implementation that picks the best server based on the number of in-flight queries being processed by the server. - NumInFlightReqSelector(ServerRoutingStatsManager) - Constructor for class org.apache.pinot.broker.routing.adaptiveserverselector.NumInFlightReqSelector
O
- onAssignmentChange(IdealState, ExternalView, Set<String>) - Method in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
-
Processes the segment assignment (ideal state or external view) change based on the given online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - onAssignmentChange(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.instanceselector.MultiStageReplicaGroupSelector
- onAssignmentChange(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetcher
- onAssignmentChange(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentselector.DefaultSegmentSelector
- onAssignmentChange(IdealState, ExternalView, Set<String>) - Method in interface org.apache.pinot.broker.routing.segmentselector.SegmentSelector
-
Processes the segment assignment (ideal state or external view) change based on the given online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - onAssignmentChange(IdealState, ExternalView, Set<String>) - Method in class org.apache.pinot.broker.routing.timeboundary.TimeBoundaryManager
-
Processes the segment assignment (ideal state or external view) change based on the given online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - onAssignmentChange(IdealState, ExternalView, Set<String>, List<String>, List<ZNRecord>) - Method in interface org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetchListener
-
Processes the segment assignment (ideal state or external view) change based on the given online segments (segments with ONLINE/CONSUMING instances in the ideal state and pre-selected by the
SegmentPreSelector
). - onAssignmentChange(IdealState, ExternalView, Set<String>, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionMetadataManager
- onAssignmentChange(IdealState, ExternalView, Set<String>, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.EmptySegmentPruner
- onAssignmentChange(IdealState, ExternalView, Set<String>, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.MultiPartitionColumnsSegmentPruner
- onAssignmentChange(IdealState, ExternalView, Set<String>, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.SinglePartitionColumnSegmentPruner
- onAssignmentChange(IdealState, ExternalView, Set<String>, List<String>, List<ZNRecord>) - Method in class org.apache.pinot.broker.routing.segmentpruner.TimeSegmentPruner
- onBecomeDroppedFromOffline(Message, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel
- onBecomeDroppedFromOnline(Message, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel
- onBecomeOfflineFromError(Message, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel
- onBecomeOfflineFromOnline(Message, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel
- onBecomeOnlineFromOffline(Message, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.BrokerResourceOnlineOfflineStateModelFactory.BrokerResourceOnlineOfflineStateModel
- onExternalViewChange(List<ExternalView>, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
- onIdealStateChange(List<IdealState>, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
- onInstanceConfigChange(List<InstanceConfig>, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
- onInstancesChange(Set<String>, List<String>) - Method in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
-
Processes the instances change.
- onInstancesChange(Set<String>, List<String>) - Method in class org.apache.pinot.broker.routing.instanceselector.MultiStageReplicaGroupSelector
- onLiveInstanceChange(List<LiveInstance>, NotificationContext) - Method in class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
- org.apache.pinot.broker.api - package org.apache.pinot.broker.api
- org.apache.pinot.broker.api.resources - package org.apache.pinot.broker.api.resources
- org.apache.pinot.broker.broker - package org.apache.pinot.broker.broker
- org.apache.pinot.broker.broker.helix - package org.apache.pinot.broker.broker.helix
- org.apache.pinot.broker.failuredetector - package org.apache.pinot.broker.failuredetector
- org.apache.pinot.broker.querylog - package org.apache.pinot.broker.querylog
- org.apache.pinot.broker.queryquota - package org.apache.pinot.broker.queryquota
- org.apache.pinot.broker.requesthandler - package org.apache.pinot.broker.requesthandler
- org.apache.pinot.broker.routing - package org.apache.pinot.broker.routing
- org.apache.pinot.broker.routing.adaptiveserverselector - package org.apache.pinot.broker.routing.adaptiveserverselector
- org.apache.pinot.broker.routing.instanceselector - package org.apache.pinot.broker.routing.instanceselector
- org.apache.pinot.broker.routing.segmentmetadata - package org.apache.pinot.broker.routing.segmentmetadata
- org.apache.pinot.broker.routing.segmentpartition - package org.apache.pinot.broker.routing.segmentpartition
- org.apache.pinot.broker.routing.segmentpreselector - package org.apache.pinot.broker.routing.segmentpreselector
- org.apache.pinot.broker.routing.segmentpruner - package org.apache.pinot.broker.routing.segmentpruner
- org.apache.pinot.broker.routing.segmentpruner.interval - package org.apache.pinot.broker.routing.segmentpruner.interval
- org.apache.pinot.broker.routing.segmentselector - package org.apache.pinot.broker.routing.segmentselector
- org.apache.pinot.broker.routing.timeboundary - package org.apache.pinot.broker.routing.timeboundary
P
- PINOT_CONFIGURATION - Static variable in class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- PinotBrokerAppConfigs - Class in org.apache.pinot.broker.api.resources
-
Resource to get the app configs
PinotAppConfigs
for the broker. - PinotBrokerAppConfigs() - Constructor for class org.apache.pinot.broker.api.resources.PinotBrokerAppConfigs
- PinotBrokerDebug - Class in org.apache.pinot.broker.api.resources
- PinotBrokerDebug() - Constructor for class org.apache.pinot.broker.api.resources.PinotBrokerDebug
- PinotBrokerHealthCheck - Class in org.apache.pinot.broker.api.resources
- PinotBrokerHealthCheck() - Constructor for class org.apache.pinot.broker.api.resources.PinotBrokerHealthCheck
- PinotBrokerLogger - Class in org.apache.pinot.broker.api.resources
-
Logger resource.
- PinotBrokerLogger() - Constructor for class org.apache.pinot.broker.api.resources.PinotBrokerLogger
- PinotBrokerRouting - Class in org.apache.pinot.broker.api.resources
- PinotBrokerRouting() - Constructor for class org.apache.pinot.broker.api.resources.PinotBrokerRouting
- PinotClientRequest - Class in org.apache.pinot.broker.api.resources
- PinotClientRequest() - Constructor for class org.apache.pinot.broker.api.resources.PinotClientRequest
- PinotStreamingQueryClient(GrpcConfig) - Constructor for class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler.PinotStreamingQueryClient
- preSelect(Set<String>) - Method in class org.apache.pinot.broker.routing.segmentpreselector.SegmentLineageBasedSegmentPreSelector
- preSelect(Set<String>) - Method in interface org.apache.pinot.broker.routing.segmentpreselector.SegmentPreSelector
-
Pre-selects the online segments to filter out the unnecessary segments.
- processBrokerRequest(long, BrokerRequest, BrokerRequest, BrokerRequest, Map<ServerInstance, Pair<List<String>, List<String>>>, BrokerRequest, Map<ServerInstance, Pair<List<String>, List<String>>>, long, BaseSingleStageBrokerRequestHandler.ServerStats, RequestContext) - Method in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
-
Processes the optimized broker requests for both OFFLINE and REALTIME table.
- processBrokerRequest(long, BrokerRequest, BrokerRequest, BrokerRequest, Map<ServerInstance, Pair<List<String>, List<String>>>, BrokerRequest, Map<ServerInstance, Pair<List<String>, List<String>>>, long, BaseSingleStageBrokerRequestHandler.ServerStats, RequestContext) - Method in class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler
- processBrokerRequest(long, BrokerRequest, BrokerRequest, BrokerRequest, Map<ServerInstance, Pair<List<String>, List<String>>>, BrokerRequest, Map<ServerInstance, Pair<List<String>, List<String>>>, long, BaseSingleStageBrokerRequestHandler.ServerStats, RequestContext) - Method in class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- processClusterChange(HelixConstants.ChangeType) - Method in interface org.apache.pinot.broker.broker.helix.ClusterChangeHandler
-
Processes the cluster change of the given type (e.g.
- processClusterChange(HelixConstants.ChangeType) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
- processClusterChange(HelixConstants.ChangeType) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
- processQueryRateLimitingExternalViewChange(ExternalView) - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
-
Process query quota change when number of online brokers has changed.
- processQueryRateLimitingInstanceConfigChange() - Method in class org.apache.pinot.broker.queryquota.HelixExternalViewBasedQueryQuotaManager
-
Process query quota state change when instance config gets changed
- processSqlQueryGet(String, String, AsyncResponse, Request, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotClientRequest
- processSqlQueryPost(String, AsyncResponse, Request, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotClientRequest
- processSqlWithMultiStageQueryEngineGet(String, AsyncResponse, Request, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotClientRequest
- processSqlWithMultiStageQueryEnginePost(String, AsyncResponse, Request, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotClientRequest
- prune(BrokerRequest, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentpruner.EmptySegmentPruner
- prune(BrokerRequest, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentpruner.MultiPartitionColumnsSegmentPruner
- prune(BrokerRequest, Set<String>) - Method in interface org.apache.pinot.broker.routing.segmentpruner.SegmentPruner
-
Prunes the segments queried by the given broker request, returns the selected segments to be queried.
- prune(BrokerRequest, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentpruner.SinglePartitionColumnSegmentPruner
- prune(BrokerRequest, Set<String>) - Method in class org.apache.pinot.broker.routing.segmentpruner.TimeSegmentPruner
-
NOTE: Pruning is done by searching _intervalTree based on request time interval and check if the results are in the input segments.
Q
- QueryLogger - Class in org.apache.pinot.broker.querylog
-
QueryLogger
is responsible for logging query responses in a configurable fashion. - QueryLogger(PinotConfiguration) - Constructor for class org.apache.pinot.broker.querylog.QueryLogger
- QueryLogger.QueryLogParams - Class in org.apache.pinot.broker.querylog
- QueryLogParams(RequestContext, String, BrokerResponse, RequesterIdentity, BaseSingleStageBrokerRequestHandler.ServerStats) - Constructor for class org.apache.pinot.broker.querylog.QueryLogger.QueryLogParams
- QueryQuotaEntity - Class in org.apache.pinot.broker.queryquota
- QueryQuotaEntity(RateLimiter, HitCounter, MaxHitRateTracker, int, double, int) - Constructor for class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- QueryQuotaManager - Interface in org.apache.pinot.broker.queryquota
R
- refreshRouting(String, String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerRouting
- refreshSegment(String) - Method in class org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetcher
- refreshSegment(String) - Method in class org.apache.pinot.broker.routing.timeboundary.TimeBoundaryManager
-
Refreshes the metadata for the given segment (called when segment is getting refreshed).
- refreshSegment(String, String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Refreshes the metadata for the given segment (called when segment is getting refreshed).
- refreshSegment(String, ZNRecord) - Method in interface org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetchListener
-
Refreshes the metadata for the given segment (called when segment is getting refreshed).
- refreshSegment(String, ZNRecord) - Method in class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionMetadataManager
- refreshSegment(String, ZNRecord) - Method in class org.apache.pinot.broker.routing.segmentpruner.EmptySegmentPruner
- refreshSegment(String, ZNRecord) - Method in class org.apache.pinot.broker.routing.segmentpruner.MultiPartitionColumnsSegmentPruner
- refreshSegment(String, ZNRecord) - Method in class org.apache.pinot.broker.routing.segmentpruner.SinglePartitionColumnSegmentPruner
- refreshSegment(String, ZNRecord) - Method in class org.apache.pinot.broker.routing.segmentpruner.TimeSegmentPruner
- register(FailureDetector.Listener) - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- register(FailureDetector.Listener) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Registers a listener to the failure detector.
- register(FailureDetector.Listener) - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- register(SegmentZkMetadataFetchListener) - Method in class org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetcher
- registerExtraComponents(BrokerAdminApiApplication) - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
-
Deprecated.Use
BaseBrokerStarter.createBrokerAdminApp()
instead. This method is called after initialization of BrokerAdminApiApplication object and before calling start to allow custom broker starters to register additional components. - removeRouting(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Removes the routing for the given table.
- removeRouting(String, HttpHeaders) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerRouting
- ReplicaGroupInstanceSelector - Class in org.apache.pinot.broker.routing.instanceselector
-
Instance selector for replica-group routing strategy.
- ReplicaGroupInstanceSelector(String, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, AdaptiveServerSelector, Clock, boolean) - Constructor for class org.apache.pinot.broker.routing.instanceselector.ReplicaGroupInstanceSelector
- RequesterIdentity - Class in org.apache.pinot.broker.api
- RequesterIdentity() - Constructor for class org.apache.pinot.broker.api.RequesterIdentity
- reset() - Method in class org.apache.pinot.broker.broker.helix.BrokerUserDefinedMessageHandlerFactory
- retryUnhealthyServer(String, FailureDetector) - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector.Listener
-
Notifies the listener to retry a previous unhealthy server.
- retryUnhealthyServer(String, FailureDetector) - Method in class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- routingExists(String) - Method in class org.apache.pinot.broker.routing.BrokerRoutingManager
-
Returns
true
if the routing exists for the given table.
S
- searchAll(Interval) - Method in class org.apache.pinot.broker.routing.segmentpruner.interval.IntervalTree
-
Find all values whose intervals intersect with the input interval.
- SegmentInstanceCandidate - Class in org.apache.pinot.broker.routing.instanceselector
-
Represents an instance candidate for a segment.
- SegmentInstanceCandidate(String, boolean) - Constructor for class org.apache.pinot.broker.routing.instanceselector.SegmentInstanceCandidate
- SegmentLineageBasedSegmentPreSelector - Class in org.apache.pinot.broker.routing.segmentpreselector
-
Segment lineage based segment pre-selector This pre-selector reads the segment lineage metadata and filters out either merged segments or original segments to make sure that the final segments contain no duplicate data.
- SegmentLineageBasedSegmentPreSelector(String, ZkHelixPropertyStore<ZNRecord>) - Constructor for class org.apache.pinot.broker.routing.segmentpreselector.SegmentLineageBasedSegmentPreSelector
- SegmentPartitionInfo - Class in org.apache.pinot.broker.routing.segmentpartition
- SegmentPartitionInfo(String, PartitionFunction, Set<Integer>) - Constructor for class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionInfo
- SegmentPartitionMetadataManager - Class in org.apache.pinot.broker.routing.segmentpartition
-
The
PartitionDataManager
manages partitions of a table. - SegmentPartitionMetadataManager(String, String, String, int) - Constructor for class org.apache.pinot.broker.routing.segmentpartition.SegmentPartitionMetadataManager
- SegmentPartitionUtils - Class in org.apache.pinot.broker.routing.segmentpartition
- SegmentPreSelector - Interface in org.apache.pinot.broker.routing.segmentpreselector
-
The segment pre-selector filters the unnecessary online segments for the query.
- SegmentPreSelectorFactory - Class in org.apache.pinot.broker.routing.segmentpreselector
- SegmentPruner - Interface in org.apache.pinot.broker.routing.segmentpruner
-
The segment pruner prunes the selected segments based on the query.
- SegmentPrunerFactory - Class in org.apache.pinot.broker.routing.segmentpruner
- SegmentSelector - Interface in org.apache.pinot.broker.routing.segmentselector
-
The segment selector selects the segments for the query.
- SegmentSelectorFactory - Class in org.apache.pinot.broker.routing.segmentselector
- SegmentStates - Class in org.apache.pinot.broker.routing.instanceselector
-
The
SegmentStates
contains the candidate instances for each segment, and the unavailable segments for routing purpose. - SegmentStates(Map<String, List<SegmentInstanceCandidate>>, Set<String>, Set<String>) - Constructor for class org.apache.pinot.broker.routing.instanceselector.SegmentStates
- SegmentZkMetadataFetcher - Class in org.apache.pinot.broker.routing.segmentmetadata
-
SegmentZkMetadataFetcher
is used to cacheZNRecord
stored inZkHelixPropertyStore
for segments. - SegmentZkMetadataFetcher(String, ZkHelixPropertyStore<ZNRecord>) - Constructor for class org.apache.pinot.broker.routing.segmentmetadata.SegmentZkMetadataFetcher
- SegmentZkMetadataFetchListener - Interface in org.apache.pinot.broker.routing.segmentmetadata
-
Interface to register with
SegmentZkMetadataFetcher
. - select(List<String>) - Method in interface org.apache.pinot.broker.routing.adaptiveserverselector.AdaptiveServerSelector
-
Picks the best server to route a query from the list of candidate servers.
- select(List<String>) - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.HybridSelector
- select(List<String>) - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.LatencySelector
- select(List<String>) - Method in class org.apache.pinot.broker.routing.adaptiveserverselector.NumInFlightReqSelector
- select(BrokerRequest) - Method in class org.apache.pinot.broker.routing.segmentselector.DefaultSegmentSelector
- select(BrokerRequest) - Method in interface org.apache.pinot.broker.routing.segmentselector.SegmentSelector
-
Selects the segments queried by the given broker request.
- select(BrokerRequest, List<String>, long) - Method in interface org.apache.pinot.broker.routing.instanceselector.InstanceSelector
-
Selects the server instances for the given segments queried by the given broker request, returns a map from segment to selected server instance hosting the segment and a set of unavailable segments (no enabled instance or all enabled instances are in ERROR state).
- SelectionResult(Pair<Map<String, String>, Map<String, String>>, List<String>, int) - Constructor for class org.apache.pinot.broker.routing.instanceselector.InstanceSelector.SelectionResult
- ServerStats() - Constructor for class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler.ServerStats
- setEndpointUrl(String) - Method in class org.apache.pinot.broker.api.HttpRequesterIdentity
- setHttpHeaders(Multimap<String, String>) - Method in class org.apache.pinot.broker.api.HttpRequesterIdentity
- setLoggerLevel(String, String) - Method in class org.apache.pinot.broker.api.resources.PinotBrokerLogger
- setNumOnlineBrokers(int) - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- setNumPrunedSegments(int) - Method in class org.apache.pinot.broker.routing.instanceselector.InstanceSelector.SelectionResult
-
Sets the number of segments pruned by the broker
- setOverallRate(double) - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- setRateLimiter(RateLimiter) - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- setServerStats(String) - Method in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler.ServerStats
- setTableConfigStatVersion(int) - Method in class org.apache.pinot.broker.queryquota.QueryQuotaEntity
- shutdown() - Method in class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler.PinotStreamingQueryClient
- shutDown() - Method in interface org.apache.pinot.broker.requesthandler.BrokerRequestHandler
- shutDown() - Method in class org.apache.pinot.broker.requesthandler.BrokerRequestHandlerDelegate
- shutDown() - Method in class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler
- shutDown() - Method in class org.apache.pinot.broker.requesthandler.MultiStageBrokerRequestHandler
- shutDown() - Method in class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- SingleConnectionBrokerRequestHandler - Class in org.apache.pinot.broker.requesthandler
-
The
SingleConnectionBrokerRequestHandler
class is a thread-safe broker request handler using a single connection per server to route the queries. - SingleConnectionBrokerRequestHandler(PinotConfiguration, String, BrokerRoutingManager, AccessControlFactory, QueryQuotaManager, TableCache, NettyConfig, TlsConfig, ServerRoutingStatsManager) - Constructor for class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- SinglePartitionColumnSegmentPruner - Class in org.apache.pinot.broker.routing.segmentpruner
-
The
SinglePartitionColumnSegmentPruner
prunes segments based on their partition metadata stored in ZK. - SinglePartitionColumnSegmentPruner(String, String) - Constructor for class org.apache.pinot.broker.routing.segmentpruner.SinglePartitionColumnSegmentPruner
- start() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- start() - Method in class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
-
Starts the cluster change mediator.
- start() - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- start() - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Starts the failure detector.
- start() - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- start() - Method in interface org.apache.pinot.broker.requesthandler.BrokerRequestHandler
- start() - Method in class org.apache.pinot.broker.requesthandler.BrokerRequestHandlerDelegate
- start() - Method in class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler
- start() - Method in class org.apache.pinot.broker.requesthandler.MultiStageBrokerRequestHandler
- start() - Method in class org.apache.pinot.broker.requesthandler.SingleConnectionBrokerRequestHandler
- start(List<ListenerConfig>) - Method in class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- START_TIME - Static variable in class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- stop() - Method in class org.apache.pinot.broker.broker.BrokerAdminApiApplication
- stop() - Method in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- stop() - Method in class org.apache.pinot.broker.broker.helix.ClusterChangeMediator
-
Stops the cluster change mediator.
- stop() - Method in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- stop() - Method in interface org.apache.pinot.broker.failuredetector.FailureDetector
-
Stops the failure detector.
- stop() - Method in class org.apache.pinot.broker.failuredetector.NoOpFailureDetector
- StrictReplicaGroupInstanceSelector - Class in org.apache.pinot.broker.routing.instanceselector
-
Instance selector for strict replica-group routing strategy.
- StrictReplicaGroupInstanceSelector(String, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics, AdaptiveServerSelector, Clock, boolean) - Constructor for class org.apache.pinot.broker.routing.instanceselector.StrictReplicaGroupInstanceSelector
- submit(String, int, Server.ServerRequest) - Method in class org.apache.pinot.broker.requesthandler.GrpcBrokerRequestHandler.PinotStreamingQueryClient
T
- TimeBoundaryManager - Class in org.apache.pinot.broker.routing.timeboundary
-
The
TimeBoundaryManager
class manages the time boundary information for a table. - TimeBoundaryManager(TableConfig, ZkHelixPropertyStore<ZNRecord>, BrokerMetrics) - Constructor for class org.apache.pinot.broker.routing.timeboundary.TimeBoundaryManager
- TimeSegmentPruner - Class in org.apache.pinot.broker.routing.segmentpruner
-
The
TimeSegmentPruner
prunes segments based on their time column start & end time metadata stored in ZK. - TimeSegmentPruner(TableConfig, DateTimeFieldSpec) - Constructor for class org.apache.pinot.broker.routing.segmentpruner.TimeSegmentPruner
- toResponse(Throwable) - Method in class org.apache.pinot.broker.api.resources.BrokerCommonExceptionMapper
- toString() - Method in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
Z
- ZkBasicAuthAccessControlFactory - Class in org.apache.pinot.broker.broker
-
Zookeeper Basic Authentication based on Pinot Controller UI.
- ZkBasicAuthAccessControlFactory() - Constructor for class org.apache.pinot.broker.broker.ZkBasicAuthAccessControlFactory
_
- _accessControlFactory - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _accessControlFactory - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _brokerAdminApplication - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _brokerConf - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _brokerId - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _brokerMetrics - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _brokerMetrics - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _brokerMetrics - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _brokerQueryEventListener - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _brokerRequestHandler - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _brokerTimeoutMs - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _clusterChangeMediator - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _clusterName - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _config - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _defaultHllLog2m - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _disableGroovy - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _enableDistinctCountBitmapOverride - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _enableQueryLimitOverride - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _externalViewChangeHandlers - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _helixAdmin - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _helixDataAccessor - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _hostname - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _idealStateChangeHandlers - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _instanceConfigChangeHandlers - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _instanceId - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _listenerConfigs - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _listeners - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _liveInstanceChangeHandlers - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _max - Variable in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- _maxRetries - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _metricsRegistry - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _min - Variable in class org.apache.pinot.broker.routing.segmentpruner.interval.Interval
- _name - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _participantHelixManager - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _port - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _propertyStore - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _queriesById - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _queryLogger - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _queryOptimizer - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _queryQuotaManager - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _queryResponseLimit - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _requestIdGenerator - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _retryDelayFactor - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _retryInfoDelayQueue - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _retryInitialDelayNs - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _retryThread - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _routingManager - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _routingManager - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _running - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _serverRoutingStatsManager - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _spectatorHelixManager - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _sqlQueryExecutor - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _tableCache - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _tlsPort - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
- _trackedHeaders - Variable in class org.apache.pinot.broker.requesthandler.BaseBrokerRequestHandler
- _unhealthyServerRetryInfoMap - Variable in class org.apache.pinot.broker.failuredetector.BaseExponentialBackoffRetryFailureDetector
- _useApproximateFunction - Variable in class org.apache.pinot.broker.requesthandler.BaseSingleStageBrokerRequestHandler
- _zkServers - Variable in class org.apache.pinot.broker.broker.helix.BaseBrokerStarter
All Classes All Packages