Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W Y Z _ 

A

abort() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Abort the task.
aborted(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Change the task state to aborted.
AbstractAcceptanceGoal - Class in io.confluent.cruisecontrol.analyzer.goals
An abstract class for goals that only validates actions generated by other goals.
AbstractAcceptanceGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
 
AbstractConfig - Class in com.linkedin.cruisecontrol.common.config
A convenient base class for configurations to extend.
AbstractConfig(ConfigDef, Map<?, ?>, boolean) - Constructor for class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
AbstractConfig(ConfigDef, Map<?, ?>) - Constructor for class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
AbstractGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
An abstract class for goals.
AbstractGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Constructor of Abstract Goal class sets the _finished flag to false to signal that the goal requirements have not been satisfied, yet.
AbstractReplicaMovementStrategy - Class in com.linkedin.kafka.cruisecontrol.executor.strategy
An abstract class for replica movement strategy.
AbstractReplicaMovementStrategy() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.strategy.AbstractReplicaMovementStrategy
 
accept(boolean, Throwable) - Method in interface io.confluent.databalancer.operation.BalanceOpExecutionCompletionCallback
 
acquireForModelGeneration(OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Acquire the semaphore for the cluster model generation.
action() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
ActionAcceptance - Enum in com.linkedin.kafka.cruisecontrol.analyzer
Flags to indicate if an action is acceptable by the goal(s).
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Check whether the given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskCapacityGoal
 
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
 
actionAcceptance(BalancingAction, ClusterModel) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Check whether the given action is acceptable by this goal in the given state of the cluster.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Check whether the given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Check whether given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
An action is acceptable if it does not move the leader bytes in above the threshold for leader bytes in.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
Check whether the given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundCapacityGoal
 
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundUsageDistributionGoal
 
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Check whether given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Check whether given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Check whether given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
Check whether the given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Check whether given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Check whether the given action is acceptable by this goal.
actionAcceptance(BalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.CrossRackMovementGoal
Check if the action will move data between racks, and reject it if it would.
actionAcceptance(BalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Assuming that the cluster already satisfies replica placement constraints, then: Replica movement from broker A to broker B is accepted in two cases 1.
actionAcceptance(BalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.SequentialReplicaMovementGoal
Check if the action will move a replica of partition which already has a replica movement planned, and reject it if it would.
ActionType - Enum in com.linkedin.kafka.cruisecontrol.analyzer
Flags to indicate the type of an action.
actionUuid() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
ACTIVE_BALANCER_COUNT_METRIC_NAME - Static variable in class io.confluent.databalancer.KafkaDataBalanceManager
 
add(short, MetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Add the metric value to the given metric id.
add(AggregatedMetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Add another AggregatedMetricValues to this one.
add(double[]) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Add a value array to the existing value array.
add(MetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Add another MetricValue to this MetricValues.
add(Replica) - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
Add a new replicas to the sorted replicas.
addBrokerAddStatus(BrokerAddStatus) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
addBrokerRemovalStateRecord(BrokerRemovalStateRecord) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
addBrokers(MultiBrokerAdditionOperation, BalanceOpExecutionCompletionCallback, String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Add brokers.
addBrokers(Set<Integer>, String) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
addBrokers(Set<Integer>, String) - Method in interface io.confluent.databalancer.DataBalanceEngine
 
addBrokers(Set<Integer>, String) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
addErrorMessage(String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
addExecutionProposals(Collection<ExecutionProposal>, Collection<Integer>, Cluster, ReplicaMovementStrategy) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Add a collection of execution proposals for execution.
addExecutionProposals(Collection<ExecutionProposal>, Cluster, ReplicaMovementStrategy) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Add each given proposal to execute, unless the given cluster state indicates that the proposal would be a no-op.
addIneligibleBroker(Broker) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Record the broker which is unable to host the replica of the partition.
addMetric(CruiseControlMetric) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
 
addMetric(Class<?>, String) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry.MetricsAllowListBuilder
 
addMetricObservation(Collection<BrokerMetricSample>) - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
 
addMetricObservation(Collection<BrokerMetricSample>) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
addSample(MetricSample<G, E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Add a sample to the metric aggregator.
addSample(MetricSample<?, ?>, long, MetricDef) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Add a MetricSample to the raw metric values.
addSample(PartitionMetricSample) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Add a sample to the metric aggregator.
addSample(PartitionMetricSample, boolean) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Add a sample to the metric aggregator.
addSingleBrokerStats(String, int, Broker.State, double, double, double, double, double, double, int, int, boolean, double, Map<String, DiskStats>) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
addStep(OperationStep) - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
Add a OperationStep to the progress.
addTasksToTrace(Collection<ExecutionTask>, ExecutionTask.TaskType) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Add new tasks to ExecutionTaskTracker to trace their execution.
ADMIN_CLIENT_CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
AdminClientResult<T> - Class in com.linkedin.kafka.cruisecontrol.common
 
AdminClientResult(T) - Constructor for class com.linkedin.kafka.cruisecontrol.common.AdminClientResult
 
AdminClientResult(Throwable) - Constructor for class com.linkedin.kafka.cruisecontrol.common.AdminClientResult
 
advanceState(E) - Method in class io.confluent.databalancer.operation.StateMachine
React to an event #E by advancing the state machine.
aggregate(long, long, AggregationOptions<G, E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Aggregate the metric samples in the given period into a MetricSampleAggregationResult based on the specified AggregationOptions.
aggregate(SortedSet<Long>, MetricDef) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Get the aggregated values of the given sorted set of windows.
aggregate(Set<BrokerEntity>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaBrokerMetricSampleAggregator
Aggregate the metrics for the given brokers.
aggregate(MetadataClient.ClusterAndGeneration, long, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Collect the aggregated metrics for all the topic partitions.
aggregate(MetadataClient.ClusterAndGeneration, long, long, ModelCompletenessRequirements, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Collect the aggregated metrics for all the topic partitions for a time window.
AggregatedMetricValues - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
The aggregated metric values.
AggregatedMetricValues() - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Create an empty metric values.
AggregatedMetricValues(Map<Short, MetricValues>) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Create an AggregatedMetricValues with the given values by metric ids.
AggregationFunction - Enum in com.linkedin.cruisecontrol.metricdef
Define the way to pick the metric values among all the samples in a window.
aggregationFunction() - Method in class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
AggregationOptions<G,E extends Entity<G>> - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
The metric sample aggregation options.
AggregationOptions(double, double, int, int, Set<E>, AggregationOptions.Granularity, boolean) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
Construct an AggregationOptions.
AggregationOptions.Granularity - Enum in com.linkedin.cruisecontrol.monitor.sampling.aggregator
The granularity of the aggregation.
alert(Object, boolean, long, AnomalyType) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
Alert on anomaly.
alert(Object, boolean, long, AnomalyType) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
aliveBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get alive brokers in the cluster.
aliveBrokersMatchingAttributes(Map<String, String>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get brokers with matching attributes
aliveBrokersOverThreshold(Resource, double) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
aliveBrokersUnderThreshold(Resource, double) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
aliveRackIds() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
all() - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
 
allMetricTypes() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
allMetricValues() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
allWindows() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
ANALYZER_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
AnalyzerState - Class in com.linkedin.kafka.cruisecontrol.analyzer
The state for the analyzer.
AnalyzerState(boolean, Map<Goal, Boolean>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
analyzerState() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
AnalyzerUtils - Class in com.linkedin.kafka.cruisecontrol.analyzer
A util class for Analyzer.
Anomaly - Interface in com.linkedin.cruisecontrol.detector
The interface for an anomaly.
anomaly() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
ANOMALY_DETECTION_ALLOW_CAPACITY_ESTIMATION_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
anomaly.detection.allow.capacity.estimation
ANOMALY_DETECTION_GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
anomaly.detection.goals
ANOMALY_DETECTION_INTERVAL_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
anomaly.detection.interval.ms
ANOMALY_DETECTOR_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
ANOMALY_NOTIFIER_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
anomaly.notifier.class
AnomalyDetector - Class in com.linkedin.kafka.cruisecontrol.detector
The anomaly detector class that helps detect and handle anomalies.
AnomalyDetector(KafkaCruiseControlConfig, Option<ZKClientConfig>, LoadMonitor, KafkaCruiseControl, Time, DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
anomalyDetectorState() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
AnomalyDetectorState - Class in com.linkedin.kafka.cruisecontrol.detector
 
AnomalyDetectorState(Time, Map<AnomalyType, Boolean>, int, DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorState
 
anomalyDetectorState() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
AnomalyDetectorUtils - Class in com.linkedin.kafka.cruisecontrol.detector
A util class for Anomaly Detectors.
anomalyId() - Method in interface com.linkedin.cruisecontrol.detector.Anomaly
 
anomalyId() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
anomalyId() - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
 
anomalyId() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations
 
AnomalyMetrics - Class in com.linkedin.kafka.cruisecontrol.detector
 
AnomalyMetrics(Map<AnomalyType, Double>, double, long, long) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.AnomalyMetrics
Mean time between anomalies: The mean time between detected anomalies, while there is no ongoing execution. Mean time to start fix: Mean time between the detection of earliest ongoing anomaly and start of a proposal execution.
AnomalyNotificationResult - Class in com.linkedin.kafka.cruisecontrol.detector.notifier
The result of an anomaly notification.
AnomalyNotificationResult.Action - Enum in com.linkedin.kafka.cruisecontrol.detector.notifier
 
AnomalyNotifier - Interface in com.linkedin.kafka.cruisecontrol.detector.notifier
 
AnomalyState - Class in com.linkedin.kafka.cruisecontrol.detector
A class to indicate how an anomaly is handled.
AnomalyState(Anomaly) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
AnomalyState.Status - Enum in com.linkedin.kafka.cruisecontrol.detector
 
AnomalyType - Enum in com.linkedin.kafka.cruisecontrol.detector.notifier
Flags to indicate the type of an anomaly.
API_STATE_TOPIC_CLEANUP_POLICY - Static variable in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
ApiStatePersistenceStore - Class in io.confluent.databalancer.persistence
This class stores state of an SBK API (remove broker, add broker) as it executes its state machine and transitions from one state to another.
ApiStatePersistenceStore(KafkaConfig, Time, Map<String, Object>) - Constructor for class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
ApiStatePersistenceStore.SbkApiStatusKeySerde - Class in io.confluent.databalancer.persistence
 
ApiStatePersistenceStore.SbkApiStatusMessageSerde - Class in io.confluent.databalancer.persistence
 
applyStrategy(Set<ExecutionTask>, Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.AbstractReplicaMovementStrategy
 
applyStrategy(Set<ExecutionTask>, Cluster) - Method in interface com.linkedin.kafka.cruisecontrol.executor.strategy.ReplicaMovementStrategy
Determine the execution order for replica movement tasks based on a customized strategy.
arrayIndex(long) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
Get the array index of the given window index.
assignPartitions(Cluster, int) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.DefaultMetricSamplerPartitionAssignor
 
assignPartitions(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.DefaultMetricSamplerPartitionAssignor
 
assignPartitions(Cluster, int) - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSamplerPartitionAssignor
Deprecated.
Please use MetricSamplerPartitionAssignor.assignPartitions(Cluster). Assign the partitions in the cluster to the metric fetchers.
assignPartitions(Cluster) - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSamplerPartitionAssignor
Assign the partitions in the cluster to the single metric fetcher.
atLeast(Number) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef.Range
A numeric range that checks only the lower bound
ATTRIBUTE_MAX - Static variable in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
 
ATTRIBUTE_MEAN - Static variable in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
 
attributes() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the attributes of the broker.
authorizedOperations() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
The authorized operations.
AUTO_THROTTLE - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
AutoCloseableSemaphore() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor.AutoCloseableSemaphore
 
availableWindows() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Get a list of available windows in the MetricSampleAggregator.
averageDiskUtilizationPercentage(Broker) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Get the latest average utilization percentage of all the alive disks on the broker.
avg() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
 
awaitingPauseSampling() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Allow tasks to know if another thread, e.g.

B

backoff(Supplier<Boolean>, int, long, long, Time) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Run some boolean operation with exponential backoff until it succeeds or maxTimeout is hit.
balancednessCostByGoal(List<Goal>, double, double) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Get the balancedness cost of violating goals by their name, where the sum of costs is KafkaCruiseControlUtils.MAX_BALANCEDNESS_SCORE.
balancednessScore() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolationDetector
 
balanceLowerThreshold() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
BalanceOpExecutionCompletionCallback - Interface in io.confluent.databalancer.operation
A callback routine to be invoked when a CruiseControl ProposalExecution (rebalance plan) completes execution, whether successfully or otherwise.
BalancerOperationCallback<S extends BalancerOperationState,E extends BalancerOperationEvent> - Interface in io.confluent.databalancer.operation
This class helps track the progress of a single balancer operation.
BalancerOperationEvent - Interface in io.confluent.databalancer.operation
An interface to denote an event that is part of an SBK operation (add broker, remove broker).
BalancerOperationProgressListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for a listener for the progress of a balancer operation
BalancerOperationState - Interface in io.confluent.databalancer.operation
An interface to denote the state of an SBK operation (add broker, remove broker).
BalancerOperationTerminationListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for a listener that gets called when a balancer operation reaches a terminal state
balanceUpperThreshold() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
balancingAction() - Method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionType
 
BalancingAction - Class in com.linkedin.kafka.cruisecontrol.analyzer
Represents the load balancing operation over a replica for Kafka Load GoalOptimizer.
BalancingAction(TopicPartition, Integer, Integer, ActionType) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Constructor for creating a balancing proposal with given topic partition, source and destination broker id, and balancing action type.
BalancingAction(TopicPartition, Integer, Integer, ActionType, TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Constructor for creating a balancing proposal with given topic partitions, source and destination broker id, balancing action type and the topic partition of replica to swap with.
BalancingAction(TopicPartition, Disk, Disk, ActionType) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Constructor for creating a balancing proposal with given topic partition, source and destination disk (on the same broker), and balancing action type.
BalancingAction(TopicPartition, Disk, Disk, ActionType, TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Constructor for creating a balancing proposal with given topic partitions, source and destination disk (on the same broker), balancing action type and the topic partition of replica to swap with.
balancingAction() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the type of action that provides balancing.
BalancingConstraint - Class in com.linkedin.kafka.cruisecontrol.analyzer
A class that holds the information of balancing constraint of resources, balance and capacity thresholds, and self healing distribution threshold multiplier.
BalancingConstraint(KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Constructor for Balancing Constraint.
BalancingConstraint(BalancingConstraint) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
 
BaseReplicaMovementStrategy - Class in com.linkedin.kafka.cruisecontrol.executor.strategy
The basic replica movement strategy, which determines the tasks' execution order based on their task id.
BaseReplicaMovementStrategy() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.strategy.BaseReplicaMovementStrategy
 
between(Number, Number) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef.Range
A numeric range that checks both the upper and lower bound
BlockingSend - Interface in com.linkedin.kafka.cruisecontrol.client
 
BlockingSendClient - Class in com.linkedin.kafka.cruisecontrol.client
#BlockingSendClient is a client used for sending internal inter-broker requests.
BlockingSendClient.Builder - Class in com.linkedin.kafka.cruisecontrol.client
 
BOOTSTRAP_SERVERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
bootstrap.servers
brokenBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get broken brokers brokers -- i.e.
broker() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerAndSortedReplicas
 
broker() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
Broker - Class in com.linkedin.kafka.cruisecontrol.model
A class that holds the information of the broker, including its liveness and load for replicas.
broker(int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the requested broker in the cluster.
broker() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
broker(int) - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
broker(int) - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the broker with the given broker id.
broker() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get broker that the replica resides in.
BROKER - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
Broker.State - Enum in com.linkedin.kafka.cruisecontrol.model
 
BROKER_ADD_COUNT_METRIC_NAME - Static variable in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
BROKER_ADDITION_STATE_METRIC_NAME - Static variable in class io.confluent.databalancer.KafkaDataBalanceManager
 
BROKER_CAPACITY_CONFIG_RESOLVER_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.capacity.config.resolver.class
BROKER_CAPACITY_CONFIG_RESOLVER_OBJECT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
 
BROKER_FAILURE_ALERT_THRESHOLD_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.failure.alert.threshold.ms
BROKER_FAILURE_ALERT_THRESHOLD_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
BROKER_FAILURE_EXCLUDE_RECENTLY_DEMOTED_BROKERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.failure.exclude.recently.demoted.brokers
BROKER_FAILURE_EXCLUDE_RECENTLY_REMOVED_BROKERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.failure.exclude.recently.removed.brokers
BROKER_FAILURE_SELF_HEALING_THRESHOLD_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.failure.self.healing.threshold.ms
BROKER_FAILURE_SELF_HEALING_THRESHOLD_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
BROKER_ID - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
BROKER_METRIC_SAMPLE_AGGREGATOR_COMPLETENESS_CACHE_SIZE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.metric.sample.aggregator.completeness.cache.size
BROKER_METRIC_SAMPLE_STORE_TOPIC_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
BROKER_METRICS_WINDOW_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
broker.metrics.window.ms
BROKER_REMOVAL_SHUTDOWN_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
The amount of time to block for when waiting for the broker to be shut down.
BROKER_REMOVAL_STATE_METRIC_NAME - Static variable in class io.confluent.databalancer.KafkaDataBalanceManager
 
BROKER_SAMPLE_STORE_TOPIC_PARTITION_COUNT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
BROKER_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
BROKER_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
BrokerAdditionCallback - Interface in com.linkedin.kafka.cruisecontrol.operation
This class helps track the progress of a single broker addition.
brokerAdditions() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
BrokerAdditionStateMachine - Class in io.confluent.databalancer.operation
This is an ASCII representation of the state machine diagram in https://confluentinc.atlassian.net/wiki/spaces/CNKAF/pages/1549730493/SBK+Add+Broker+API+-+Kafka+1-Pager +-----------------------------+ | REASSIGNMENT_CANCELED | | <-------------------------+ | CANCELED | | +-----------------------------+ | | +-----------------------------+ | | PLAN_COMPUTATION_CANCELED | | | <-----------+ | | CANCELED | | | +-----------------------------+ | | | | | BROKER_REMOVAL_REQUEST_OVERRIDES | BROKER_REMOVAL_REQUEST_OVERRIDES | | | | +-------------+ +---------------+-------------+ SUCCESS +--------------+--------------+ SUCCESS +-----------------------------+ | | | PLAN_COMPUTATION | | REASSIGNMENT | | COMPLETED | | START +--------->+ +------------------> +-----------------> | | | | PENDING | | IN_PROGRESS | | COMPLETED | +-------------+ +---------------+-------------+ +--------------+--------------+ +-----------------------------+ | | | UNEXPECTED_ERROR | UNEXPECTED_ERROR | | +-----------------------------+ | | | PLAN_COMPUTATION_FAILED | | | | <-----------+ | | ERROR | | +-----------------------------+ | +-----------------------------+ | | REASSIGNMENT_FAILED | | | <------------------------+ | ERROR | +-----------------------------+
BrokerAdditionStateMachine(int) - Constructor for class io.confluent.databalancer.operation.BrokerAdditionStateMachine
 
BrokerAdditionStateMachine.BrokerAdditionEvent - Enum in io.confluent.databalancer.operation
An #BalancerOperationEvent that can take place during the broker addition operation
BrokerAdditionStateMachine.BrokerAdditionState - Enum in io.confluent.databalancer.operation
All the possible states of the broker addition operation
BrokerAdditionStateManager - Class in io.confluent.databalancer.operation
This class encapsulates the nitty-gritty logic of tracking and advancing the broker addition state machine for a single broker's addition.
BrokerAdditionStateManager(int, BalancerOperationProgressListener<BrokerAdditionStateMachine.BrokerAdditionState>, BalancerOperationTerminationListener<BrokerAdditionStateMachine.BrokerAdditionState>, AtomicReference<String>, Time) - Constructor for class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
BrokerAndSortedReplicas - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A class that maintains the broker and a sorted set of replicas based on a given comparator.
BrokerAndSortedReplicas(Broker, Comparator<Replica>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerAndSortedReplicas
 
BrokerCapacityConfigFileResolver - Class in com.linkedin.kafka.cruisecontrol.config
The broker capacity config resolver implementation based on files.
BrokerCapacityConfigFileResolver() - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
BrokerCapacityConfigResolver - Interface in com.linkedin.kafka.cruisecontrol.config
The interface for getting the broker capacity.
BrokerCapacityInfo - Class in com.linkedin.kafka.cruisecontrol.config
 
BrokerCapacityInfo(Map<Resource, Double>, String, Map<String, Double>, short) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with the given capacity, estimation, per absolute logDir disk capacity, and number of CPU cores.
BrokerCapacityInfo(Map<Resource, Double>, Map<String, Double>, short) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with the given capacity, per absolute logDir disk capacity, and number of CPU cores.
BrokerCapacityInfo(Map<Resource, Double>, short) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with the given capacity and number of CPU cores.
BrokerCapacityInfo(Map<Resource, Double>, String, Map<String, Double>) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with the given capacity, estimation, and per absolute logDir disk capacity.
BrokerCapacityInfo(Map<Resource, Double>, String) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with no capacity information specified per absolute logDir.
BrokerCapacityInfo(Map<Resource, Double>, Map<String, Double>) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with no estimation.
BrokerCapacityInfo(Map<Resource, Double>) - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
BrokerCapacityInfo with no estimation, no capacity information specified per absolute logDir.
BrokerCapacityResolver - Class in com.linkedin.kafka.cruisecontrol.config
The broker capacity config resolver implementation based on value stored directly in the KafkaCruiseControlConfig.
BrokerCapacityResolver() - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
BrokerEntity - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
The Entity class used by MetricSampleAggregator for brokers.
BrokerEntity(String, int) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
brokerEpoch - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
BrokerFailureDetector - Class in com.linkedin.kafka.cruisecontrol.detector
This class detects broker failures.
BrokerFailureDetector(KafkaCruiseControlConfig, Option<ZKClientConfig>, LoadMonitor, Queue<Anomaly>, Time, KafkaCruiseControl, List<String>) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.BrokerFailureDetector
 
BrokerFailures - Class in com.linkedin.kafka.cruisecontrol.detector
The broker failures that have been detected.
BrokerFailures(KafkaCruiseControl, Map<Integer, Long>, boolean, boolean, boolean, List<String>) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
An anomaly to indicate broker failure(s).
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
Get the broker id who reported this metric.
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionMetricSample
The id of the broker from which the metrics are from.
brokerId() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
brokerId() - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
brokerId() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
brokerIds() - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 
BrokerLoad - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
A helper class to hold broker load.
BrokerLoad() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
BrokerMetric - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
A container class to hold broker metric.
BrokerMetric(RawMetricType, long, int, double) - Constructor for class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.BrokerMetric
 
brokerMetric(RawMetricType) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
brokerMetricAvailable(RawMetricType) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
brokerMetricDef() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
brokerMetrics() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
BrokerMetricSample - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
The class hosting all the broker level metrics in KafkaMetricDef.
BrokerMetricSample(String, Integer, byte) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
Create a broker metric sample with the given host name, broker id, and version to be used in deserialization.
brokerMetricSamples() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.Samples
 
brokerMetricTypesDiffByVersion() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
brokerMetricTypesDiffForVersion(byte) - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
brokerMonitoringPeriodMs() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore.SampleLoader
 
BrokerRemovalCallback - Interface in com.linkedin.kafka.cruisecontrol.operation
This class helps track the progress of a single broker removal operation.
BrokerRemovalCancellationMode - Enum in io.confluent.databalancer.operation
An enumeration of the possible modes of cancelling a broker removal operation.
BrokerRemovalFuture - Class in com.linkedin.kafka.cruisecontrol.operation
A class that encapsulates the multiple futures and handles that compose a running broker removal operation.
BrokerRemovalFuture(AtomicReference<Executor.ReservationHandle>, CompletableFuture<Void>, CompletableFuture<Future<?>>) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalFuture
 
brokerRemovalFuture(int) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
BrokerRemovalOptions - Class in com.linkedin.kafka.cruisecontrol.operation
A mutable set of options for broker removal to be passed around each broker removal phase in #BrokerRemovalPhaseExecutor.
BrokerRemovalOptions(Set<Integer>, Optional<Long>, BrokerRemovalCallback, String, PlanComputationOptions, OperationProgress) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
BrokerRemovalPhase<T> - Interface in com.linkedin.kafka.cruisecontrol.operation
A functional interface to implement a phase of the broker removal operation.
BrokerRemovalPhaseBuilder - Class in com.linkedin.kafka.cruisecontrol.operation
A class that helps orchestrate all the necessary steps for achieving a broker removal.
BrokerRemovalPhaseBuilder() - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseBuilder
Build the necessary phase executors with the appropriate removal events on success/failure.
BrokerRemovalPhaseExecutor<T> - Class in com.linkedin.kafka.cruisecontrol.operation
A #BrokerRemovalPhaseExecutor is a wrapper encapsulating the repeatable pattern of each broker removal phase execution.
BrokerRemovalPhaseExecutor.Builder<T> - Class in com.linkedin.kafka.cruisecontrol.operation
 
BrokerRemovalRestartablePhase<T> - Class in com.linkedin.kafka.cruisecontrol.operation
A broker removal phase that can be part of Broker Removal state machine either when it is started anew or if it restarted during failure recovery.
BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder<T> - Class in com.linkedin.kafka.cruisecontrol.operation
 
BrokerRemovalRestartablePhaseBuilder() - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder
 
brokerRemovals() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
BrokerRemovalStateMachine - Class in io.confluent.databalancer.operation
This is an ASCII representation of the state machine diagram in https://confluentinc.atlassian.net/wiki/spaces/CNKAF/pages/1219931556/SBK+Remove+Broker+Mega-Pager SUCCESS SUCCESS SUCCESS SUCCESS +-----------------------------------------------+ +--------------------------------+ +---------------------------+ +----------------------------------------+ | | | | | | | | | v | v | v | v +----------------+-------------------+ +--------------+-+----------+ +-------------+--+-----------+ +---------+--+-------------+ +-----------+--------------+ | INITIAL_PLAN_COMPUTATION_INITIATED | | BROKER_SHUTDOWN_INITIATED | | PLAN_COMPUTATION_INITIATED | | PLAN_EXECUTION_INITIATED | | PLAN_EXECUTION_SUCCEEDED | | | | | | | | | | | | PAR=PENDING | | PAR=IN_PROGRESS | | PAR=IN_PROGRESS | | PAR=IN_PROGRESS | | PAR=SUCCESS | | BSS=PENDING | | BSS=PENDING | | BSS=COMPLETED | | BSS=COMPLETED | | BSS=COMPLETED | +-------------------+-+--------------+ +-----------+-+-------------+ +-------------+-----+--------+ +--------------------+---+-+ +--------------------------+ | | | | | | | ERROR | ERROR | | ERROR | | BROKER ERROR | | BROKER | | | | | RESTART | | RESTART | | | | | | | +---------------------------------+ | +------------------------+ | | +-------------------------+ | | +-----------------------+ | | | INITIAL_PLAN_COMPUTATION_FAILED | | | BROKER_SHUTDOWN_FAILED | | | | PLAN_COMPUTATION_FAILED | | | | PLAN_EXECUTION_FAILED | | | | | | | | | | | | | | | | | | | PAR=ERROR +<-----+ | PAR=CANCELED +<----------+ | | PAR=ERROR <-----+ | | PAR=ERROR +<---+ | | BSS=CANCELED | | BSS=FAILED | | | BSS=COMPLETED | | | BSS=COMPLETED | | +---------------------------------+ +------------------------+ | +-------------------------+ | +-----------------------+ | | | | | | | +------------------------+ | +-------------------------+ | +------------------------+ | |BROKER_SHUTDOWN_CANCELED| | |PLAN_COMPUTATION_CANCELED| | | PLAN_EXECUTION_CANCELED| | | | | | | | | | | | PAR=CANCELED +<------------+ | PAR=CANCELED +<----------+ | PAR=CANCELED +<------+ | BSS=CANCELED | | BSS=COMPLETED | | BSS=COMPLETED | +------------------------+ +-------------------------+ +------------------------+ Created via https://asciiflow.com/
BrokerRemovalStateMachine(int) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
BrokerRemovalStateMachine(int, BrokerRemovalStateMachine.BrokerRemovalState) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
BrokerRemovalStateMachine.BrokerRemovalEvent - Enum in io.confluent.databalancer.operation
 
BrokerRemovalStateMachine.BrokerRemovalState - Enum in io.confluent.databalancer.operation
All the possible states of the broker removal operation
BrokerRemovalStateRecord - Class in io.confluent.databalancer.persistence
An internal, persisted representation of a broker removal operation's state
BrokerRemovalStateRecord(int, BrokerRemovalStateMachine.BrokerRemovalState, Exception) - Constructor for class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
BrokerRemovalStateSerializer - Class in io.confluent.databalancer.persistence
A simple helper to serialize #BrokerRemovalStateMachine.BrokerRemovalState
BrokerRemovalStateSerializer() - Constructor for class io.confluent.databalancer.persistence.BrokerRemovalStateSerializer
 
BrokerRemovalStateTracker - Class in io.confluent.databalancer.operation
This class encapsulates the nitty-gritty logic of tracking and advancing the broker removal state machine.
BrokerRemovalStateTracker(int, BalancerOperationProgressListener<BrokerRemovalStateMachine.BrokerRemovalState>, BalancerOperationTerminationListener<BrokerRemovalStateMachine.BrokerRemovalState>, AtomicReference<String>) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
BrokerRemovalStateTracker(int, BrokerRemovalStateMachine.BrokerRemovalState, BalancerOperationProgressListener<BrokerRemovalStateMachine.BrokerRemovalState>, BalancerOperationTerminationListener<BrokerRemovalStateMachine.BrokerRemovalState>, AtomicReference<String>) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
BROKERS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
brokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of brokers in the cluster.
brokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
BROKERS - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
brokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the collection of brokers in the current rack.
BROKERS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
brokerSampleCount() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore.SampleLoader
 
brokerSampleDeserializationVersion() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
brokersBeingAdded() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
Returns a {#@link Set} of broker ids representing the brokers being added to the cluster as part of a #MultiBrokerAdditionOperation
brokersBeingAdded() - Method in interface io.confluent.databalancer.DataBalanceEngineContext
Returns a {#@link Set} of broker ids representing the brokers being added to the cluster as part of a #MultiBrokerAdditionOperation
brokersHavingOfflineReplicasOnBadDisks() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get brokers containing offline replicas residing on bad disks in the current cluster model.
BrokerShutdownManager - Class in com.linkedin.kafka.cruisecontrol.server
 
BrokerShutdownManager(SbkAdminUtils, KafkaCruiseControlConfig, BlockingSendClient.Builder, Time) - Constructor for class com.linkedin.kafka.cruisecontrol.server.BrokerShutdownManager
 
brokerShutdownStatus() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Returns the broker shutdown status for this state.
brokerShutdownStatus() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
brokerStats(KafkaCruiseControlConfig) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get broker return the broker stats.
BrokerStats - Class in com.linkedin.kafka.cruisecontrol.servlet.response.stats
Get broker level stats in human readable format.
BrokerStats(KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
brokerStatsAfterOptimization() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
brokerStatsBeforeOptimization() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Get sorted brokers that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
This is a hard goal; hence, the proposals are not limited to broken broker replicas in case of self-healing.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Get brokers in the cluster so that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Get brokers in the cluster so that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Get brokers that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
This is a hard goal; hence, the proposals are not limited to dead broker replicas in case of self-healing.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
This is a hard goal; hence, the proposals are not limited to dead broker replicas in case of self-healing.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
Get brokers that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Get brokers that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Get brokers that the rebalance process will go over to apply balancing actions to replicas they contain.
brokersToBalance(ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
No brokers need to be balanced for this goal, because it only needs to validate moves proposed by other goals
brokersToBalance(ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
brokersToRemove - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
brokersWithBadDisks() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of brokers with bad disks -- i.e.
brokersWithOfflineReplicas(int) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get all the brokers having offline replca in the cluster based on the partition assignment.
brokersWithReplicas(int) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get all the active brokers in the cluster based on the replica assignment.
build(BrokerEndPoint) - Method in class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient.Builder
 
build(BrokerRemovalCallback, BrokerRemovalOptions) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseExecutor.Builder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
build(StateMachineInitializer.InitializationMode) - Method in class io.confluent.databalancer.operation.StateMachineInitializer.Builder
buildAllowList() - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry.MetricsAllowListBuilder
 
Builder(KafkaConfig, Time, String, LogContext) - Constructor for class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient.Builder
 
Builder(BrokerRemovalStateMachine.BrokerRemovalEvent, BrokerRemovalStateMachine.BrokerRemovalEvent, Function<Set<Integer>, String>) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseExecutor.Builder
 
Builder(BrokerRemovalStateMachine.BrokerRemovalEvent, BrokerRemovalStateMachine.BrokerRemovalEvent, Function<Set<Integer>, String>, Class<? extends Exception>) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseExecutor.Builder
 
Builder() - Constructor for class io.confluent.databalancer.operation.StateMachineInitializer.Builder
 
BYTES_IN_MB - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
bytesIn() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
bytesOut() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 

C

CACHED_VALUES - Static variable in enum com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState.SubState
 
cachedBrokerDefValues() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
cachedBrokerLoadStats(boolean) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cached load.
cachedCommonDefValues() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
cachedJSONResponse() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
cachedPlaintextResponse() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionAcceptance
 
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionType
 
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.common.Resource
Use this instead of values() because values() creates a new array each time.
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
Use this instead of values() because values() creates a new array each time.
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.detector.AnomalyState.Status
Use this instead of values() because values() creates a new array each time.
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyType
Use this instead of values() because values() creates a new array each time.
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.State
 
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.TaskType
 
cachedValues() - Static method in enum com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState.SubState
Use this instead of values() because values() creates a new array each time.
CALCULATED_THROTTLE_RATIO_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
calculated.throttle.ratio
canAssignReplicaToBroker(Broker) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Check if the broker is eligible to host the replica of the partition.
cancel() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalFuture
Attempt to cancel the broker removal operation future.
cancel(Exception, BrokerRemovalCancellationMode) - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
Cancels the broker removal state tracking by setting a terminal canceled state
cancelBrokerRemoval(int) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
Cancels the on-going broker removal operations for the given #brokerIds
cancelBrokerRemoval(int) - Method in interface io.confluent.databalancer.DataBalanceEngine
Cancel the on-going broker removal operation for the given #brokerId
cancelBrokerRemoval(int) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
cancelInterBrokerReplicaMovements(List<TopicPartition>) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Cancels any partition reassignments for the given topic partitions
canChangeReplicationFactor() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
True if this goal can change replication factor of a topic
canChangeReplicationFactor() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
CandidateBroker - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A helper class for goals to keep track of the candidate brokers, its sorted replicas with respect to the given resource, and if they are excluded -- e.g.
CandidateBroker(Broker, Resource, SortedSet<Replica>, boolean, Set<Integer>, Set<Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
canTransferToState(ExecutionTask.State) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Check if the state transfer is possible.
capacity() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
CAPACITY_CONFIG_FILE - Static variable in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
capacityEstimationInfoByBrokerId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
capacityEstimationInfoByBrokerId() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
capacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get broker capacity for the requested resource.
capacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get cluster capacity for the requested resource.
capacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Host
Get host capacity for the requested resource.
capacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get rack capacity for the requested resource.
capacityForBroker(String, String, int) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
capacityForBroker(String, String, int) - Method in interface com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigResolver
Get the capacity of a broker based on rack, host and broker id.
capacityForBroker(String, String, int) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
CapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
HARD GOAL: Generate leadership and replica movement proposals to push the load on brokers and/or hosts under the capacity limit.
CapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Constructor for Capacity Goal.
capacityThreshold(Resource) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the capacity threshold for the requested resource.
chain(ReplicaMovementStrategy) - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.AbstractReplicaMovementStrategy
 
chain(ReplicaMovementStrategy) - Method in interface com.linkedin.kafka.cruisecontrol.executor.strategy.ReplicaMovementStrategy
Chain with another replica movement strategy to create a composite strategy.The returned strategy should use a combined rule of two strategies in determining the task execution order.
check(long) - Static method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
checkIfMetricReporterTopicExist(String, Consumer<byte[], byte[]>) - Static method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
checkStartupCondition(KafkaCruiseControlConfig, Semaphore) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
Make sure any condition needed to start this CruiseControlComponent is satisfied.
checkStartupCondition(KafkaCruiseControlConfig, Semaphore) - Static method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
Make sure any condition needed to start this CruiseControlComponent is satisfied.
checkStartupCondition(KafkaCruiseControlConfig, Semaphore) - Static method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
Make sure any condition needed to start this CruiseControlComponent is satisfied.
checkTopicPropertiesMaybeCreate(SbkTopicUtils.SbkTopicConfig, Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils
Checks for existence of a topic and creates it if its not already present.
cleanupPolicy - Variable in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
clear() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Clear all the values in this AggregatedMetricValues.
clear() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Clear the MetricSampleAggregator.
clear() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Clear the entire MetricValues.
clear() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
Clear the progress.
clear() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
clear() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Clear all the states.
clear() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Clear the replica action and leader action tasks.
clear() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Clear the content and structure of the cluster.
clear() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Clear the leader to null and clear followers.
clear() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
 
clearLoad() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Clear the content of monitoring data at each replica in the cluster.
clearLongLivedMetric(Class<?>, String) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
clearShortLivedMetrics() - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
CLIENT_ID_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
client.id
close(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
Close this metric sample.
close() - Method in interface com.linkedin.kafka.cruisecontrol.client.BlockingSend
 
close() - Method in class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient
 
close() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Close the admin client.
close() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
close() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
close() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor.ReservationHandle
 
close() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
close() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor.AutoCloseableSemaphore
 
close() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
close() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampler
 
close() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
close() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.ReadOnlyKafkaSampleStore
 
close() - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore
Close the sample store.
close() - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
close() - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
closeAdminClientWithTimeout(Admin) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Close the given AdminClient with the default timeout of KafkaCruiseControlUtils.ADMIN_CLIENT_CLOSE_TIMEOUT_MS.
closeAdminClientWithTimeout(Admin, long) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
closeAndClearState() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
closeKafkaZkClientWithTimeout(KafkaZkClient) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Close the given KafkaZkClient with the default timeout of KafkaCruiseControlUtils.KAFKA_ZK_CLIENT_CLOSE_TIMEOUT_MS.
closeKafkaZkClientWithTimeout(KafkaZkClient, long) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
cluster() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Get the current cluster.
cluster() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
cluster() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndPlacements
 
CLUSTER_GENERATION_ACCEPTABLE_STALENESS_LAG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
CLUSTER_MODEL_STATS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
clusterAndGeneration() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Get the current cluster and generation
ClusterAndGeneration(MetadataClient.ClusterAndPlacements, int) - Constructor for class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
ClusterAndPlacements(Cluster, Map<String, TopicPlacement>) - Constructor for class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndPlacements
 
clusterGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
clusterId() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
The current cluster id.
ClusterModel - Class in com.linkedin.kafka.cruisecontrol.model
A class that holds the information of the cluster, including topology, liveness and load for racks, brokers and replicas.
ClusterModel(ModelGeneration, double) - Constructor for class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Constructor for the cluster class.
clusterModel(long, ModelCompletenessRequirements, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the most recent cluster load model before the given timestamp.
clusterModel(long, long, ModelCompletenessRequirements, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cluster load model for a time range.
clusterModel(long, long, ModelCompletenessRequirements, boolean, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cluster load model for a time range.
ClusterModel.NonExistentBrokerException - Exception in com.linkedin.kafka.cruisecontrol.model
Thrown when a broker is not found in the cluster model
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
 
clusterModelCompletenessRequirements() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Specify the load requirements for this goal.
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
clusterModelCompletenessRequirements() - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
Return the model completeness requirements for this goal.
clusterModelCompletenessRequirements() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
clusterModelGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the current cluster model generation.
clusterModelStats() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
ClusterModelStats - Class in com.linkedin.kafka.cruisecontrol.model
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
 
clusterModelStatsComparator() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Get an instance of Goal.ClusterModelStatsComparator for this goal.
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
clusterModelStatsComparator() - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
 
clusterModelStatsComparator() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
clusterModelStatsComparatorByGoalName() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
com.linkedin.cruisecontrol - package com.linkedin.cruisecontrol
 
com.linkedin.cruisecontrol.common - package com.linkedin.cruisecontrol.common
 
com.linkedin.cruisecontrol.common.config - package com.linkedin.cruisecontrol.common.config
 
com.linkedin.cruisecontrol.common.config.types - package com.linkedin.cruisecontrol.common.config.types
 
com.linkedin.cruisecontrol.common.utils - package com.linkedin.cruisecontrol.common.utils
 
com.linkedin.cruisecontrol.config - package com.linkedin.cruisecontrol.config
 
com.linkedin.cruisecontrol.detector - package com.linkedin.cruisecontrol.detector
 
com.linkedin.cruisecontrol.exception - package com.linkedin.cruisecontrol.exception
 
com.linkedin.cruisecontrol.metricdef - package com.linkedin.cruisecontrol.metricdef
 
com.linkedin.cruisecontrol.model - package com.linkedin.cruisecontrol.model
 
com.linkedin.cruisecontrol.monitor.sampling - package com.linkedin.cruisecontrol.monitor.sampling
 
com.linkedin.cruisecontrol.monitor.sampling.aggregator - package com.linkedin.cruisecontrol.monitor.sampling.aggregator
 
com.linkedin.kafka.cruisecontrol - package com.linkedin.kafka.cruisecontrol
 
com.linkedin.kafka.cruisecontrol.analyzer - package com.linkedin.kafka.cruisecontrol.analyzer
 
com.linkedin.kafka.cruisecontrol.analyzer.goals - package com.linkedin.kafka.cruisecontrol.analyzer.goals
 
com.linkedin.kafka.cruisecontrol.analyzer.goals.internals - package com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
 
com.linkedin.kafka.cruisecontrol.async.progress - package com.linkedin.kafka.cruisecontrol.async.progress
 
com.linkedin.kafka.cruisecontrol.client - package com.linkedin.kafka.cruisecontrol.client
 
com.linkedin.kafka.cruisecontrol.common - package com.linkedin.kafka.cruisecontrol.common
 
com.linkedin.kafka.cruisecontrol.config - package com.linkedin.kafka.cruisecontrol.config
 
com.linkedin.kafka.cruisecontrol.detector - package com.linkedin.kafka.cruisecontrol.detector
 
com.linkedin.kafka.cruisecontrol.detector.notifier - package com.linkedin.kafka.cruisecontrol.detector.notifier
 
com.linkedin.kafka.cruisecontrol.exception - package com.linkedin.kafka.cruisecontrol.exception
 
com.linkedin.kafka.cruisecontrol.executor - package com.linkedin.kafka.cruisecontrol.executor
 
com.linkedin.kafka.cruisecontrol.executor.strategy - package com.linkedin.kafka.cruisecontrol.executor.strategy
 
com.linkedin.kafka.cruisecontrol.metricsreporter.exception - package com.linkedin.kafka.cruisecontrol.metricsreporter.exception
 
com.linkedin.kafka.cruisecontrol.metricsreporter.metric - package com.linkedin.kafka.cruisecontrol.metricsreporter.metric
 
com.linkedin.kafka.cruisecontrol.model - package com.linkedin.kafka.cruisecontrol.model
 
com.linkedin.kafka.cruisecontrol.monitor - package com.linkedin.kafka.cruisecontrol.monitor
 
com.linkedin.kafka.cruisecontrol.monitor.metricdefinition - package com.linkedin.kafka.cruisecontrol.monitor.metricdefinition
 
com.linkedin.kafka.cruisecontrol.monitor.sampling - package com.linkedin.kafka.cruisecontrol.monitor.sampling
 
com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator - package com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator
 
com.linkedin.kafka.cruisecontrol.monitor.sampling.holder - package com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
 
com.linkedin.kafka.cruisecontrol.monitor.task - package com.linkedin.kafka.cruisecontrol.monitor.task
 
com.linkedin.kafka.cruisecontrol.operation - package com.linkedin.kafka.cruisecontrol.operation
 
com.linkedin.kafka.cruisecontrol.plan - package com.linkedin.kafka.cruisecontrol.plan
 
com.linkedin.kafka.cruisecontrol.server - package com.linkedin.kafka.cruisecontrol.server
 
com.linkedin.kafka.cruisecontrol.servlet.response - package com.linkedin.kafka.cruisecontrol.servlet.response
 
com.linkedin.kafka.cruisecontrol.servlet.response.stats - package com.linkedin.kafka.cruisecontrol.servlet.response.stats
 
combineLoadRequirementOptions(Collection<Goal>) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
 
commonMetricDef() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
commonMetricDefId(KafkaMetricDef) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
commonMetricDefInfo(KafkaMetricDef) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
compare(double, double, Resource) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Compare the given values.
compare(double, double, double) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Compare the given values.
compare(ClusterModelStats, ClusterModelStats) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal.ClusterModelStatsComparator
Compare two cluster model stats and determine which stats is preferred.
compareGeneration(Generationed<G>) - Method in interface com.linkedin.cruisecontrol.common.Generationed
Compare the generation of this object with the other object.
compareGeneration(G) - Method in interface com.linkedin.cruisecontrol.common.Generationed
Compare the generation of this object with the given generation.
compareGeneration(Generationed<Long>) - Method in class com.linkedin.cruisecontrol.common.LongGenerationed
Compare the generation of this object with the other object.
compareGeneration(Long) - Method in class com.linkedin.cruisecontrol.common.LongGenerationed
 
compareTo(CandidateBroker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
compareTo(ExecutionTask) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
compareTo(Broker) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Compare by broker id.
compareTo(Disk) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
compareTo(Replica) - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Compare by (1) offline / online status (2) partition id then (2) original broker id then (3) topic name.
compareTo(ReplicaWrapper) - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
completed(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Change the task state to completed.
completeness() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregationResult
Get the completeness summary of this aggregation result.
completeness(long, long, AggregationOptions<G, E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Get the MetricSampleCompleteness of the MetricSampleAggregator with the given AggregationOptions for a given period of time.
completeness(Cluster, long, long, ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Get the metric sample completeness for a given period.
completionPercentage() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.GeneratingClusterModel
 
completionPercentage() - Method in interface com.linkedin.kafka.cruisecontrol.async.progress.OperationStep
 
completionPercentage() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OptimizationForGoal
 
completionPercentage() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.Pending
 
completionPercentage() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.RetrievingMetrics
 
completionPercentage() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.WaitingForClusterModel
 
composeRemoval(BrokerRemovalOptions, BrokerRemovalCallback, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Future<?>>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseBuilder
Returns all the phases chained together in a #CompletableFuture object
compute() - Method in interface com.linkedin.kafka.cruisecontrol.plan.PlanComputable
Compute a reassignment plan
computeThrottle() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Computes a replication throttle based on the network capacity and the current network usage
Config - Class in com.linkedin.cruisecontrol.common.config
 
Config(List<ConfigValue>) - Constructor for class com.linkedin.cruisecontrol.common.config.Config
 
config() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
ConfigDef - Class in com.linkedin.cruisecontrol.common.config
This class is used for specifying the set of expected configurations.
ConfigDef() - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigDef
 
ConfigDef(ConfigDef) - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigDef
 
ConfigDef.ConfigKey - Class in com.linkedin.cruisecontrol.common.config
 
ConfigDef.Importance - Enum in com.linkedin.cruisecontrol.common.config
The importance level for a configuration
ConfigDef.NonEmptyString - Class in com.linkedin.cruisecontrol.common.config
 
ConfigDef.Range - Class in com.linkedin.cruisecontrol.common.config
Validation logic for numeric ranges
ConfigDef.Recommender - Interface in com.linkedin.cruisecontrol.common.config
This is used by the ConfigDef.validate(Map) to get valid values for a configuration given the current configuration values in order to perform full configuration validation and visibility modification.
ConfigDef.Type - Enum in com.linkedin.cruisecontrol.common.config
The config types
ConfigDef.Validator - Interface in com.linkedin.cruisecontrol.common.config
Validation logic the user may provide to perform single configuration validation.
ConfigDef.ValidList - Class in com.linkedin.cruisecontrol.common.config
 
ConfigDef.ValidString - Class in com.linkedin.cruisecontrol.common.config
 
ConfigDef.Width - Enum in com.linkedin.cruisecontrol.common.config
The width of a configuration value
ConfigException - Exception in com.linkedin.cruisecontrol.common.config
Thrown if the user supplies an invalid configuration
ConfigException(String) - Constructor for exception com.linkedin.cruisecontrol.common.config.ConfigException
 
ConfigException(String, Object) - Constructor for exception com.linkedin.cruisecontrol.common.config.ConfigException
 
ConfigException(String, Object, String) - Constructor for exception com.linkedin.cruisecontrol.common.config.ConfigException
 
ConfigKey(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender, boolean) - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
configKeys() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Get the configuration keys
configure(Map<String, ?>) - Method in interface com.linkedin.cruisecontrol.common.CruiseControlConfigurable
Configure this class with the given key-value pairs
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNoopNotifier
 
configure(Map<String, ?>, boolean) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.DefaultMetricSamplerPartitionAssignor
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampler
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.ReadOnlyKafkaSampleStore
We have to override the configure method so that no producer is created and no ZK topic configuration change is made either.
configure(Map<String, ?>) - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
ConfigValue - Class in com.linkedin.cruisecontrol.common.config
 
ConfigValue(String) - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigValue
 
ConfigValue(String, Object, List<Object>, List<String>) - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigValue
 
configValues() - Method in class com.linkedin.cruisecontrol.common.config.Config
 
ConfluentDataBalanceEngine - Class in io.confluent.databalancer
A simple class for: - providing an API mapping from DataBalanceManager<->CruiseControl - managing synchronization and computation resources for CruiseControl and the methods exposed
ConfluentDataBalanceEngine(DataBalancerMetricsRegistry, KafkaConfig) - Constructor for class io.confluent.databalancer.ConfluentDataBalanceEngine
 
ConfluentDataBalanceEngineContext - Class in io.confluent.databalancer
An object that contains all information related to an active DataBalanceEngine.
ConfluentDataBalanceEngineContext(DataBalancerMetricsRegistry, KafkaCruiseControl, Time) - Constructor for class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
ConfluentMetricsReporterSampler - Class in io.confluent.cruisecontrol.metricsreporter
This class reads Kafka and Yammer metrics as byte arrays from the metrics topic, converts them to Cruise Control metrics, and submits them to the metrics processor
ConfluentMetricsReporterSampler() - Constructor for class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsReporterSampler
 
ConfluentMetricsSamplerBase - Class in io.confluent.cruisecontrol.metricsreporter
 
ConfluentMetricsSamplerBase() - Constructor for class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
ConfluentTelemetryReporterSampler - Class in io.confluent.cruisecontrol.metricsreporter
This class reads Confluent telemetry metrics as byte arrays from the metrics topic, converts them to Cruise Control metrics, and submits them to the metrics processor
ConfluentTelemetryReporterSampler() - Constructor for class io.confluent.cruisecontrol.metricsreporter.ConfluentTelemetryReporterSampler
 
ConnectionException - Exception in com.linkedin.kafka.cruisecontrol.client
Thrown when a connection could not be established
ConnectionException(String, Throwable) - Constructor for exception com.linkedin.kafka.cruisecontrol.client.ConnectionException
 
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
connections.max.idle.ms
CONSUMER_CLIENT_ID - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
CONSUMER_GROUP - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
containsAny(Set<Integer>, Set<Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Check if set a contains any element in set b.
containsRack(Rack) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Returns a boolean indicating if replica of this partition are on rack passed in as argument.
controller() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
The current controller id.
convertBrokerAdditionStatus(PartitionReassignmentsStatus) - Static method in class io.confluent.databalancer.operation.BrokerAdditionStateMachine
Converts the specific sub-task status of a broker addition operation to a #BalancerOperationStatus.
convertBrokerRemovalStatus(BrokerShutdownStatus, PartitionReassignmentsStatus) - Static method in class io.confluent.databalancer.operation.BrokerRemovalStateMachine
Converts the specific status of a broker removal operation to a #BalancerOperationStatus.
convertMetricRecord(ConsumerRecord<byte[], byte[]>) - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsReporterSampler
 
convertMetricRecord(ConsumerRecord<byte[], byte[]>) - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
convertMetricRecord(ConsumerRecord<byte[], byte[]>) - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentTelemetryReporterSampler
 
convertToString(Object, ConfigDef.Type) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
CPU_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
cpu.balance.threshold
CPU_CAPACITY_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
cpu.capacity.threshold
CPU_LOW_UTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
cpu.low.utilization.threshold
CpuCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
CpuCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuCapacityGoal
Constructor for Cpu Capacity Goal.
CpuUsageDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
CpuUsageDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuUsageDistributionGoal
Constructor for Resource Distribution Goal.
createAdmin(Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Create an instance of ConfluentAdmin using the given configurations.
createBroker(String, String, int, BrokerCapacityInfo, boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Create a broker under this cluster/rack and get the created broker.
createConsumer(Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
createConsumerForMetricTopic(Properties, String) - Static method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
createKafkaZkClient(String, String, String, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Create an instance of KafkaZkClient with security disabled.
createKafkaZkClient(KafkaCruiseControlConfig, String, String, Option<ZKClientConfig>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
createKafkaZkClient(String, String, String, boolean, Option<ZKClientConfig>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
createOrDeleteReplicas(Map<Short, Set<String>>, Map<String, List<Integer>>, Map<Integer, String>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
For partitions of specified topics, create or delete replicas in given cluster model to change the partition's replication factor to target replication factor.
createProducer(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
createRack(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Create a rack under this cluster.
createReplica(String, int, TopicPartition, int, boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Create a replica under given cluster/rack/broker.
createReplica(String, int, TopicPartition, int, boolean, boolean, String, boolean, boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Create a replica under given cluster/rack/broker.
creationTimeMs() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
CrossRackMovementGoal - Class in io.confluent.cruisecontrol.analyzer.goals
 
CrossRackMovementGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.CrossRackMovementGoal
 
CruiseControlConfig - Class in com.linkedin.cruisecontrol.config
The configuration for Cruise Control.
CruiseControlConfig(ConfigDef, Map<?, ?>, boolean) - Constructor for class com.linkedin.cruisecontrol.config.CruiseControlConfig
 
CruiseControlConfig(ConfigDef, Map<?, ?>) - Constructor for class com.linkedin.cruisecontrol.config.CruiseControlConfig
 
CruiseControlConfig(Map<String, Object>) - Constructor for class com.linkedin.cruisecontrol.config.CruiseControlConfig
 
CruiseControlConfigurable - Interface in com.linkedin.cruisecontrol.common
A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters
CruiseControlException - Exception in com.linkedin.cruisecontrol.exception
 
CruiseControlException(String, Throwable) - Constructor for exception com.linkedin.cruisecontrol.exception.CruiseControlException
 
CruiseControlException(String) - Constructor for exception com.linkedin.cruisecontrol.exception.CruiseControlException
 
CruiseControlException(Throwable) - Constructor for exception com.linkedin.cruisecontrol.exception.CruiseControlException
 
CruiseControlMetric - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
An interface for all the raw metrics reported.
CruiseControlMetric(RawMetricType, long, int, double) - Constructor for class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
 
CruiseControlMetric.MetricClassId - Enum in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
An enum that list all the implementations of the interface.
CruiseControlMetricsProcessor - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
Process the raw metrics collected by ConfluentTelemetryReporterSampler from the Kafka cluster.
CruiseControlMetricsProcessor(BrokerCapacityConfigResolver, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
 
CruiseControlMetricsReporterException - Exception in com.linkedin.kafka.cruisecontrol.metricsreporter.exception
 
CruiseControlMetricsReporterException(String, Throwable) - Constructor for exception com.linkedin.kafka.cruisecontrol.metricsreporter.exception.CruiseControlMetricsReporterException
 
CruiseControlMetricsReporterException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.metricsreporter.exception.CruiseControlMetricsReporterException
 
CruiseControlMetricsReporterException(Throwable) - Constructor for exception com.linkedin.kafka.cruisecontrol.metricsreporter.exception.CruiseControlMetricsReporterException
 
CruiseControlStartable - Class in io.confluent.databalancer.startup
An abstraction above the necessary logic to create a #KafkaCruiseControl instance, like checking its necessary components can have their start up conditions met and translating the #KafkaConfig into #KafkaCruiseControlConfig
CruiseControlStartable(Time, DataBalancerMetricsRegistry) - Constructor for class io.confluent.databalancer.startup.CruiseControlStartable
 
CruiseControlState - Class in com.linkedin.kafka.cruisecontrol.servlet.response
 
CruiseControlState(ExecutorState, LoadMonitorState, AnalyzerState, AnomalyDetectorState, KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
CruiseControlState.SubState - Enum in com.linkedin.kafka.cruisecontrol.servlet.response
 
CruiseControlUtils - Class in com.linkedin.cruisecontrol
Utils class for Cruise Control
currentBrokerMetricValues() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the latest metric values of the brokers.
currentOfflineReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get current offline replicas -- i.e.
currentPartitionMetricValues() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the latest metric values of the partitions.
currentState() - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
Returns the current state of the broker addition operation.
currentState() - Method in interface io.confluent.databalancer.operation.BalancerOperationCallback
 
currentState() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
currentState() - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
currentState - Variable in class io.confluent.databalancer.operation.StateMachine
 
currentUtcDate() - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
currentWindowIndex() - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 

D

DataBalanceEngine - Interface in io.confluent.databalancer
Interface to expose CruiseControl operations to users of that functionality (the KafkaDataBalanceManager).
DataBalanceEngineContext - Interface in io.confluent.databalancer
 
DataBalancerMetricsRegistry - Class in io.confluent.databalancer.metrics
DataBalancerMetricsRegistry tracks and manages the object lifetime of various DataBalancer short-lived metrics, i.e.: metrics that should only be alive as long as some other object is active.
DataBalancerMetricsRegistry(MetricsRegistry, Set<MetricName>) - Constructor for class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
DataBalancerMetricsRegistry.MetricsAllowListBuilder - Class in io.confluent.databalancer.metrics
 
dataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
DATE_FORMAT - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
DATE_FORMAT2 - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
deadBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the dead brokers in the cluster.
deadBrokersWithReplicas(int) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get all the dead brokers in the cluster based on the replica assignment.
DEFAULT_ANOMALY_DETECTION_GOALS_LIST - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_ANOMALY_DETECTION_INTERVAL_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
default.api.timeout.ms
DEFAULT_API_TIMEOUT_MS_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BROKER_CAPACITY_CONFIG_RESOLVER_OBJECT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
 
DEFAULT_BROKER_FAILURE_ALERT_THRESHOLD_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BROKER_FAILURE_SELF_HEALING_THRESHOLD_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BROKER_METRICS_WINDOW_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BROKER_REMOVAL_SHUTDOWN_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BROKER_SAMPLE_STORE_TOPIC_PARTITION_COUNT - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
DEFAULT_CAPACITY_BROKER_ID - Static variable in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
DEFAULT_CAPACITY_BROKER_ID - Static variable in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
DEFAULT_CPU_CAPACITY_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_CPU_CAPACITY_WITH_CORES - Static variable in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
DEFAULT_CPU_LOW_UTILIZATION_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_DESCRIBE_CLUSTER_RESPONSE_TIMEOUT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_DESCRIBE_TOPICS_RESPONSE_TIMEOUT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_DISK_CAPACITY_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_DISK_LOW_UTILIZATION_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_GOAL_VIOLATION_DISTRIBUTION_THRESHOLD_MULTIPLIER - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_GOALS_LIST - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_METADATA_MAX_AGE_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_METADATA_TTL - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_METRIC_SAMPLING_INTERVAL_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_MIN_BROKER_SAMPLE_STORE_TOPIC_RETENTION_TIME_MS - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
DEFAULT_MIN_PARTITION_SAMPLE_STORE_TOPIC_RETENTION_TIME_MS - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
DEFAULT_MIN_SAMPLES_PER_BROKER_METRICS_WINDOW - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_MIN_SAMPLES_PER_PARTITION_METRICS_WINDOW - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_MIN_VALID_PARTITION_RATIO - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NETWORK_INBOUND_CAPACITY_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NETWORK_INBOUND_LOW_UTILIZATION_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NETWORK_OUTBOUND_CAPACITY_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NETWORK_OUTBOUND_LOW_UTILIZATION_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NUM_BROKER_METRICS_WINDOWS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NUM_CPU_CORES - Static variable in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
DEFAULT_NUM_PARTITION_METRICS_WINDOWS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_NUM_SAMPLE_LOADING_THREADS - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
DEFAULT_PARTITION_METRICS_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_PARTITION_SAMPLE_STORE_TOPIC_PARTITION_COUNT - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
DEFAULT_READ_THROUGHPUT_MULTIPLIER - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_REPLICA_MOVEMENT_STRATEGIES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
default.replica.movement.strategies
DEFAULT_SKIP_SAMPLE_STORE_TOPIC_RACK_AWARENESS_CHECK - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
DEFAULT_SLACK_SELF_HEALING_NOTIFIER_ICON - Static variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
DEFAULT_SLACK_SELF_HEALING_NOTIFIER_USER - Static variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
DEFAULT_WRITE_THROUGHPUT_MULTIPLIER - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
defaultMetricSamplerGroupId() - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsReporterSampler
 
defaultMetricSamplerGroupId() - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
defaultMetricSamplerGroupId() - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentTelemetryReporterSampler
 
DefaultMetricSamplerPartitionAssignor - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
The default implementation of metric sampler partition assignor.
DefaultMetricSamplerPartitionAssignor() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.DefaultMetricSamplerPartitionAssignor
 
defaultModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizer
 
defaultStartState() - Method in class io.confluent.databalancer.operation.StateMachineInitializer
Return the state at which the #StateMachine should start at
define(ConfigDef.ConfigKey) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no dependents
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no special validation logic, not dependents and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic, no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no group, no order in group, no width, no display name, no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, String, String) - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
Define the metric.
define(String, String, String, boolean) - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
Define the metric.
defineInternal(String, ConfigDef.Type, Object, ConfigDef.Importance) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Define a new internal configuration.
defScope() - Method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
delay() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
deleteReplica(TopicPartition, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Delete a replica from cluster.
demotedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the demoted brokers in the cluster.
DEMOTION_HISTORY_RETENTION_TIME_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
demotion.history.retention.time.ms
deprioritizeDiskImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
This priority function can be used together with SortedReplicas.reverselySortedReplicas() to provide sorted replicas in descending order of score and prioritize the immigrant replicas for the disk.
deprioritizeImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
This priority function can be used together with SortedReplicas.reverselySortedReplicas() to provide sorted replicas in descending order of score and prioritize the immigrant replicas.
deprioritizeOfflineReplicas() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
This priority function can be used together with SortedReplicas.reverselySortedReplicas() to provide sorted replicas in descending order of score and prioritize the offline replicas.
deprioritizeOfflineReplicasThenImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
This priority function can be used together with SortedReplicas.reverselySortedReplicas() to provide sorted replicas in descending order of score and prioritize the offline replicas then immigrants.
derivedFrom() - Method in enum com.linkedin.kafka.cruisecontrol.model.RawAndDerivedResource
 
DESCRIBE_CLUSTER_RESPONSE_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
describe.cluster.response.timeout.ms
DESCRIBE_TOPICS_RESPONSE_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
describe.topics.response.timeout.ms
describeCluster() - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Describes the Kafka cluster, listing all the online brokers.
describeCluster(long) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Describes the Kafka cluster, listing all the online brokers.
description() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.GeneratingClusterModel
 
description() - Method in interface com.linkedin.kafka.cruisecontrol.async.progress.OperationStep
 
description() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OptimizationForGoal
 
description() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.Pending
 
description() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.RetrievingMetrics
 
description() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.WaitingForClusterModel
 
deserializationVersion() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
deserialize(String, byte[]) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
deserialize(RemoveBroker.RemovalState) - Static method in class io.confluent.databalancer.persistence.BrokerRemovalStateSerializer
 
destinationBrokerId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the destination broker Id.
destinationBrokerLogdir() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the destination broker logdir.
destinationTopic() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get topic name of the replica to swap with at the destination.
destinationTopicPartition() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the destination topic partition to swap with.
detailTrainingProgress() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
detectionMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
DISABLED_THROTTLE - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
discardIrrelevantAndCacheJsonAndPlaintext() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
Keeps the JSON and plaintext response and discards the optimizer result.
discardIrrelevantAndCacheRelevant() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
discardIrrelevantAndCacheRelevant() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
disk(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get disk information that corresponds to the logdir.
Disk - Class in com.linkedin.kafka.cruisecontrol.model
A class that holds the disk information of a broker, including its liveness, capacity and load.
disk() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get disk that the replica resides in.
Disk.State - Enum in com.linkedin.kafka.cruisecontrol.model
 
DISK_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
disk.balance.threshold
DISK_CAPACITY_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Disk capacity: disk.max.load
DISK_LOW_UTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
disk.low.utilization.threshold
DISK_READ_RATIO_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
disk.read.ratio
DISK_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
diskCapacityByLogDir() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
DiskCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
DiskCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskCapacityGoal
Constructor for Disk Capacity Goal.
disks() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get all the disks of the broker.
diskStats() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get per-logdir disk statistics of the broker.
diskStats() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
DiskStats - Class in com.linkedin.kafka.cruisecontrol.model
A helper class to store statistics about the Disk.
diskStatsByLogdir() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
Get per-logdir disk statistics of the broker.
diskUsage() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
DiskUsageDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
DiskUsageDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
Constructor for Resource Distribution Goal.
diskUtilizationPercentage(Disk) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Get the latest utilization percentage of the disk, or GoalUtils.DEAD_DISK_UTILIZATION if the disk is dead.
diskUtilizationStandardDeviation() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get the standard deviation of disk utilization of this cluster model;
done() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OptimizationForGoal
 
done() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.Pending
 
done() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.RetrievingMetrics
Mark the step as finished.
done() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.WaitingForClusterModel
 
doneDefinition() - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
Finish the metric definition and make the MetricDef immutable.
doubleArray() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
 
doWork() - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailureDetector
This function is called continuously in a loop, till the failure detector thread is shutdown.
dropRecentlyRemovedBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Drop the given brokers from the recently removed brokers.

E

earliestWindow() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
embed(String, String, int, ConfigDef) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
EMPTY_SAMPLES - Static variable in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler
 
endedBy() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
endMs() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
endTime() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
EngineInitializationContext - Class in io.confluent.databalancer
 
EngineInitializationContext(KafkaConfig, Map<Integer, Long>, Function<Integer, AtomicReference<String>>, Function<Integer, AtomicReference<String>>) - Constructor for class io.confluent.databalancer.EngineInitializationContext
 
ensureNoOfflineReplicas(ClusterModel, String) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Checks the replicas that are supposed to be moved away from the dead brokers or broken disks have been moved.
ensureNoPartitionUnderPartitionReassignment(KafkaZkClient) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
Check whether there are ongoing partition reassignments and wait for the reassignments to finish.
ensureReplicasMoveOffBrokersWithBadDisks(ClusterModel, String) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Checks for the broker with broken disk, the partitions of the replicas used to be on its broken disk does not have any replica on this broker.
ensureValid(String, Object) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.NonEmptyString
 
ensureValid(String, Object) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.Range
 
ensureValid(String, Object) - Method in interface com.linkedin.cruisecontrol.common.config.ConfigDef.Validator
Perform single configuration validation.
ensureValid(String, Object) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ValidList
 
ensureValid(String, Object) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ValidString
 
ensureValidString(String, String) - Static method in class com.linkedin.cruisecontrol.CruiseControlUtils
Ensure the string value of the string key is not null or empty.
Entity<G> - Class in com.linkedin.cruisecontrol.model
The abstract class for an entity.
Entity() - Constructor for class com.linkedin.cruisecontrol.model.Entity
 
entity() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
Get the entity this metric sample is corresponding to.
EPSILON - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
epsilon(double, double) - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
equals(Object) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
equals(Object) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
equals(Object) - Method in class com.linkedin.cruisecontrol.common.config.types.Password
 
equals(Object) - Method in class com.linkedin.cruisecontrol.model.Entity
The entity will be used as a key of a map.
equals(Object) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Compare the given object with this object.
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerAndSortedReplicas
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
equals(Object) - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
errorMessages() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
estimateLeaderCpuUtil(double, double, double, double, double, double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
Estimate the leader CPU utilization for the partition with the given information as a double in [0.0,1.0].
estimateLeaderCpuUtilUsingLinearRegressionModel(double, double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
estimationInfo() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
evictSamplesBefore(long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
evictSamplesBefore(long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
evictSamplesBefore(long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.ReadOnlyKafkaSampleStore
 
evictSamplesBefore(long) - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore
This method is called when a workload snapshot window is evicted.
exception() - Method in class com.linkedin.kafka.cruisecontrol.common.AdminClientResult
The exception of the AdminClient-backed call.
exception - Variable in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations.GoalResult
nullable, an exception that caused the goal violation to not be fixable
exception() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
exception() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
exception() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
excludedBrokersForLeadership() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
excludedBrokersForLeadership() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
excludedBrokersForReplicaMove() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
excludedBrokersForReplicaMove() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
excludedTopics() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
excludedTopics() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
execute(Duration) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalFuture
Executes the broker removal
execute(BrokerRemovalOptions) - Method in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhase
Execute the broker removal phase
execute(BrokerRemovalPhase<T>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseExecutor
Executes the given #BrokerRemovalPhase, notifies the progress callback and completes the future.
execute(BrokerRemovalOptions) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase
 
executeIntraBrokerReplicaMovements(List<ExecutionTask>, ExecutionTaskManager) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Execute intra-broker replica movement tasks by sending alterReplicaLogDirs request.
executeProposals(Collection<ExecutionProposal>, Set<Integer>, Set<Integer>, LoadMonitor, Integer, Integer, Integer, ReplicaMovementStrategy, String, BalanceOpExecutionCompletionCallback) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Initialize proposal execution and start execution.
EXECUTION_PROGRESS_CHECK_INTERVAL_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
execution.progress.check.interval.ms
executionId() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
ExecutionProposal - Class in com.linkedin.kafka.cruisecontrol.executor
The execution proposal corresponding to a particular partition.
ExecutionProposal(TopicPartition, long, ReplicaPlacementInfo, List<ReplicaPlacementInfo>, List<ReplicaPlacementInfo>, List<ReplicaPlacementInfo>, List<ReplicaPlacementInfo>) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
Construct an execution proposals.
executionStarted(String, Set<Integer>, Set<Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
executionState() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
executionSucceeded() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
ExecutionTask - Class in com.linkedin.kafka.cruisecontrol.executor
A class that wraps the execution information of a balancing proposal The task state machine is the following:
ExecutionTask(long, ExecutionProposal, Integer, ExecutionTask.TaskType) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Construct an execution task.
ExecutionTask(long, ExecutionProposal, ExecutionTask.TaskType) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
ExecutionTask.State - Enum in com.linkedin.kafka.cruisecontrol.executor
 
ExecutionTask.TaskType - Enum in com.linkedin.kafka.cruisecontrol.executor
 
ExecutionTaskManager - Class in com.linkedin.kafka.cruisecontrol.executor
The class that helps track the execution status for the balancing.
ExecutionTaskManager(int, int, int, List<String>, ConfluentAdmin, DataBalancerMetricsRegistry, Time, KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
The constructor of The Execution task manager.
ExecutionTaskPlanner - Class in com.linkedin.kafka.cruisecontrol.executor
The class holds the execution of balance proposals for rebalance.
ExecutionTaskPlanner(ConfluentAdmin, List<String>, KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
 
executionTasksSummary() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
ExecutionTaskTracker - Class in com.linkedin.kafka.cruisecontrol.executor
A class for tracking the (1) dead tasks, (2) aborting/aborted tasks, (3) in progress tasks, and (4) pending tasks.
ExecutionTaskTracker.ExecutionTasksSummary - Class in com.linkedin.kafka.cruisecontrol.executor
 
Executor - Class in com.linkedin.kafka.cruisecontrol.executor
Executor for Kafka GoalOptimizer.
Executor(KafkaCruiseControlConfig, Option<ZKClientConfig>, Time, DataBalancerMetricsRegistry, long, long, AnomalyDetector) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.Executor
The executor class that execute the proposals generated by optimizer.
Executor.ReservationHandle - Class in com.linkedin.kafka.cruisecontrol.executor
A helper auto closeable class for acquiring the Executor's reservation.
EXECUTOR_NOTIFIER_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
EXECUTOR_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
executorIsReserved() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
ExecutorNoopNotifier - Class in com.linkedin.kafka.cruisecontrol.executor
A no-op notifier for executor.
ExecutorNoopNotifier() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorNoopNotifier
 
ExecutorNotification - Class in com.linkedin.kafka.cruisecontrol.executor
A class to encapsulate notification information sent to requester associated with an execution.
ExecutorNotification(long, long, String, boolean, boolean, Throwable, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
ExecutorNotification.ActionAgent - Enum in com.linkedin.kafka.cruisecontrol.executor
 
ExecutorNotifier - Interface in com.linkedin.kafka.cruisecontrol.executor
For sending notification about executor completion status.
ExecutorState - Class in com.linkedin.kafka.cruisecontrol.executor
 
executorState() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
ExecutorState.State - Enum in com.linkedin.kafka.cruisecontrol.executor
 
expectedUtilizationFor(Resource, boolean, boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get a single snapshot value that is representative for the given resource.
expectedUtilizationFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Load
 
expectedUtilizationFor(KafkaMetricDef, boolean, boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get a single snapshot value that is representative for the given KafkaMetric type.
expectedUtilizationFor(Resource, AggregatedMetricValues, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.model.Load
Get a single snapshot value that is representative for the given resource.
explainLastComparison() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal.ClusterModelStatsComparator
This is a method to get the reason for the last comparison.
extrapolatedEntitiesByWindowIndex() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
Get the number of extrapolated entities.
Extrapolation - Enum in com.linkedin.cruisecontrol.monitor.sampling.aggregator
There are a few extrapolations we will do when there is not sufficient samples in a window for an entity.
extrapolation() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.SampleExtrapolation
 
extrapolations() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.ValuesAndExtrapolations
Get the extrapolations for the values.

F

failedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
Get the failed broker list and their failure time in millisecond.
fetchPartitionMetricSamples(long, long, long, SampleStore) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
Fetch the partition metric samples for a given period.
filterAdminClientConfigs(Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
filterConsumerConfigs(Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
filteredTasksByState() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
filterProducerConfigs(Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
filterReplicas(Broker, boolean, boolean, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Get a filtered set of replicas from the given broker based on given filtering requirements.
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
 
finish() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Signal for finishing the process for rebalance or self-healing for this goal.
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
finish() - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
Signal for finishing the process for rebalance or self-healing for this goal.
finish() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
finishedInterBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
finishedInterBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
finishedInterBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
finishedIntraBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
finishedIntraBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
finishedIntraBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
firstArrayIndex() - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
Get the first array index in the circular array.
firstWindowIndex() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
fix() - Method in interface com.linkedin.cruisecontrol.detector.Anomaly
Fix the anomaly with the system.
fix() - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
 
fix() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations
 
fix() - Static method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
FIXED - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
FOLLOWER_NETWORK_INBOUND_WEIGHT_FOR_CPU_UTIL_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
follower.network.inbound.weight.for.cpu.util
followerBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that followers reside in.
followers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get follower replicas.
forceRefreshClusterAndGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
forceRefreshMetadata() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Force-refresh metadata, paying no attention to how recently it has been refreshed.
forId(byte) - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
forRawMetricType(RawMetricType) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
fromBytes(byte[]) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
fromBytes(byte[]) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
Deserialize the bytes to get a broker metric data.
fromBytes(byte[]) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionMetricSample
 

G

generateClientConfigs(KafkaConfig) - Static method in class io.confluent.databalancer.startup.CruiseControlStartable
 
generatePlanWithRetries(PlanComputable, String) - Method in class com.linkedin.kafka.cruisecontrol.plan.PlanComputationUtils
Computes a reassignments plan, retrying in the case of insufficient metrics in the hopes of eventually collecting them
GeneratingClusterModel - Class in com.linkedin.kafka.cruisecontrol.async.progress
A step indicating that the cluster model generation is in progress.
GeneratingClusterModel(int) - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.GeneratingClusterModel
 
generation() - Method in interface com.linkedin.cruisecontrol.common.Generationed
Get the current generation.
generation() - Method in class com.linkedin.cruisecontrol.common.LongGenerationed
 
generation() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
generation() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
get the metadata generation for this cluster model.
Generationed<G> - Interface in com.linkedin.cruisecontrol.common
An interface that helps maintain and compare the generation.
get(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
get(int) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Get value at the given index.
getAllBrokerAddStatus() - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
getAllBrokerRemovalStateRecords() - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
getBoolean(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getBrokerAdditionsStateManagers() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
Return the #BrokerAdditionStateManagers for the active broker addition operations
getBrokerAdditionsStateManagers() - Method in interface io.confluent.databalancer.DataBalanceEngineContext
Return the #BrokerAdditionStateManagers for the active broker addition operations
getBrokerAddStatus(int) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
getBrokerId(KafkaConfig) - Static method in class io.confluent.databalancer.KafkaDataBalanceManager
 
getBrokerRemovalsStateTrackers() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
Return the #BrokerRemovalStateTracker for the active broker removal operations
getBrokerRemovalsStateTrackers() - Method in interface io.confluent.databalancer.DataBalanceEngineContext
Return the #BrokerRemovalStateTracker for the active broker removal operations
getBrokerRemovalStateRecord(int) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
getCaseInsensitiveGoalsByName(KafkaCruiseControlConfig) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Get a goal map with goal name as the keys.
getChannel() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
getClass(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getClusterStats(BalancingConstraint) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Populate the analysis stats with this cluster and given balancing constraint.
getCoefficient(LinearRegressionModelParameters.ModelCoefficient) - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
 
getCoefficient(LinearRegressionModelParameters.ModelCoefficient) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
getConfiguredInstance(String, Class<T>) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Get a configured instance of the give class specified by the given configuration key.
getConfiguredInstance(String, Class<T>) - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
getConfiguredInstance(String, Class<T>, Map<String, Object>) - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
getConfiguredInstances(String, Class<T>) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfiguredInstances(String, Class<T>, Map<String, Object>) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfiguredInstances(String, Class<T>) - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
getConfiguredInstances(String, Class<T>, Map<String, Object>) - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
getConfigValue(ConfigDef.ConfigKey, String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
getContextOrCruiseControlClassLoader() - Static method in class com.linkedin.cruisecontrol.common.utils.Utils
Get the Context ClassLoader on this thread or, if not present, the ClassLoader that loaded Kafka.
getCpuMetric(long, int) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Returns the "recent CPU usage" for the JVM process as a double in [0.0,1.0].
getCruiseControl() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
getCruiseControlClassLoader() - Static method in class com.linkedin.cruisecontrol.common.utils.Utils
Get the ClassLoader which loaded Kafka.
getDataBalanceEngineContext() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
getDataBalanceEngineContext() - Method in interface io.confluent.databalancer.DataBalanceEngine
Return DataBalanceEngineContext associated with this DataBalanceEngine.
getDataBalanceEngineContext() - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
getDataBalancerMetricsRegistry() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
getDiff(Map<TopicPartition, List<ReplicaPlacementInfo>>, Map<TopicPartition, ReplicaPlacementInfo>, Map<TopicPartition, List<ReplicaPlacementInfo>>, ClusterModel) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Get the diff represented by the set of balancing proposals to move from initial to final distribution.
getDiff(Map<TopicPartition, List<ReplicaPlacementInfo>>, Map<TopicPartition, ReplicaPlacementInfo>, Map<TopicPartition, List<ReplicaPlacementInfo>>, ClusterModel, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Get the diff represented by the set of balancing proposals to move from initial to final distribution.
getDouble(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getExecutionTasksSummary(Set<ExecutionTask.TaskType>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
getExecutionTasksSummary(Set<ExecutionTask.TaskType>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
getFollowerCpuUtilFromLeaderLoad(double, double, double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
getFollowerLoadFromLeader() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get the expected load if this replica becomes a follower replica.
getGoalsByPriority(KafkaCruiseControlConfig) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Get the list of goals sorted by highest to lowest default priority.
getIconEmoji() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
getInt(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getInterBrokerReplicaMovementTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns a list of execution tasks that move the replicas cross brokers.
getInterBrokerReplicaMovementTasks(Map<Integer, Integer>, Set<TopicPartition>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Get a list of executable inter-broker replica movements that comply with the concurrency constraint.
getIntraBrokerReplicaMovementTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns a list of execution tasks that move the replicas cross disks of the same broker.
getIntraBrokerReplicaMovementTasks(Map<Integer, Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Get a list of executable intra-broker replica movements that comply with the concurrency constraint.
getJsonArray() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
getJSONString() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
 
getJSONString(boolean) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
getJsonStructure(boolean) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Return an object that can be further used to encode into JSON
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorState
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
Return an object that can be further used to encode into JSON
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Return an object that can be further used to encode into JSON
getJsonStructure(boolean) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
Return an object that can be further used to encode into JSON
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
 
getJSONStructure() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Return an object that can be further used to encode into JSON
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
 
getJsonStructure(boolean) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
getJsonStructure(boolean) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
Return an object that can be further be used to encode into JSON
getJSONStructure() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
getJsonStructureForLoad() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
 
getLeaderDistribution() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get leader broker ids for each partition.
getLeadershipMovementTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns a list of execution tasks that move the leadership.
getLeadershipMovementTasks(int) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Get the leadership movement tasks, and remove them from _remainingLeadershipMovements.
getList(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getLogdirInfoForExecutionTask(Collection<ExecutionTask>) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Fetch the logdir information for subject replicas in intra-broker replica movement tasks.
getLong(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getMetricConsumerProperties(Map<String, ?>) - Static method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
getMetricReporterTopic(Map<String, ?>) - Static method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
getObserverDistribution() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the distribution of observer replicas in the cluster.
getPartitionsByTopic() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get a map of partitions by topic names.
getPassword(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getPersistenceStore() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
getPersistenceStore() - Method in interface io.confluent.databalancer.DataBalanceEngineContext
Return persistence store associated with this DataBalanceEngineContext.
getPlaintext() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
getPlaintext() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
getPlaintext(boolean, String) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
getPlaintextPretext() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
getProposals(List<String>, ModelCompletenessRequirements, OperationProgress, boolean, boolean, boolean, boolean, Set<Integer>, boolean) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Optimize a cluster workload model.
getProposalSummary() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
getProposalSummaryForJson() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
getRackHandleNull(Node) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
 
getReplicaDistribution() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the distribution of replicas in the cluster at the point of call.
getReplicasForPartition(TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Returns the replicas for a given partition.
getRequiredConfig(Map<String, ?>, String) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Get a configuration and throw exception if the configuration was not provided.
getSamples(Cluster, Set<TopicPartition>, long, long, MetricSampler.SamplingMode, MetricDef, long) - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler
Get the metric sample of the given topic partition and replica from the Kafka cluster.
getSamples(Cluster, Set<TopicPartition>, long, long, MetricSampler.SamplingMode, MetricDef, long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampler
 
getSamples(Cluster, Set<TopicPartition>, long, long, MetricSampler.SamplingMode, MetricDef, long) - Method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
Get the metric sample of the given topic partition and replica from the Kafka cluster.
getShort(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getString(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getText() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
getTime() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
getTopicPlacement(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
getUsername() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
Goal - Interface in com.linkedin.kafka.cruisecontrol.analyzer.goals
This is the interface of the optimization goals used by Cruise Control.
GOAL - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
Goal.ClusterModelStatsComparator - Interface in com.linkedin.kafka.cruisecontrol.analyzer.goals
A comparator that compares two cluster model stats.
GOAL_BALANCEDNESS_PRIORITY_WEIGHT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.balancedness.priority.weight
GOAL_BALANCEDNESS_STRICTNESS_WEIGHT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.balancedness.strictness.weight
GOAL_SUMMARY - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
GOAL_VIOLATION_DISTRIBUTION_THRESHOLD_MULTIPLIER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.violation.distribution.threshold.multiplier
GOAL_VIOLATION_EXCLUDE_RECENTLY_DEMOTED_BROKERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.violation.exclude.recently.demoted.brokers
GOAL_VIOLATION_EXCLUDE_RECENTLY_REMOVED_BROKERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.violation.exclude.recently.removed.brokers
GoalOptimizer - Class in com.linkedin.kafka.cruisecontrol.analyzer
A class for optimizing goals in the given order of priority.
GoalOptimizer(KafkaCruiseControlConfig, LoadMonitor, DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizer
Constructor for Goal Optimizer takes the goals as input.
goalProposals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
GoalResult(String, Exception) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.GoalViolations.GoalResult
 
goalResultDescription(String) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goals
GoalUtils - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
A util class for goals.
GoalViolationDetector - Class in com.linkedin.kafka.cruisecontrol.detector
This class will be scheduled to run periodically to check if the given goals are violated or not.
GoalViolationDetector(KafkaCruiseControlConfig, LoadMonitor, Queue<Anomaly>, Time, KafkaCruiseControl, List<String>) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.GoalViolationDetector
 
goalViolationDistributionThresholdMultiplier() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get goal violation distribution threshold multiplier to be used in detection and fixing goal violations.
GoalViolations - Class in com.linkedin.kafka.cruisecontrol.detector
A class that holds all the goal violations.
GoalViolations(KafkaCruiseControl, boolean, boolean, boolean, List<String>, List<String>) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.GoalViolations
 
GoalViolations.GoalResult - Class in com.linkedin.kafka.cruisecontrol.detector
 
granularity() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
greaterThan(double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
Get a ReplicaWrapper for searching purpose on a collection.
greaterThanOrEqualsTo(double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
Get a ReplicaWrapper for searching purpose on a collection.
group() - Method in class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
group() - Method in class com.linkedin.cruisecontrol.model.Entity
Note that the group will be used as keys of maps.
group() - Method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
The metric group of the Kafka metric def.
group() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
group() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
groups() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Get the groups for the configuration

H

handleDeadBroker(String, int, BrokerCapacityInfo) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
If the rack or broker does not exist, create them with UNKNOWN host name.
hasBadDisks() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Check if the broker has bad disks (i.e.
hasDefault() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
hasException() - Method in class com.linkedin.kafka.cruisecontrol.common.AdminClientResult
 
hashCode() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
hashCode() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
hashCode() - Method in class com.linkedin.cruisecontrol.common.config.types.Password
 
hashCode() - Method in class com.linkedin.cruisecontrol.model.Entity
The entity will be used as a key of a map.
hashCode() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerAndSortedReplicas
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
hashCode() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
hasLeaderAction() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
hasOngoingExecution() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Whether there is an ongoing operation triggered by current Cruise Control deployment.
hasOngoingPartitionReassignments() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Whether there is any ongoing partition reassignment.
hasReplicaAction() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
hasSkippedExecution() - Method in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhase
 
hasSkippedExecution() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase
 
headers() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
HIDDEN - Static variable in class com.linkedin.cruisecontrol.common.config.types.Password
 
host() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
Host - Class in com.linkedin.kafka.cruisecontrol.model
 
host() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
HOST - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
HOST - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
host() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
HOSTS - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
hosts() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Return the hosts in this rack.
HOSTS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 

I

id() - Method in class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
id() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
id() - Method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
id() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get broker Id.
id() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the rack Id.
id() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
ignore(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
ignore() - Static method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
immigrantReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the immigrant replicas (The replicas that are moved here).
in(String...) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ValidList
 
in(String...) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ValidString
 
includeAllTopics() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
includeInvalidEntities() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
incrementPopulatedNumPartitions() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.GeneratingClusterModel
 
inExecutionInterBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
inExecutionInterBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
inExecutionInterBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
inExecutionIntraBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
inExecutionIntraBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
inExecutionIntraBrokerDataMovementInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
inExecutionTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
inExecutionTasks(Collection<ExecutionTask.TaskType>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
inExecutionTasks(Collection<ExecutionTask.TaskType>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
init(KafkaCruiseControlConfig) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
init(KafkaCruiseControlConfig) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
init(S) - Method in class io.confluent.databalancer.operation.StateMachineInitializer
Return the state at which the given #givenState should be initialized to.
init(KafkaConfig, Time, Map<String, Object>) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Initialize states that this goal requires -- e.g.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Sanity checks: Existing total load on cluster is less than the limiting capacity determined by the total capacity of alive cluster multiplied by the capacity threshold.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Sanity checks: For each alive broker in the cluster, the load for Resource.DISK less than the limiting capacity determined by the total capacity of alive disks multiplied by the capacity threshold.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Initialize the utilization thresholds.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Set the flag which indicates whether the self healing failed to relocate all offline replicas away from dead brokers or the corresponding dead disks in its initial attempt.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
This is a hard goal; hence, the proposals are not limited to dead broker replicas in case of self-healing.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
This is a hard goal; hence, the proposals are not limited to dead broker replicas in case of self-healing.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
Initiates replica distribution abstract goal.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
Initiates replica distribution goal.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
(1) Initialize the current resource to be balanced or self healed.
initGoalState(ClusterModel, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Initiates this goal.
initGoalState(ClusterModel, OptimizationOptions) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
Initialize states that this goal requires -- e.g.
initGoalState(ClusterModel, OptimizationOptions) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Sanity check: There must be at least enough brokers matching a particular constraint across both replicas and observers.
InitializationRule(S, S) - Constructor for class io.confluent.databalancer.operation.StateMachineInitializer.InitializationRule
 
initialize() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
Initialize the #BrokerAdditionStateManager by setting the current state and notify the listener if it's the initial addition state
initialize() - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
Initialize the RemovalStateTracker by setting the current state and notifying the listener of the initial state.
initiateClose() - Method in interface com.linkedin.kafka.cruisecontrol.client.BlockingSend
 
initiateClose() - Method in class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient
 
inProgress(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Mark task in progress.
INTER_BROKER_PARTITION_MOVEMENTS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
interBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
interBrokerPartitionMovementConcurrency() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
interestedEntities() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
interestedEntityGroups() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
INTRA_BROKER_GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
intra.broker.goals
INTRA_BROKER_PARTITION_MOVEMENTS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
intraBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
IntraBrokerDiskCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Class for achieving the following hard goal: HARD GOAL: Generate replica movement proposals between disks of the same broker to push the load on each disk of broker under the capacity limit.
IntraBrokerDiskCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Constructor for Capacity Goal.
IntraBrokerDiskUsageDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Class for achieving the following soft goal: SOFT GOAL: For each broker rebalance disk usage to push each disk's utilization percentage within range around the utilization percentage of the whole broker.
IntraBrokerDiskUsageDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Constructor for Resource Distribution Goal.
intraBrokerPartitionMovementConcurrency() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
INVALID_INDEX - Static variable in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
invalidEntities() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregationResult
Get the entities that are not valid.
inValidWindowRange(long) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
Check if a given window index is valid or not.
io.confluent.cruisecontrol.analyzer.goals - package io.confluent.cruisecontrol.analyzer.goals
 
io.confluent.cruisecontrol.metricsreporter - package io.confluent.cruisecontrol.metricsreporter
 
io.confluent.databalancer - package io.confluent.databalancer
 
io.confluent.databalancer.metrics - package io.confluent.databalancer.metrics
 
io.confluent.databalancer.operation - package io.confluent.databalancer.operation
 
io.confluent.databalancer.persistence - package io.confluent.databalancer.persistence
 
io.confluent.databalancer.startup - package io.confluent.databalancer.startup
 
IS_LEADER - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
isActive() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
Returns if CruiseControl is active and can work on balancing cluster.
isActive() - Method in interface io.confluent.databalancer.DataBalanceEngine
 
isActive() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
isActive() - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
isAlive() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Check broker liveness status.
isAlive() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
isAlive() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
isAtATerminalState() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
Returns a boolean indicating whether the current state is terminal.
isBrokerResource() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
isBrokerStatsEstimated() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
isCapacityEstimated() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
isClusterAlive() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Checks if cluster has at least one alive rack.
isCruiseControlInitialized() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
isCurrentOffline() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Check whether the replica is currently offline.
isDemoted() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Check if the broker is demoted from being a partition leader.
isEmpty() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Check if the AggregatedMetricValues contains value for any metrics.
isEstimated() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
isEstimated() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
isExtrapolatedAtWindowIndex(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Check if the window at the given window index is extrapolated.
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
 
isHardGoal() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
True if this is a hard goal, false otherwise.
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
isHardGoal() - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
True if this is a hard goal, false otherwise.
isHardGoal() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
isHostResource() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
isImmigrant() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Check whether the replica is an immigrant replica of the broker.
isInitialized() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
isInterBrokerMovementAborted(Node[], Node[]) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
Check whether the abortion of inter-broker replica movement from this proposal is reflected in the current ordered replicas in the given cluster.
isInterBrokerMovementCompleted(Node[], Node[]) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
Check whether the successful completion of inter-broker replica movement from this proposal is reflected in the current ordered replicas in the given cluster.
isInterested(MetricName) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Check if a kafkaMetric is an interested metric.
isInterested(YammerMetricWrapper) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Check if a yammer metric name is an interested metric
isLeader() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Check the leadership status of the broker.
isLoadMonitorReady(LoadMonitorTaskRunner.LoadMonitorTaskRunnerState) - Static method in class com.linkedin.kafka.cruisecontrol.detector.ViolationUtils
Check whether the load monitor state is ready -- i.e.
isNew() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Check if the broker is a new broker
isObserver() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Check whether the replica is an observer.
isOngoingIntraBrokerReplicaMovement(Collection<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Check whether there is ongoing intra-broker replica movement.
isOriginalOffline() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get the original state of the replica before rebalance.
isPartitionUnderReplicated(Cluster, TopicPartition) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Check if the partition is currently under replicated.
isProposalAcceptableForOptimizedGoals(Set<Goal>, BalancingAction, ClusterModel) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Check whether the given proposal is acceptable for all of the given optimized goals.
isRackAlive() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Checks if rack has at least one alive servers.
isReservedByOther() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Whether the Executor's is reserved (paused) by another thread.
isStale(ModelGeneration) - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
Check whether this model generation is stale.
isStateTerminal(BrokerAdditionStateMachine.BrokerAdditionState) - Static method in class io.confluent.databalancer.operation.BrokerAdditionStateMachine
 
isStateTerminal(BrokerRemovalStateMachine.BrokerRemovalState) - Static method in class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
isTerminalState(S) - Method in class io.confluent.databalancer.operation.StateMachine
 
isTriggeredByGoalViolation() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
isValid(int) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Check whether this raw metric value is valid or not.
isValid(MetricDef) - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
Validate the metric sample.
isValidAtWindowIndex(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Check if the window at the given window index is valid.
isValidLeader(PartitionMetricSample) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
 

J

join(Collection<T>, String) - Static method in class com.linkedin.cruisecontrol.common.utils.Utils
Create a string representation of a list joined by the given separator
JSON_VERSION - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 

K

KAFKA_ZK_CLIENT_CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
KafkaBrokerMetricSampleAggregator - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator
The metrics sample aggregator for brokers.
KafkaBrokerMetricSampleAggregator(KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaBrokerMetricSampleAggregator
Construct the metric sample aggregator.
KafkaCluster - Class in com.linkedin.kafka.cruisecontrol.common
The result of a #DescribeClusterResult
KafkaCluster(Collection<Node>, Node, String, Set<AclOperation>) - Constructor for class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
 
kafkaCluster() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cluster information from Kafka metadata.
KafkaCruiseControl - Class in com.linkedin.kafka.cruisecontrol
The main class of Cruise Control.
KafkaCruiseControl(KafkaCruiseControlConfig, Option<ZKClientConfig>, DataBalancerMetricsRegistry, BlockingSendClient.Builder) - Constructor for class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Construct the Cruise Control
KafkaCruiseControlConfig - Class in com.linkedin.kafka.cruisecontrol.config
The configuration class of Kafka Cruise Control.
KafkaCruiseControlConfig(Map<?, ?>) - Constructor for class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
KafkaCruiseControlConfig(Map<?, ?>, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
KafkaCruiseControlException - Exception in com.linkedin.kafka.cruisecontrol.exception
The parent exception for all the Cruise Control exceptions.
KafkaCruiseControlException(String, Throwable) - Constructor for exception com.linkedin.kafka.cruisecontrol.exception.KafkaCruiseControlException
 
KafkaCruiseControlException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.exception.KafkaCruiseControlException
 
KafkaCruiseControlException(Throwable) - Constructor for exception com.linkedin.kafka.cruisecontrol.exception.KafkaCruiseControlException
 
KafkaCruiseControlThreadFactory - Class in com.linkedin.kafka.cruisecontrol.common
 
KafkaCruiseControlThreadFactory(String, boolean, Logger) - Constructor for class com.linkedin.kafka.cruisecontrol.common.KafkaCruiseControlThreadFactory
 
KafkaCruiseControlThreadFactory(String, boolean, Logger, Optional<Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.common.KafkaCruiseControlThreadFactory
 
KafkaCruiseControlUtils - Class in com.linkedin.kafka.cruisecontrol
Util class for convenience.
KafkaDataBalanceManager - Class in io.confluent.databalancer
 
KafkaDataBalanceManager(KafkaConfig) - Constructor for class io.confluent.databalancer.KafkaDataBalanceManager
Create a KafkaDataBalanceManager.
KafkaMetricDef - Enum in com.linkedin.kafka.cruisecontrol.monitor.metricdefinition
The metric definitions of Kafka Cruise Control.
KafkaMetricDef.DefScope - Enum in com.linkedin.kafka.cruisecontrol.monitor.metricdefinition
 
KafkaPartitionMetricSampleAggregator - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator
This class aggregates the partition metric samples generated by the MetricFetcher.
KafkaPartitionMetricSampleAggregator(KafkaCruiseControlConfig, MetadataClient) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Construct the metric sample aggregator.
KafkaSampleStore - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
The sample store that implements the SampleStore.
KafkaSampleStore() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
kill(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Kill the task.

L

lastArrayIndex() - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
lastUpdateTime() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
lastUpdateTimeMs() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
The last time the state was updated
lastWindowIndex() - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
lastWindowIndex() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
latest() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
 
LATEST_SUPPORTED_VERSION - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
leader() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the leader replica.
LEADER_NETWORK_INBOUND_WEIGHT_FOR_CPU_UTIL_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
leader.network.inbound.weight.for.cpu.util
LEADER_NETWORK_OUTBOUND_WEIGHT_FOR_CPU_UTIL_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
leader.network.outbound.weight.for.cpu.util
LEADER_REPLICA_COUNT_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
leader.replica.count.balance.threshold
LEADER_REPLICAS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
LeaderBytesInDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Soft goal to distribute leader bytes evenly.
LeaderBytesInDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
leaderReplicaBalancePercentage() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get leader replica balance percentage for LeaderReplicaDistributionGoal.
LeaderReplicaDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Generate leadership movement and leader replica movement proposals to ensure that the number of leader replicas on each broker is Under: (the average number of leader replicas per broker) * (1 + leader replica count balance percentage) Above: (the average number of leader replicas per broker) * Math.max(0, 1 - leader replica count balance percentage)
LeaderReplicaDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
Constructor for Leader Replica Distribution Goal.
LeaderReplicaDistributionGoal(BalancingConstraint) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
Package private for unit test.
leaderReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get all the leader replicas.
leaderReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get all the leader replicas in the cluster.
leaderReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
leaderReplicaStats() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get leader replica stats for the cluster instance that the object was populated with.
LEADERSHIP_MOVEMENTS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
leadershipLoadForNwResources() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
The load for the replicas for which this broker is a leader.
leadershipMovementConcurrency() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
length() - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
length() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
 
length() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
The length of the value array.
length() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
 
lessThan(double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
Get a ReplicaWrapper for searching purpose on a collection.
lessThanOrEqualsTo(double) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
Get a ReplicaWrapper for searching purpose on a collection.
LINEAR_REGRESSION_MODEL_CPU_UTIL_BUCKET_SIZE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
linear.regression.model.cpu.util.bucket.size
LINEAR_REGRESSION_MODEL_MIN_NUM_CPU_UTIL_BUCKETS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
linear.regression.model.min.num.cpu.util.buckets
LINEAR_REGRESSION_MODEL_REQUIRED_SAMPLES_PER_CPU_UTIL_BUCKET_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
linear.regression.model.required.samples.per.bucket
LinearRegressionModelParameters - Class in com.linkedin.kafka.cruisecontrol.model
 
LinearRegressionModelParameters() - Constructor for class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
 
LinearRegressionModelParameters.LinearRegressionModelState - Class in com.linkedin.kafka.cruisecontrol.model
 
LinearRegressionModelParameters.ModelCoefficient - Enum in com.linkedin.kafka.cruisecontrol.model
An enumeration holding the coefficients.
linearRegressionModelState() - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
load() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the broker load of the broker.
load() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the recent cluster load information.
load() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
The load on the rack.
Load - Class in com.linkedin.kafka.cruisecontrol.model
A class for representing load information for each resource.
Load() - Constructor for class com.linkedin.kafka.cruisecontrol.model.Load
Package constructor for load with given load properties.
LOAD - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
load() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the rack load information.
load() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get the replica load for each resource.
LOAD_AFTER_OPTIMIZATION - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
LOAD_BEFORE_OPTIMIZATION - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
LOAD_GENERATION_ACCEPTABLE_STALENESS_LAG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
loadByWindows() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get load by their window time.
loadGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
loading(int, SortedMap<Long, Float>, int, int, double) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
LoadMonitor - Class in com.linkedin.kafka.cruisecontrol.monitor
The LoadMonitor monitors the workload of a Kafka cluster.
LoadMonitor(KafkaCruiseControlConfig, Time, DataBalancerMetricsRegistry, MetricDef) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Construct a load monitor.
LoadMonitor.AutoCloseableSemaphore - Class in com.linkedin.kafka.cruisecontrol.monitor
 
LoadMonitorState - Class in com.linkedin.kafka.cruisecontrol.monitor
 
LoadMonitorTaskRunner - Class in com.linkedin.kafka.cruisecontrol.monitor.task
A class that is responsible for running all the LoadMonitor tasks.
LoadMonitorTaskRunner(KafkaCruiseControlConfig, KafkaPartitionMetricSampleAggregator, KafkaBrokerMetricSampleAggregator, MetadataClient, MetricDef, Time, DataBalancerMetricsRegistry, BrokerCapacityConfigResolver) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Private constructor to avoid duplicate code.
LoadMonitorTaskRunner.LoadMonitorTaskRunnerState - Enum in com.linkedin.kafka.cruisecontrol.monitor.task
 
loadSamples(SampleStore.SampleLoader) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
loadSamples(SampleStore.SampleLoader) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
loadSamples(SampleStore.SampleLoader) - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore
Load the samples from the sample store.
loadSamples(MetricSampler.Samples) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore.SampleLoader
 
LOG - Variable in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
LOG_DIRS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
logDir() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
logdir() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
LOGDIR_RESPONSE_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
logdir.response.timeout.ms
logUnused() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Log warnings for any unused configurations
LongGenerationed - Class in com.linkedin.cruisecontrol.common
 
LongGenerationed(long) - Constructor for class com.linkedin.cruisecontrol.common.LongGenerationed
 
lowUtilizationThreshold(Resource) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the low utilization threshold for a resource.

M

markSelfHealingFinished(String) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
Update anomaly status once associated self-healing operation has finished.
markSelfHealingFinished(String) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorState
Update anomaly status once associated self-healing operation has finished.
markTaskAborting(ExecutionTask) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Mark an in-progress task as aborting (1) if an error is encountered and (2) the rollback is possible.
markTaskDead(ExecutionTask) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Mark an in-progress task as aborting (1) if an error is encountered and (2) the rollback is not possible.
markTaskDone(ExecutionTask) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Mark the successful completion of a given task.
markTasksAborting(List<ExecutionTask>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Mark the given tasks as aborting.
markTasksInProgress(List<ExecutionTask>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Mark the given tasks as in progress.
markTaskState(ExecutionTask, ExecutionTask.State) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Update the execution state of the task.
max() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
 
MAX_ALLOWED_EXTRAPOLATIONS_PER_BROKER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
max.allowed.extrapolations.per.broker
MAX_ALLOWED_EXTRAPOLATIONS_PER_ENTITY_CONFIG - Static variable in class com.linkedin.cruisecontrol.config.CruiseControlConfig
max.allowed.extrapolations.per.entity
MAX_ALLOWED_EXTRAPOLATIONS_PER_PARTITION_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
max.allowed.extrapolations.per.partition
MAX_BALANCEDNESS_SCORE - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
MAX_METADATA_WAIT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorUtils
 
MAX_REPLICA - Static variable in class com.linkedin.kafka.cruisecontrol.model.Replica
 
MAX_REPLICAS_PER_BROKER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Broker replica capacity: max.replicas
MAX_VOLUME_THROUGHPUT_MB_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
max.volume.throughput
maxAllowedExtrapolationsPerEntity() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
maxReplicasPerBroker() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get maximum number of replicas per broker.
maxReplicationFactor() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the maximum replication factor of a replica that was added to the cluster before.
maybeApplyBalancingAction(ClusterModel, Replica, Collection<Broker>, ActionType, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Attempt to apply the given balancing action to the given replica in the given cluster.
maybeClearOngoingAnomalyDetectionTimeMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
maybeMoveReplicaBetweenDisks(ClusterModel, Replica, Collection<Disk>, Set<Goal>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Attempt to move replica between disks of the same broker.
maybeShutdownBroker(int, Optional<Long>) - Method in class com.linkedin.kafka.cruisecontrol.server.BrokerShutdownManager
Ensures that the given broker is shut down by initiating shutdown via an #InitiateShutdownRequest and awaiting the shutdown of the broker.
meanTimeBetweenAnomaliesMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyMetrics
 
meanTimeToStartFixMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyMetrics
 
meetCompletenessRequirements(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Check if the completeness requirements are met for the given goals.
meetCompletenessRequirements(MetadataClient.ClusterAndGeneration, ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Check whether the monitored load meets the load requirements.
meetCompletenessRequirements(ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Check whether the monitored load meets the load requirements.
mergedConfigValues() - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
METADATA - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
METADATA_MAX_AGE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metadata.max.age.ms
METADATA_TTL_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metadata.ttl
metadataChanged(MetadataClient.ClusterAndPlacements, MetadataClient.ClusterAndPlacements) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
Check whether the metadata has changed.
MetadataClient - Class in com.linkedin.kafka.cruisecontrol.common
 
MetadataClient(KafkaCruiseControlConfig, long, Time) - Constructor for class com.linkedin.kafka.cruisecontrol.common.MetadataClient
 
MetadataClient.ClusterAndGeneration - Class in com.linkedin.kafka.cruisecontrol.common
 
MetadataClient.ClusterAndPlacements - Class in com.linkedin.kafka.cruisecontrol.common
 
METRIC_SAMPLE_AGGREGATOR_COMPLETENESS_CACHE_SIZE_CONFIG - Static variable in class com.linkedin.cruisecontrol.config.CruiseControlConfig
metric.sample.aggregator.completeness.cache.size
METRIC_SAMPLER_BOOTSTRAP_SERVERS - Static variable in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
METRIC_SAMPLER_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metric.sampler.class
METRIC_SAMPLER_GROUP_ID - Static variable in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
METRIC_SAMPLER_PARTITION_ASSIGNOR_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metric.sampler.partition.assignor.class
METRIC_SAMPLING_INTERVAL_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metric.sampling.interval.ms
METRIC_VALUES - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
metricClassId() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.BrokerMetric
 
metricClassId() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
Get the metric class id for this metric.
metricClassId() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.PartitionMetric
 
metricClassId() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
metricConsumer - Variable in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
MetricDef - Class in com.linkedin.cruisecontrol.metricdef
The definition of metrics.
MetricDef() - Constructor for class com.linkedin.cruisecontrol.metricdef.MetricDef
 
metricDefForToString() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
A method that can be overridden by subclasses to get prettier toString() format.
metricDefForToString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
MetricFetcherManager - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
The class manages the metric fetchers.
MetricFetcherManager(KafkaCruiseControlConfig, KafkaPartitionMetricSampleAggregator, KafkaBrokerMetricSampleAggregator, MetadataClient, MetricDef, Time, DataBalancerMetricsRegistry, BrokerCapacityConfigResolver) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
Create a metric fetcher manager.
MetricFetcherManager(KafkaCruiseControlConfig, KafkaPartitionMetricSampleAggregator, KafkaBrokerMetricSampleAggregator, MetadataClient, MetricDef, Time, DataBalancerMetricsRegistry, BrokerCapacityConfigResolver, MetricSampler) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
Create a metric fetcher manager.
metricFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
metricIds() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
 
metricInfo(String) - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
Get the metric id from the metric name.
metricInfo(short) - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
 
MetricInfo - Class in com.linkedin.cruisecontrol.metricdef
The metric information including the name, id, the way of interpretation and the metric group name.
MetricInfo(String, short, AggregationFunction, String) - Constructor for class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
metricInfoForGroup(String) - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
Get all the metric info for the given group.
metricName() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.YammerMetricWrapper
 
METRICS_WINDOW_MS_CONFIG - Static variable in class com.linkedin.cruisecontrol.config.CruiseControlConfig
window.ms
MetricsAllowListBuilder() - Constructor for class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry.MetricsAllowListBuilder
 
MetricSample<G,E extends Entity<G>> - Class in com.linkedin.cruisecontrol.monitor.sampling
A class to host a set of metric values of a given entity.
MetricSample(E) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
MetricSampleAggregationResult<G,E extends Entity<G>> - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
MetricSampleAggregationResult(long, MetricSampleCompleteness<G, E>) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregationResult
 
MetricSampleAggregator<G,E extends Entity<G>> - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
This class is responsible for aggregate MetricSamples for entities.
MetricSampleAggregator(int, long, byte, int, MetricDef) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Construct the metric sample aggregator.
MetricSampleAggregator.SampleType - Enum in com.linkedin.cruisecontrol.monitor.sampling.aggregator
The MetricSamples type which the aggregator collects.
MetricSampleCompleteness<G,E extends Entity<G>> - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
This class contains the completeness information of the MetricSampleAggregatorState.
MetricSampleCompleteness(long, long) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
MetricSampler - Interface in com.linkedin.kafka.cruisecontrol.monitor.sampling
The interface to get metric samples of given topic partitions.
MetricSampler.Samples - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
A container class that wraps both the partition metric samples and broker metric samples.
MetricSampler.SamplingMode - Enum in com.linkedin.kafka.cruisecontrol.monitor.sampling
The sampling mode to indicate which type of samples is interested.
MetricSamplerPartitionAssignor - Interface in com.linkedin.kafka.cruisecontrol.monitor.sampling
The interface to assign the partitions to the metric samplers.
MetricSamplingException - Exception in com.linkedin.kafka.cruisecontrol.exception
The exception indicating something went wrong during the metrics sampling.
MetricSamplingException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.exception.MetricSamplingException
 
metricScope() - Method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
MetricSerde - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
 
MetricSerde() - Constructor for class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
metricsToPredict() - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
 
MetricsUtils - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
 
metricValue(short) - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
The metric for the specified metric id.
metricValue(KafkaMetricDef) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
MetricValues - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
A class hosting the values of a particular metric.
MetricValues(int) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Construct a MetricValues.
metricValues() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.ValuesAndExtrapolations
Get the metric values for all the included windows.
MIN_BROKER_SAMPLE_STORE_TOPIC_RETENTION_TIME_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
MIN_NUM_VALID_WINDOWS_FOR_SELF_HEALING - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
 
MIN_PARTITION_SAMPLE_STORE_TOPIC_RETENTION_TIME_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
MIN_REPLICA - Static variable in class com.linkedin.kafka.cruisecontrol.model.Replica
 
MIN_SAMPLES_PER_BROKER_METRICS_WINDOW_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
min.samples.per.broker.metrics.window
MIN_SAMPLES_PER_METRICS_WINDOW_CONFIG - Static variable in class com.linkedin.cruisecontrol.config.CruiseControlConfig
min.samples.per.window
MIN_SAMPLES_PER_PARTITION_METRICS_WINDOW_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
min.samples.per.partition.metrics.window
MIN_SUPPORTED_VERSION - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
 
MIN_VALID_PARTITION_RATIO_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
min.valid.partition.ratio
minMonitoredPartitionsPercentage() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
minRequiredBrokerMetricsAvailable() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
minRequiredNumWindows() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
minRetentionTimeMs - Variable in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
minValidEntityGroupRatio() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
minValidEntityRatio() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
minValidWindows() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
missingBrokerMetricsInMinSupportedVersion() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
modelCoefficientTrainingCompleteness() - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
 
modelCoefficientTrainingCompleteness() - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
ModelCompletenessRequirements - Class in com.linkedin.kafka.cruisecontrol.monitor
This class is created to describe the requirements of the model.
ModelCompletenessRequirements(int, double, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
Constructor for the requirements.
modelGeneration() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
ModelGeneration - Class in com.linkedin.kafka.cruisecontrol.monitor
A container class to hold generation information.
ModelGeneration(int, long) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
ModelParameters - Class in com.linkedin.kafka.cruisecontrol.model
 
ModelParameters.ConfigSetting - Enum in com.linkedin.kafka.cruisecontrol.model
An enumeration holding the different configuration combinations.
modelState() - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
 
ModelUtils - Class in com.linkedin.kafka.cruisecontrol.model
The util class for model.
MONITOR_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
monitoredPartitionsPercentage() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get the monitored partition percentage of this cluster model;
monitoredPartitionsRatio() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the coverage of this cluster model.
monitoredPercentage(MetadataClient.ClusterAndGeneration) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Get the valid partitions percentage across all the windows.
monitoredWindows() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
monitoringPeriodMs() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Get the length of time aggregator keeps samples in memory.
monitorState() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
MonitorUtils - Class in com.linkedin.kafka.cruisecontrol.monitor
A util class for Monitor.
moveReplicaToEnd(Replica) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Move a replica to the end of the replica list.
MultiBrokerAdditionOperation - Class in com.linkedin.kafka.cruisecontrol.operation
This class helps track the progress of a multiple brokers being added that are part of the same broker addition operation.
MultiBrokerAdditionOperation(Set<Integer>, List<BrokerAdditionStateManager>) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 

N

name() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
name() - Method in class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuCapacityGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuUsageDistributionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskCapacityGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
 
name() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundCapacityGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundUsageDistributionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundCapacityGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundUsageDistributionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.GeneratingClusterModel
 
name() - Method in interface com.linkedin.kafka.cruisecontrol.async.progress.OperationStep
 
name() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OptimizationForGoal
 
name() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.Pending
 
name() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.RetrievingMetrics
 
name() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.WaitingForClusterModel
 
name - Variable in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations.GoalResult
the name of the goal
name() - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.BaseReplicaMovementStrategy
Get the name of this strategy.
name() - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.PostponeUrpReplicaMovementStrategy
Get the name of this strategy.
name() - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.PrioritizeLargeReplicaMovementStrategy
Get the name of this strategy.
name() - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.PrioritizeSmallReplicaMovementStrategy
Get the name of this strategy.
name() - Method in interface com.linkedin.kafka.cruisecontrol.executor.strategy.ReplicaMovementStrategy
Get the name of this strategy.
name() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
The name of the host
NAME - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.CrossRackMovementGoal
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.SequentialReplicaMovementGoal
 
name() - Method in interface io.confluent.databalancer.operation.BalancerOperationState
The name of the state
names() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Returns unmodifiable set of properties names defined in this ConfigDef
nanToZero(double) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
NETWORK_IN_CAPACITY_BYTES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Network Capacity values
NETWORK_INBOUND_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
network.inbound.balance.threshold
NETWORK_INBOUND_CAPACITY_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
network.inbound.capacity.threshold
NETWORK_INBOUND_LOW_UTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
network.inbound.low.utilization.threshold
NETWORK_OUT_CAPACITY_BYTES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
NETWORK_OUTBOUND_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
network.outbound.balance.threshold
NETWORK_OUTBOUND_CAPACITY_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
network.outbound.capacity.threshold
NETWORK_OUTBOUND_LOW_UTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
network.outbound.low.utilization.threshold
NetworkInboundCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
NetworkInboundCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundCapacityGoal
Constructor for Network Inbound Capacity Goal.
NetworkInboundUsageDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
NetworkInboundUsageDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundUsageDistributionGoal
Constructor for Resource Distribution Goal.
NetworkOutboundCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
NetworkOutboundCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundCapacityGoal
Constructor for Network Outbound Capacity Goal.
NetworkOutboundUsageDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
NetworkOutboundUsageDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundUsageDistributionGoal
Constructor for Resource Distribution Goal.
newBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of new brokers.
newGauge(Class<?>, String, Supplier<T>) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
newGauge(Class<?>, String, Supplier<T>, Map<String, String>) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
newGauge(Class<?>, String, Supplier<T>, boolean) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
newGauge(Class<?>, String, Supplier<T>, boolean, Map<String, String>) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
newInstance(Class<T>) - Static method in class com.linkedin.cruisecontrol.common.utils.Utils
Instantiate the class
newInstance(String, Class<T>) - Static method in class com.linkedin.cruisecontrol.common.utils.Utils
Look up the class by name and instantiate it.
newLeader() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
newMeter(Class<?>, String, String, TimeUnit) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
newObservers() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
newReplicas() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
newThread(Runnable) - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCruiseControlThreadFactory
 
newTimer(Class<?>, String) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
nextArrayIndex(int) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
The next array index of a given array index.
NL - Static variable in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
NO_ACTION - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
NO_DEFAULT_VALUE - Static variable in class com.linkedin.cruisecontrol.common.config.ConfigDef
A unique Java object which represents the lack of a default value.
NO_THROTTLE - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
nodes() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
A collection of nodes that consist the Kafka Cluster.
NonEmptyString() - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigDef.NonEmptyString
 
NonExistentBrokerException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.model.ClusterModel.NonExistentBrokerException
 
NoOpDataBalanceEngine - Class in io.confluent.databalancer
The NoOpDataBalancer is what's used for handling DataBalanceEngine requests when nodes that aren't eligible to run the DataBalanceEngine (i.e.
NoOpDataBalanceEngine() - Constructor for class io.confluent.databalancer.NoOpDataBalanceEngine
 
NoopNotifier - Class in com.linkedin.kafka.cruisecontrol.detector.notifier
A no-op notifier.
NoopNotifier() - Constructor for class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
NoopSampler - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
 
NoopSampler() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampler
 
NoopSampleStore - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
 
NoopSampleStore() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
noTaskInProgress(Set<Integer>, Set<Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
NotEnoughValidWindowsException - Exception in com.linkedin.cruisecontrol.exception
Thrown when there is not enough valid windows to meet the requirements specified by AggregationOptions
NotEnoughValidWindowsException(String) - Constructor for exception com.linkedin.cruisecontrol.exception.NotEnoughValidWindowsException
 
notStarted() - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
NUM_BROKER_METRICS_WINDOWS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
num.broker.metrics.windows
NUM_CACHED_RECENT_ANOMALY_STATES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
num.cached.recent.anomaly.states
NUM_CACHED_RECENT_ANOMALY_STATES_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
NUM_CONCURRENT_INTRA_BROKER_PARTITION_MOVEMENTS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
num.concurrent.intra.broker.partition.movements
NUM_CONCURRENT_LEADER_MOVEMENTS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
num.concurrent.leader.movements
NUM_CONCURRENT_PARTITION_MOVEMENTS_PER_BROKER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
num.concurrent.partition.movements.per.broker
NUM_METRIC_FETCHERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Deprecated.
(i.e. cannot be configured to a value other than 1). num.metric.fetchers
NUM_METRICS_WINDOWS_CONFIG - Static variable in class com.linkedin.cruisecontrol.config.CruiseControlConfig
num.windows
NUM_PARTITION_METRICS_WINDOWS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
num.partition.metrics.windows
NUM_SAMPLE_LOADING_THREADS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
numAliveRacks() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get number of alive racks in the cluster.
numAvailableWindows() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Get the number of available windows in the MetricSampleAggregator.
numAvailableWindows(long, long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Get the number of available windows in the given time range, excluding the current active window.
numBalancedBrokersByResource() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of balanced brokers by resource for the cluster instance that the object was populated with.
numBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of brokers for the cluster instance that the object was populated with.
numBrokersUnderPotentialNwOut() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of brokers under potential nw out for the cluster instance that the object was populated with.
numCheckedWithDelay() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
numCpuCores() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
numFinishedInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numFinishedInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
numFinishedIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numFinishedIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
numFinishedLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numFinishedLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
numFinishedMovements(ExecutionTask.TaskType) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
numLeaderReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the number of leader replicas in cluster.
numLeaderReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
numPartitionsWithOfflineReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of number of partitions with offline replicas in the cluster.
numRemainingInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numRemainingInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
numRemainingIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numRemainingIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
numRemainingLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numRemainingLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
numReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the number of replicas in cluster.
numReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
numReplicasInCluster() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of replicas for the cluster instance that the object was populated with.
numReplicasOfTopicInBroker(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get number of replicas from the given topic in this broker.
numSamples() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Get the total number of samples that is currently aggregated by the MetricSampleAggregator.
numSamples() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
 
numSelfHealingStarted() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyMetrics
 
numSnapshotWindows() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get the number of snapshot windows used by this cluster model;
numTopicReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the number of replicas with the given topic name in cluster.
numTopicReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Host
Get the number of replicas with the given topic name in this host.
numTopicReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the number of replicas with the given topic name in this rack.
numTopics() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of topics for the cluster instance that the object was populated with.
numTotalInterBrokerDataToMove() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
numTotalIntraBrokerDataToMove() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
numTotalMovements(ExecutionTask.TaskType) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
numUnbalancedDisks() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get the number of unbalanced disk in this cluster model; A disk is taken as unbalanced if its utilization percentage is out of the range centered at its broker utilization percentage with boundary determined by KafkaCruiseControlConfig.DISK_BALANCE_THRESHOLD_CONFIG.
numValidPartitions() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
numValidWindows() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
numWindows() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get the number of windows in the load.
numWindowsWithExtrapolation() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
 

O

oldLeader() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
oldObservers() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
oldReplicas() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
onActivation(EngineInitializationContext) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
onActivation(EngineInitializationContext) - Method in interface io.confluent.databalancer.DataBalanceEngine
To be called when this DataBalanceEngine should be activated and start running.
onActivation(EngineInitializationContext) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
onBrokerFailure(BrokerFailures) - Method in interface com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotifier
The method will be called when a broker failure has been detected.
onBrokerFailure(BrokerFailures) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
onBrokerFailure(BrokerFailures) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
onBrokersStartup(Set<Integer>, Set<Integer>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
onDeactivation() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
onDeactivation() - Method in interface io.confluent.databalancer.DataBalanceEngine
To be called when this DataBalanceEngine should stop execution.
onDeactivation() - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
onElection(Map<Integer, Long>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Start-up the DataBalanceManager.
onGoalViolation(GoalViolations) - Method in interface com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotifier
When a particular goal is violated this method will be called.
onGoalViolation(GoalViolations) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
onGoalViolation(GoalViolations) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
ongoingAnomalyDurationMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyMetrics
 
onlineFollowerBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that online followers reside in.
onlineFollowers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get online follower replicas.
onlyMoveImmigrantReplicas() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
onProgressChanged(int, S, Exception) - Method in interface io.confluent.databalancer.operation.BalancerOperationProgressListener
Called whenever the state of the balancer operation operation changes.
onProgressChanged(int, BrokerRemovalStateMachine.BrokerRemovalState, Exception) - Method in class io.confluent.databalancer.operation.PersistRemoveApiStateListener
 
onResignation() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
When the broker ceases to be the primary DataBalancer in the cluster.
onTerminalState(int, S, Exception) - Method in interface io.confluent.databalancer.operation.BalancerOperationTerminationListener
Called when the state of a balancer operation reaches a terminal point
operation() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
operationInProgress(ExecutorState.State, ExecutionTaskTracker.ExecutionTasksSummary, int, int, int, String, Set<Integer>, Set<Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
OperationProgress - Class in com.linkedin.kafka.cruisecontrol.async.progress
A class to track the progress of a task.
OperationProgress() - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
operationProgress - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
OperationStep - Interface in com.linkedin.kafka.cruisecontrol.async.progress
A single step of an operation.
OptimizationFailureException - Exception in com.linkedin.kafka.cruisecontrol.exception
An exception thrown when goal optimization failed.
OptimizationFailureException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.exception.OptimizationFailureException
 
OptimizationForGoal - Class in com.linkedin.kafka.cruisecontrol.async.progress
Indicating the goal optimization is in progress.
OptimizationForGoal(String) - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.OptimizationForGoal
 
OptimizationOptions - Class in com.linkedin.kafka.cruisecontrol.analyzer
A class to indicate options intended to be used during optimization of goals.
OptimizationOptions(Set<String>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
Default value for OptimizationOptions._excludedBrokersForLeadership is an empty set.
OptimizationOptions(Set<String>, Set<Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
Default value for OptimizationOptions._excludedBrokersForReplicaMove is an empty set.
OptimizationOptions(Set<String>, Set<Integer>, Set<Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
OptimizationOptions(Set<String>, Set<Integer>, Set<Integer>, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
Default value for OptimizationOptions._requestedDestinationBrokerIds is an empty set.
OptimizationOptions(Set<String>, Set<Integer>, Set<Integer>, boolean, Set<Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
OptimizationOptions(Set<String>, Set<Integer>, Set<Integer>, boolean, Set<Integer>, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
OptimizationResult - Class in com.linkedin.kafka.cruisecontrol.servlet.response
 
OptimizationResult(OptimizerResult) - Constructor for class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
optimizations(ClusterModel, List<Goal>, Set<Integer>, Set<Integer>, boolean, Map<TopicPartition, List<ReplicaPlacementInfo>>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizer
Depending the existence of dead/broken/decommissioned brokers in the given cluster: (1) Re-balance: Generates proposals to update the state of the cluster to achieve a final balanced state.
optimize(ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
optimize(ClusterModel, Set<Goal>, OptimizationOptions) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Optimize the given cluster model as needed for this goal.
optimize(ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
OptimizerResult - Class in com.linkedin.kafka.cruisecontrol.analyzer
A class for representing the results of goal optimizer.
optimizerResult() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
originalBroker() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get the original broker of this replica before rebalance.
originalDisk() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get disk that the replica originally resides in.
originals() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
originalsStrings() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Get all the original settings, ensuring that all values are of type String.
originalsWithPrefix(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Gets all original settings with the given prefix, stripping the prefix before adding it to the output.
OVERRIDE_STATIC_THROTTLES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
static.throttle.rate.override.enabled

P

parameterObject() - Method in class com.linkedin.kafka.cruisecontrol.config.RequestParameterWrapper
 
parametersClass() - Method in class com.linkedin.kafka.cruisecontrol.config.RequestParameterWrapper
 
parse(Map<?, ?>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Parse and validate configs against this configuration definition.
parseType(String, Object, ConfigDef.Type) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Parse a value according to its expected type.
partition() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.PartitionMetric
 
partition(TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get partition of the given replica.
PARTITION - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
Partition - Class in com.linkedin.kafka.cruisecontrol.model
A partition consists of replicas with the same topic partition.
PARTITION_METRIC_SAMPLE_AGGREGATOR_COMPLETENESS_CACHE_SIZE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
partition.metric.sample.aggregator.completeness.cache.size
PARTITION_METRIC_SAMPLE_STORE_TOPIC_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
PARTITION_METRICS_WINDOW_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
partition.metrics.windows.ms
PARTITION_SAMPLE_STORE_TOPIC_PARTITION_COUNT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
partitionBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that contain replicas of the partition.
partitionCount - Variable in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
PartitionEntity - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
The Entity class used by MetricSampleAggregator
PartitionEntity(TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
partitionId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the partition Id that is impacted by the balancing action.
partitionId() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
PartitionMetric - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
 
PartitionMetric(RawMetricType, long, int, String, int, double) - Constructor for class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.PartitionMetric
 
partitionMetric(String, int, RawMetricType) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
partitionMetricAvailable(TopicPartition, RawMetricType) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
PartitionMetricSample - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
The class that hosts all the metric samples for a partition.
PartitionMetricSample(int, TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionMetricSample
 
partitionMetricSamples() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.Samples
 
partitionMetricTypes() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
partitionMonitoringPeriodMs() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore.SampleLoader
 
partitionObserverBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that contain observer replicas of the partition.
partitionReassignmentsStatus() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Returns the partitions reassignment status for this state
partitionReassignmentsStatus() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
partitionSampleCount() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore.SampleLoader
 
partitionSyncBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that contain sync(non-observer) replicas of the partition
Password - Class in com.linkedin.cruisecontrol.common.config.types
A wrapper class for passwords to hide them while logging a config
Password(String) - Constructor for class com.linkedin.cruisecontrol.common.config.types.Password
Construct a new Password object
paused(int, SortedMap<Long, Float>, int, int, Map<TopicPartition, List<SampleExtrapolation>>, String) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
pauseMetricSampling(String) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Pause all the activities of the load monitor.
pauseSampling(String) - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Pause the scheduled sampling tasks..
peekCurrentWindow() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Peek the information for all the available entities of the current window.
peekCurrentWindow(long, MetricDef) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Peek the value for the current window.
Pending - Class in com.linkedin.kafka.cruisecontrol.async.progress
Indicating that the operation is still in the queue and hasn't started execution yet.
Pending() - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.Pending
 
PersistRemoveApiStateListener - Class in io.confluent.databalancer.operation
An implementation of #BalancerOperationProgressListener that persists all state updates for a single broker removal operation to disk
PersistRemoveApiStateListener(ApiStatePersistenceStore) - Constructor for class io.confluent.databalancer.operation.PersistRemoveApiStateListener
 
PLAN_COMPUTATION_RETRY_INTERVAL_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
PLAN_COMPUTATION_RETRY_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
plan.computation.retry.timeout.ms
PLAN_COMPUTATION_RETRY_TIMEOUT_MS_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
PlanComputable - Interface in com.linkedin.kafka.cruisecontrol.plan
A dead-simple interface to use as a lambda for computing a reassignments plan.
planComputationOptions - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
PlanComputationOptions - Class in com.linkedin.kafka.cruisecontrol
 
PlanComputationOptions(boolean, boolean, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.PlanComputationOptions
 
PlanComputationUtils - Class in com.linkedin.kafka.cruisecontrol.plan
 
PlanComputationUtils(KafkaCruiseControlConfig, Time) - Constructor for class com.linkedin.kafka.cruisecontrol.plan.PlanComputationUtils
 
PostponeUrpReplicaMovementStrategy - Class in com.linkedin.kafka.cruisecontrol.executor.strategy
The strategy, which tries to first move replicas of partitions which currently are not under replicated.
PostponeUrpReplicaMovementStrategy() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.strategy.PostponeUrpReplicaMovementStrategy
 
postProcessParsedConfig(Map<String, Object>) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Called directly after user configs got parsed (and thus default values got set).
POTENTIAL_NW_OUT - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
potentialLeadershipLoadFor(Integer) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the leadership load for given broker id.
PotentialNwOutGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Generate proposals to keep the outbound network utilization on a broker such that even if all partitions within the broker become the leader, the outbound network utilization would not exceed the corresponding broker capacity threshold.
PotentialNwOutGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Empty constructor for Potential Network Outbound Goal.
potentialNwOutUtilizationStats() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get outbound network utilization stats for the cluster instance that the object was populated with.
PreferredLeaderElectionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Simply move the leaders to the first replica of each partition.
PreferredLeaderElectionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
PreferredLeaderElectionGoal(boolean, boolean, Cluster) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.PreferredLeaderElectionGoal
 
prepareBrokerMetrics(Cluster, int, long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
Due to the yammer metric exponential decaying mechanism, the broker metric and the sum of the partition metrics on the same broker may differ by a lot.
prevArrayIndex(int) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
The previous array index of a given array index.
prioritizeDiskImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
prioritizeImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
PrioritizeLargeReplicaMovementStrategy - Class in com.linkedin.kafka.cruisecontrol.executor.strategy
The strategy, which tries to first move replicas of larger size partitions.
PrioritizeLargeReplicaMovementStrategy() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.strategy.PrioritizeLargeReplicaMovementStrategy
 
prioritizeOfflineReplicas() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
prioritizeOfflineReplicasThenImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
PrioritizeSmallReplicaMovementStrategy - Class in com.linkedin.kafka.cruisecontrol.executor.strategy
The strategy, which tries to first move replicas of small size partitions.
PrioritizeSmallReplicaMovementStrategy() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.strategy.PrioritizeSmallReplicaMovementStrategy
 
priorityFunction() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
 
process(Cluster, Set<TopicPartition>, MetricSampler.SamplingMode) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
Process all the added CruiseControlMetric to get the MetricSampler.Samples
PRODUCER_CLIENT_ID - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
progress() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
progressCallback - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
proposal() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
proposalReady() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
proposals - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
PROPOSALS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
proposalSummary(String) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
putBrokerRemovalFuture(int, BrokerRemovalFuture) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
Store a future of the broker removal operation in memory
putBrokerStateManager(BrokerAdditionStateManager) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
putBrokerStateManager(BrokerAdditionStateManager) - Method in interface io.confluent.databalancer.DataBalanceEngineContext
 

R

rack() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get broker's rack.
rack(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the rack with the rack id if it is found in the cluster; null otherwise.
rack() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
Rack - Class in com.linkedin.kafka.cruisecontrol.model
A class that holds the information of the rack, including its topology, liveness and load for brokers, and replicas.
RACK_ID - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
RackAwareGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
HARD GOAL: Generate replica movement proposals to provide rack-aware replica distribution.
RackAwareGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Constructor for Rack Capacity Goal.
RawAndDerivedResource - Enum in com.linkedin.kafka.cruisecontrol.model
These are the resources derived from the base resources used by the various goals to perform balancing.
rawMetricType() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
Get the RawMetricType of this metric.
RawMetricType - Enum in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
The metric type helps the metric sampler to distinguish what metric a value is representing.
RawMetricType.MetricScope - Enum in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
 
RawMetricValues - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
This class is responsible for bookkeeping raw values of each kind of metrics defined in the MetricDef.
RawMetricValues(int, byte, int) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Construct a RawMetricValues.
READ_THROUGHPUT_MULTIPLIER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
read.throughput.multiplier
ReadOnlyKafkaSampleStore - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
This samples store only reads the partition metric samples and broker metric samples from the Kafka topic.
ReadOnlyKafkaSampleStore() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.ReadOnlyKafkaSampleStore
 
readyGoals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
reasonOfLatestPauseOrResume() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
 
rebalance(List<String>, boolean, ModelCompletenessRequirements, OperationProgress, boolean, Integer, Integer, Integer, ReplicaMovementStrategy, String, boolean, boolean, boolean, Set<Integer>, boolean) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Rebalance the cluster
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
(1) REBALANCE BY LEADERSHIP MOVEMENT: Perform leadership movement to ensure that the load on brokers and/or hosts (see Resource.isHostResource() and Resource.isBrokerResource()) for the outbound network load and CPU is under the capacity limit.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Perform optimization via replica movement cross disks on broker to ensure balance: The load on each alive disk is under the disk's the capacity limit.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
(1) REBALANCE BY REPLICA MOVEMENT: Perform optimization via replica movement between disks to ensure balance: The load on disks are within range.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Rack-awareness violations can be resolved with replica movements.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
(1) REBALANCE BY LEADERSHIP MOVEMENT: Perform leadership movement to ensure that the load on brokers for the outbound network and CPU load is under the balance limit.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
Rebalance the given broker without violating the constraints of the current goal and optimized goals.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Try to rebalance each broker by moving any replicas that exceed the total number of partition replicas for a rack to a rack with unsatisfied constraints.
RECEIVE_BUFFER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
receive.buffer.bytes
recentlyDemotedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Recently demoted brokers are the ones for which a demotion was started, regardless of how the process was completed.
recentlyDemotedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
recentlyRemovedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Recently removed brokers are the ones for which a removal was started, regardless of how the process was completed.
recentlyRemovedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
recommendedValues() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
recommendedValues(List<Object>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
record(MetricInfo, double) - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
Record a sample value for the given metric info.
recordMetric(CruiseControlMetric) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
refer(OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
Refer this operation progress to another one.
refreshClusterAndGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
refreshClusterMaxReplicationFactor() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Refresh the maximum topic replication factor statistic.
refreshMetadata() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Refresh the metadata.
refreshMetadata(int) - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Refresh the metadata, but bound the wait time for the call.
refreshMetadata(int, boolean) - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
 
registerEvent(BrokerAdditionStateMachine.BrokerAdditionEvent) - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 
registerEvent(BrokerAdditionStateMachine.BrokerAdditionEvent, Exception) - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 
registerEvent(E, Exception) - Method in interface io.confluent.databalancer.operation.BalancerOperationCallback
Registers a new errorful #BalancerOperationEvent as part of the progress changing
registerEvent(E) - Method in interface io.confluent.databalancer.operation.BalancerOperationCallback
Registers a new #BalancerOperationEvent as part of the progress changing
registerEvent(BrokerAdditionStateMachine.BrokerAdditionEvent) - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
registerEvent(BrokerAdditionStateMachine.BrokerAdditionEvent, Exception) - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
registerEvent(BrokerRemovalStateMachine.BrokerRemovalEvent) - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
registerEvent(BrokerRemovalStateMachine.BrokerRemovalEvent, Exception) - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
relocateLeadership(TopicPartition, int, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
(1) Removes leadership from source replica.
relocateReplica(TopicPartition, int, String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
For replica movement across the disks of the same broker.
relocateReplica(TopicPartition, int, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
For replica movement across the broker: (1) Remove the replica from the source broker, (2) Set the broker of the removed replica as the destination broker, (3) Add this replica to the destination broker.
remainingInterBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
remainingInterBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
remainingInterBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
remainingInterBrokerReplicaMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Get the remaining inter-broker replica movement tasks.
remainingIntraBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
remainingIntraBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
remainingIntraBrokerDataToMoveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
remainingIntraBrokerReplicaMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Get the remaining intra-broker replica movement tasks.
remainingLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Get the remaining leadership movements.
REMOVAL_HISTORY_RETENTION_TIME_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
removal.history.retention.time.ms
removeBroker(int, Optional<Long>, BalanceOpExecutionCompletionCallback, BrokerRemovalCallback, String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
A broker removal consists of 4 steps: 1.
removeBroker(int, Optional<Long>, String) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
removeBroker(int, Optional<Long>, String) - Method in interface io.confluent.databalancer.DataBalanceEngine
Schedules the removal of a broker
removeBroker(int, Optional<Long>, String) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
Request is invalid if its get handled by SBK while its not controller.
removeBrokerRemovalFuture(int) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
Clean up a stored (in memory) future of the broker removal operation
removeBrokers(Set<Integer>, List<String>, String, PlanComputationOptions) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Drain brokers #removedBrokers of all of their partition replicas, moving them to other brokers in the cluster.
removeEntities(Set<E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Remove the given set of entities from the MetricSampleAggregator.
removeEntityGroup(Set<G>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Remove the given set of entity groups from the MetricSampleAggregator.
removeReplica(int, TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Remove and get removed replica from the cluster.
replica(TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the replica if it is in the broker.
Replica - Class in com.linkedin.kafka.cruisecontrol.model
A class that holds the information of the replica, including its load, leader, topic partition, and broker.
replica() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
REPLICA_COUNT_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
replica.count.balance.threshold
REPLICA_MOVEMENT_STRATEGIES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
replica.movement.strategies
replicaBalancePercentage() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get replica balance percentage for ReplicaDistributionGoal.
ReplicaCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
HARD GOAL: Generate replica movement proposals to ensure that each broker has less than the given number of replicas.
ReplicaCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Constructor for Replica Capacity Goal.
replicaComparator() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get a comparator for the replicas in the broker.
ReplicaDistributionAbstractGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
An abstract class for replica distribution goals.
ReplicaDistributionAbstractGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
Constructor for Replica Distribution Abstract Goal.
ReplicaDistributionAbstractGoal.ChangeType - Enum in com.linkedin.kafka.cruisecontrol.analyzer.goals
Whether bring replica in or out.
ReplicaDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Generate replica movement proposals to ensure that the number of replicas on each broker is Under: (the average number of replicas per broker) * (1 + replica count balance percentage) Above: (the average number of replicas per broker) * Math.max(0, 1 - replica count balance percentage)
ReplicaDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
Constructor for Replica Distribution Goal.
ReplicaDistributionGoal(BalancingConstraint) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
 
ReplicaMovementStrategy - Interface in com.linkedin.kafka.cruisecontrol.executor.strategy
 
ReplicaPlacementGoal - Class in io.confluent.cruisecontrol.analyzer.goals
 
ReplicaPlacementGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
ReplicaPlacementInfo - Class in com.linkedin.kafka.cruisecontrol.model
 
ReplicaPlacementInfo(int, String) - Constructor for class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
ReplicaPlacementInfo(Integer) - Constructor for class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
REPLICAS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
replicas() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
replicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get replicas residing in the broker.
replicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
replicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
REPLICAS - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
replicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
 
replicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the list of replicas in the rack.
replicasOfTopicInBroker(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get replicas for topic.
ReplicaSortFunctionFactory - Class in com.linkedin.kafka.cruisecontrol.model
A factory class of replica sort functions.
replicasSortedByUtilization(Resource, boolean, boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Sort the partitions in the cluster by the utilization of the given resource.
replicaStats() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get replica stats for the cluster instance that the object was populated with.
replicasToAdd() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
replicasToMoveBetweenDisksByBroker() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
replicasToRemove() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
REPLICATION_THROTTLE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Replication throttle: throttle.bytes.per.second
replicationFactor - Variable in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
replicationFactorByTopic() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the replication factor that each topic in the cluster created with.
ReplicaWrapper - Class in com.linkedin.kafka.cruisecontrol.model
A class that helps host replica and its score.
ReplicaWrapper(Replica, double, Function<Replica, Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
request.timeout.ms
requestClass() - Method in class com.linkedin.kafka.cruisecontrol.config.RequestParameterWrapper
 
requestedDestinationBrokerIds() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
RequestParameterWrapper - Class in com.linkedin.kafka.cruisecontrol.config
A wrapper class for pluggable config names to handle a request.
RequestParameterWrapper(String, String, String) - Constructor for class com.linkedin.kafka.cruisecontrol.config.RequestParameterWrapper
 
ReservationHandle() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.Executor.ReservationHandle
Acquires the Executor's reservation
reservationHandle - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
reserveAndAbortOngoingExecutions(Duration) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Attempts to acquire a reservation on the Executor, blocking other threads from executing proposals and, if successfully reserved, aborts all of its ongoing executions.
resetWindowIndices(long, int) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Clear the state of a given number of windows starting at the given window index.
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuCapacityGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuUsageDistributionGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskCapacityGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundCapacityGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundUsageDistributionGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundCapacityGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundUsageDistributionGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
Resource - Enum in com.linkedin.kafka.cruisecontrol.common
CPU: a host and broker-level resource.
resource() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
resourceBalancePercentage(Resource) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the balance percentage for the requested resource.
ResourceDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Balance Resource distribution over brokers.
ResourceDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Constructor for Resource Distribution Goal.
ResourceDistributionGoal.ChangeType - Enum in com.linkedin.kafka.cruisecontrol.analyzer.goals
Whether bring load in or bring load out.
resources() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the balancing for different resources.
resourceToMetricIds(Resource) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
resourceToMetricInfo(Resource) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
resourceUtilizationStats() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get resource utilization stats for the cluster instance that the object was populated with.
result() - Method in class com.linkedin.kafka.cruisecontrol.common.AdminClientResult
The result of the AdminClient-backed call.
resumeMetricSampling(String) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Resume the activities of the load monitor.
resumeSampling(String) - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Resume the scheduled sampling tasks.
retainEntities(Set<E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Keep the given set of entities in the MetricSampleAggregator and remove the rest of the entities.
retainEntityGroup(Set<G>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Keep the given set of entity groups in the MetricSampleAggregator and remove the reset of the entity groups.
RetrievingMetrics - Class in com.linkedin.kafka.cruisecontrol.async.progress
This is the step when retrieving the workload snapshot from KafkaPartitionMetricSampleAggregator
RetrievingMetrics() - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.RetrievingMetrics
 
RETRY_BACKOFF_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
reverselySortedReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
Get a list of replicas in the descending order of their priority and score.
run() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolationDetector
 
run() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.SampleLoadingTask
 
running(int, SortedMap<Long, Float>, int, int, Map<TopicPartition, List<SampleExtrapolation>>, String) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 

S

SAMPLE_STORE_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
sample.store.class
sampleCountsAtWindowIndex(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Assumes RawMetricValues.sanityCheckWindowIndex(long) is called before this function.
SampleExtrapolation - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator
The sample with extrapolation for a partition that is still treated as valid.
SampleExtrapolation(long, Extrapolation) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.SampleExtrapolation
 
sampleExtrapolations() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
SampleLoader(KafkaPartitionMetricSampleAggregator, KafkaBrokerMetricSampleAggregator) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore.SampleLoader
 
sampleLoadingProgress() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
sampleLoadingProgress() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
sampleLoadingProgress() - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore
Get the sample loading progress.
sampleLoadingProgress() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
 
SampleLoadingTask - Class in com.linkedin.kafka.cruisecontrol.monitor.task
 
Samples(Set<PartitionMetricSample>, Set<BrokerMetricSample>) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.Samples
 
SampleStore - Interface in com.linkedin.kafka.cruisecontrol.monitor.sampling
This interface is for users to implement a sample store which persists the samples stored in Kafka Cruise Control.
SampleStore.SampleLoader - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
A class that will be constructed by Kafka Cruise Control and used by sample store during sample loading time.
sampleTime() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
The time this sample was taken.
sampling(int, SortedMap<Long, Float>, int, int, Map<TopicPartition, List<SampleExtrapolation>>) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
SAMPLING_ALLOW_CPU_CAPACITY_ESTIMATION_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
sampling.allow.cpu.capacity.estimation
SamplingUtils - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
 
sanityCheck() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
(1) Check whether each load in the cluster contains exactly the number of windows defined by the Load.
sanityCheckBrokerPresence(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Sanity check whether the provided brokers exist in cluster or not.
sanityCheckCapacityEstimation(boolean, Map<Integer, String>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Check whether the given capacity estimation info indicates estimations for any broker when capacity estimation is not permitted.
sanityCheckNonExistingGoal(List<String>, Map<String, Goal>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Sanity check whether the given goals exist in the given supported goals.
sanityCheckWindowIndex(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
 
sanityCheckWindowRangeReset(long, int) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Check whether the given window range can be reset.
save(BrokerRemovalStateRecord, boolean) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
Save api status passed in as argument removalStatus to persistence store.
SbkAdminUtils - Class in com.linkedin.kafka.cruisecontrol.common
 
SbkAdminUtils(ConfluentAdmin, KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
 
SbkApiStatusKeySerde() - Constructor for class io.confluent.databalancer.persistence.ApiStatePersistenceStore.SbkApiStatusKeySerde
 
SbkApiStatusMessageSerde() - Constructor for class io.confluent.databalancer.persistence.ApiStatePersistenceStore.SbkApiStatusMessageSerde
 
SbkTopicConfig(long, short, String, int, String) - Constructor for class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
SbkTopicConfigBuilder() - Constructor for class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
SbkTopicUtils - Class in com.linkedin.kafka.cruisecontrol
Utility class to deal with internal topics needed by cruise control/databalancer.
SbkTopicUtils() - Constructor for class com.linkedin.kafka.cruisecontrol.SbkTopicUtils
 
SbkTopicUtils.SbkTopicConfig - Class in com.linkedin.kafka.cruisecontrol
 
SbkTopicUtils.SbkTopicConfigBuilder - Class in com.linkedin.kafka.cruisecontrol
 
scheduleBrokerRemoval(int, Option<Long>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
score() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
scoreFunction() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
 
SEC_TO_MS - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
selectImmigrantLeaders() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
selectImmigrants() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
selectionFunction() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
 
selectLeaders() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
selectOnlineReplicas() - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
SELF_HEALING_BROKER_FAILURE_ENABLED_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
self.healing.broker.failure.enabled
SELF_HEALING_BROKER_FAILURE_ENABLED_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
SELF_HEALING_GOAL_VIOLATION_ENABLED_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
self.healing.goal.violation.enabled
SELF_HEALING_GOAL_VIOLATION_ENABLED_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
SELF_HEALING_GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
self.healing.goals
selfHealingEligibleReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get replicas eligible for self-healing.
selfHealingEnabled() - Method in interface com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotifier
Check whether the self healing is enabled for different anomaly types.
selfHealingEnabled() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
selfHealingEnabled() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
selfHealingEnabledRatio() - Method in interface com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotifier
Get the ratio during which the self-healing is enabled over the total operating time.
selfHealingEnabledRatio() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
selfHealingEnabledRatio() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
SelfHealingNotifier - Class in com.linkedin.kafka.cruisecontrol.detector.notifier
This class implements a logic of self-healing when anomaly is detected.
SelfHealingNotifier() - Constructor for class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
This is a hard goal; hence, the proposals are not limited to broken broker replicas in case of self-healing.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Check if the movement of potential outbound network utilization from the given source replica to given destination broker is acceptable for this goal.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
Check if requirements of this goal are not violated if this proposal is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Check if requirements of this goal are not violated if this proposal is applied to the given cluster state, false otherwise.
selfSatisfied(ClusterModel, BalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
This goal is always considered self-satisfied, since it can only be violated by other goals' actions
selfSatisfied(ClusterModel, BalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
SEND_BUFFER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
send.buffer.bytes
sendNotification(ExecutorNotification) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNoopNotifier
 
sendNotification(ExecutorNotification) - Method in interface com.linkedin.kafka.cruisecontrol.executor.ExecutorNotifier
When an execution completes successfully or is stopped this method should be called
sendRequest(AbstractRequest.Builder<? extends AbstractRequest>) - Method in interface com.linkedin.kafka.cruisecontrol.client.BlockingSend
 
sendRequest(AbstractRequest.Builder<? extends AbstractRequest>) - Method in class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient
 
sendShutdownRequest(InitiateShutdownRequest.Builder) - Method in class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient
Sends a #InitiateShutdownRequest to the #targetNode.
sendSlackMessage(SlackMessage, String) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
SequentialReplicaMovementGoal - Class in io.confluent.cruisecontrol.analyzer.goals
 
SequentialReplicaMovementGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.SequentialReplicaMovementGoal
 
serialize(String, CruiseControlMetric) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
serialize(BrokerRemovalStateMachine.BrokerRemovalState) - Static method in class io.confluent.databalancer.persistence.BrokerRemovalStateSerializer
 
set(int, double) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Set the value at the given index.
setAlwaysExecute(boolean) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder
 
setAutoHealMode(boolean) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
setAutoHealMode(boolean) - Method in interface io.confluent.databalancer.DataBalanceEngine
Enable or disable auto-healing (automatic execution of rebalance plans) when an imbalanced cluster is detected and broker membership doesn't change.
setAutoHealMode(boolean) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
setBrokerRemovalStateTracker(BrokerRemovalCallback) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder
 
setBrokerState(int, Broker.State) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Set the liveness state of the given broker.
setCleanupPolicy(String) - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
setCruiseControl(KafkaCruiseControl) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
setDefaultStartState(S) - Method in class io.confluent.databalancer.operation.StateMachineInitializer.Builder
The default state at which the state machine should start with if no starting state is given
setGeneration(G) - Method in interface com.linkedin.cruisecontrol.common.Generationed
Set the generation.
setGeneration(Long) - Method in class com.linkedin.cruisecontrol.common.LongGenerationed
 
setGeneration(Long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregationResult
 
setGeneration(Long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
setGoalViolationSelfHealing(boolean) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Enable or disable self healing for the GOAL_VIOLATION anomaly type.
setLastUpdateTime(long) - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
setMinRetentionTimeMs(long) - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
setObservership(boolean) - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Set observership status of the replica
setPartitionCount(Map<String, ?>, String, int) - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
setPartitionCount(int) - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
setPersistenceStore(ApiStatePersistenceStore) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
setPhase(BrokerRemovalPhase<T>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder
 
setProposals(Set<ExecutionProposal>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
setReplicaLoad(String, int, TopicPartition, AggregatedMetricValues, List<Long>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Set the load for the given replica.
setReplicationFactor(Map<String, ?>, String, short) - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
setRequestedInterBrokerPartitionMovementConcurrency(Integer) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Dynamically set the inter-broker partition movement concurrency per broker.
setRequestedIntraBrokerPartitionMovementConcurrency(Integer) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Dynamically set the intra-broker partition movement concurrency.
setRequestedLeadershipMovementConcurrency(Integer) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Dynamically set the leadership movement concurrency.
setSelfHealingFor(AnomalyType, boolean) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
(1) Enable or disable self healing for the given anomaly type and (2) update the cached anomaly detector state.
setSelfHealingFor(AnomalyType, boolean) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorState
 
setSelfHealingFor(AnomalyType, boolean) - Method in interface com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotifier
Enable or disable self healing for the given anomaly type.
setSelfHealingFor(AnomalyType, boolean) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
setSelfHealingFor(AnomalyType, boolean) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
setStartTime(long) - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
setState(Disk.State) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
Set Disk status.
setStatus(AnomalyState.Status) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
setStopRequested() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
setStopRequested() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
setTopic(String) - Method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfigBuilder
 
setTopicPlacements(Map<String, TopicPlacement>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
setWindows(List<Long>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.ValuesAndExtrapolations
Method to set the windows array.
shouldExclude(Replica, Set<String>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Check whether the replica should be excluded from the rebalance.
shouldExcludeForLeadership(Replica) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
Check whether moving the given replica violates the leadership exclusion requirement
shouldExcludeForReplicaMove(Replica) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
Check whether moving the given replica violates the replica move exclusion requirement
shouldRefreshClusterAndGeneration(Set<CruiseControlState.SubState>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Check if the ClusterAndGeneration needs to be refreshed to retrieve the requested substates.
shutdown() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
Shutdown the anomaly detector.
shutdown() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Shutdown the executor.
shutdown() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
shutdown() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Shutdown the load monitor.
shutdown() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
Shutdown the metric fetcher manager.
shutdown() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Shutdown the task runner.
shutdown() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
Called when the object is going away for good (end of broker lifetime).
shutdown() - Method in interface io.confluent.databalancer.DataBalanceEngine
To be called when the object is going away.
shutdown() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
To be called when the KafkaDataBalanceManager is being fully shut down, rather than temporarily disabled for later startup.
shutdown() - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
SHUTDOWN_ANOMALY - Static variable in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorUtils
 
SingleBrokerStats - Class in com.linkedin.kafka.cruisecontrol.servlet.response.stats
 
size() - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
 
SKIP_SAMPLE_STORE_TOPIC_RACK_AWARENESS_CHECK_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
SLACK_SELF_HEALING_NOTIFIER_CHANNEL - Static variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
SLACK_SELF_HEALING_NOTIFIER_ICON - Static variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
SLACK_SELF_HEALING_NOTIFIER_USER - Static variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
SLACK_SELF_HEALING_NOTIFIER_WEBHOOK - Static variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
SlackMessage - Class in com.linkedin.kafka.cruisecontrol.detector.notifier
 
SlackMessage(String, String, String, String) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
SlackSelfHealingNotifier - Class in com.linkedin.kafka.cruisecontrol.detector.notifier
 
SlackSelfHealingNotifier() - Constructor for class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
SlackSelfHealingNotifier(Time) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
sortByMetricGroupValue(String) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
sortByMetricValue(String) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
sortedAliveBrokersUnderThreshold(Resource, double) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get a list of sorted (in ascending order by resource) alive brokers having utilization under: (given utilization threshold) * (broker and/or host capacity (see Resource.isHostResource() and Resource.isBrokerResource()).
sortedReplicas() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerAndSortedReplicas
 
SortedReplicas - Class in com.linkedin.kafka.cruisecontrol.model
A class used by the brokers/disks to host the replicas sorted in a certain order.
sortedReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
Get the sorted replicas in the ascending order of their priority and score.
sortedReplicaWrappers() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
Get the sorted replica wrappers in the ascending order of their priority and score.
sourceBrokerId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the source broker id that is impacted by the balancing action.
sourceBrokerLogdir() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the source broker logdir.
start() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Start the metric fetchers and sampling scheduler thread.
startDetection() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
startedBy() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
startedByUser() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
startMs() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
startState() - Method in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhase
Returns the broker removal state to which this state applies.
startState() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase
 
startTime() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
startTime() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
startUp() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
 
startUp() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Start up the Cruise Control.
startUp() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Start the load monitor.
startUp(KafkaConfig, Semaphore) - Method in class io.confluent.databalancer.startup.CruiseControlStartable
Checks and initiates the necessary components for starting up the data balancer (#KafkaCruiseControl and returns an instance of it
StartupCheckInterruptedException - Exception in io.confluent.databalancer.startup
Exception thrown when Cruise Control startup is aborted midway by shutdown, caused either by controller resignation or broker process shutdown.
StartupCheckInterruptedException() - Constructor for exception io.confluent.databalancer.startup.StartupCheckInterruptedException
 
StartupCheckInterruptedException(InterruptedException) - Constructor for exception io.confluent.databalancer.startup.StartupCheckInterruptedException
 
stat() - Method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
 
state(MetadataClient.ClusterAndGeneration) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizer
Get the analyzer state from the goal optimizer.
state() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
state() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Check whether the executor is executing a set of proposals.
state() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
state(OperationProgress, Set<CruiseControlState.SubState>) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Get the state with selected substates for Kafka Cruise Control.
state() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
state() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
state(OperationProgress, MetadataClient.ClusterAndGeneration) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the state of the load monitor.
state() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
state() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Get the state of the task runner.
state() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
state() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
StateMachine<S extends BalancerOperationState,E extends BalancerOperationEvent> - Class in io.confluent.databalancer.operation
An abstract state machine that helps facilitate the transition between different states for a given SBK operation (broker removal, broker addition)
StateMachine(int, String, S) - Constructor for class io.confluent.databalancer.operation.StateMachine
 
StateMachineInitializer<S extends BalancerOperationState> - Class in io.confluent.databalancer.operation
A stateless class that defines the initialization rules of any given #BalancerOperationState for a #StateMachine.
StateMachineInitializer.Builder<S extends BalancerOperationState> - Class in io.confluent.databalancer.operation
A Builder for constructing a #StateMachineInitializer with a set of #StateMachineInitializer.InitializationRules added through the #Builder#with(InitializationRule) method.
StateMachineInitializer.InitializationMode - Enum in io.confluent.databalancer.operation
A setting to configure what state to return when no state initialization is registered for a given state
StateMachineInitializer.InitializationRule<S extends BalancerOperationState> - Class in io.confluent.databalancer.operation
A rule denoting what state a given state should be initialized to.
Statistic - Enum in com.linkedin.kafka.cruisecontrol.common
 
STATISTICS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
stats() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
statsByGoalName() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
status() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
STATUS - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
status() - Method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionState
Returns the #PartitionReassignmentsStatus for this phase
statusUpdateMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
stopExecution() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor.ReservationHandle
Asynchronously stop the execution of execution proposal tasks
storeSamples(MetricSampler.Samples) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
storeSamples(MetricSampler.Samples) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampleStore
 
storeSamples(MetricSampler.Samples) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.ReadOnlyKafkaSampleStore
 
storeSamples(MetricSampler.Samples) - Method in interface com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStore
Store all the samples to the sample store.
stronger(ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
Combine the requirements of this ModelCompletenessRequirements and another one.
subtract(AggregatedMetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Subtract another AggregatedMetricValues from this one.
subtract(double[]) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Subtract a value array from the existing value array.
subtract(MetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Subtract another MetricValue from this MetricValues.
SUMMARY - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
supportedVersionSince() - Method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
swapFollowerPositions(int, int) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Given two follower indices in the replica list, swap their positions.
swapReplicaPositions(int, int) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Given two replica indices in the replica list, swap their positions.

T

tags() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.YammerMetricWrapper
 
taskComparator(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.BaseReplicaMovementStrategy
 
taskComparator(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.PostponeUrpReplicaMovementStrategy
 
taskComparator(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.PrioritizeLargeReplicaMovementStrategy
 
taskComparator(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.strategy.PrioritizeSmallReplicaMovementStrategy
 
taskComparator(Cluster) - Method in interface com.linkedin.kafka.cruisecontrol.executor.strategy.ReplicaMovementStrategy
Generate a comparator for replica movement task which incorporate the strategy to apply.
taskRunnerState() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Return the load monitor task runner state.
taskStat() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
 
TELEMETRY_REPORTER_TOPIC_PATTERN - Static variable in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
testDifference(double[][], double[][]) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Test if two clusters are significantly different in the metrics we look at for balancing.
throttledTopics() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns the topics that have had a replication throttle applied
time() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
Get the timestamp for this metric.
TIME_ZONE - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
toAllowCapacityEstimation() - Method in class com.linkedin.kafka.cruisecontrol.PlanComputationOptions
 
toBuffer(int) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.BrokerMetric
 
toBuffer(int) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.PartitionMetric
 
toBuffer(int) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
toBytes(CruiseControlMetric) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
toBytes() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerMetricSample
Serialize the partition metric sample using the BrokerMetricSample.LATEST_SUPPORTED_VERSION protocol.
toBytes() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionMetricSample
This method serialize the metric sample using a simple protocol.
toCruiseControlMetric(KafkaMetric, long, int) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Convert a KafkaMetric to a CruiseControlMetric
toCruiseControlMetric(long, int, YammerMetricWrapper, double) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Convert a Yammer metric to a CruiseControlMetric
toCruiseControlMetric(long, int, YammerMetricWrapper, double, String) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Convert a Yammer metric to a CruiseControlMetric
toCruiseControlMetric(long, int, String, Map<String, String>, double) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
build a CruiseControlMetric object.
toDateString(long) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Format the timestamp from long to a human readable string.
toDateString(long, String, String) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Format the timestamp from long to human readable string.
toEnrichedRst() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Configs with new metadata (group, orderInGroup, dependents) formatted with reStructuredText, suitable for embedding in Sphinx documentation.
toExcludeRecentlyDemotedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.PlanComputationOptions
 
toExcludeRecentlyRemovedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.PlanComputationOptions
 
toHtmlTable() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
topic() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get topic name of the impacted partition.
topic() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
topic() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.PartitionMetric
 
topic() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
TOPIC - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
topic - Variable in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
TOPIC_REPLICA_COUNT_BALANCE_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
topic.replica.count.balance.threshold
TOPIC_REPLICAS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
TopicMetric - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
 
TopicMetric(RawMetricType, long, int, String, double) - Constructor for class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
topicMetrics(String, RawMetricType) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
topicMetricsAvailable(String) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
topicMetricTypes() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
topicPartition() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get topic partition.
topicPartition() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
topicPartition() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
 
topicPartition() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get the topic partition.
topicPlacements() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
topicPlacements() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndPlacements
 
topicPlacements() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
 
topicReplicaBalancePercentage() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get topic replica balance percentage for TopicReplicaDistributionGoal.
TopicReplicaDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Balance collocations of replicas of the same topic.
TopicReplicaDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Constructor for Replica Distribution Goal.
TopicReplicaDistributionGoal(BalancingConstraint) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
topicReplicaStats() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get topic replica stats for the cluster instance that the object was populated with.
TOPICS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
topics() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the set of topics in the broker.
topics() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get topics in the cluster.
topics() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
topics() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get a set of topic names in the cluster.
TOPICS_EXCLUDED_FROM_PARTITION_MOVEMENT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
topics.excluded.from.partition.movement
topicsWithReplicationFactorChange() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
The topics of partitions which are going to be modified by proposals.
toPrettyDuration(double) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Format the duration from double to human readable string.
toPrettyTime(long) - Static method in class com.linkedin.cruisecontrol.CruiseControlUtils
Format the time to a pretty string.
toRemovalDescription() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
toRst() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Get the configs formatted with reStructuredText, suitable for embedding in Sphinx documentation.
toString() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.NonEmptyString
 
toString() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.Range
 
toString() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ValidList
 
toString() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef.ValidString
 
toString() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
toString() - Method in class com.linkedin.cruisecontrol.common.config.types.Password
Returns hidden password string
toString() - Method in class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
toString() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
 
toString() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions
 
toString() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
 
toString() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
toString() - Method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionType
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get string representation of this balancing proposal.
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get string representation of BalancingConstraint.
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
toString() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
toString() - Method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorState
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyMetrics
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations.GoalResult
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.BrokerMetric
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.PartitionMetric
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters.LinearRegressionModelState
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get string representation of Load.
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get string representation of Partition in XML format.
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get string representation of Rack.
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get string representation of the Replica.
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaPlacementInfo
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.SampleExtrapolation
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionMetricSample
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
toString() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
toStringCounts() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
 
totalNumPartitions(Cluster) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
 
tp() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
trackedSortedReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the tracked sorted replicas using the given sort name.
trackedSortedReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
Get the tracked sorted replicas using the given sort name.
trackSortedReplicas(String, Function<Replica, Double>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Ask the cluster model to keep track of the replicas sorted with the given score function.
trackSortedReplicas(String, Function<Replica, Integer>, Function<Replica, Double>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Ask the cluster model to keep track of the replicas sorted with the given priority function and score function.
trackSortedReplicas(String, Function<Replica, Boolean>, Function<Replica, Integer>, Function<Replica, Double>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Ask the cluster model to keep track of the replicas sorted with the given priority function and score function.
trackSortedReplicas(String, Function<Replica, Boolean>, Function<Replica, Integer>, Function<Replica, Double>) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
Track the sorted replicas using the given score function.
trackSortedReplicas(String, Function<Replica, Boolean>, Function<Replica, Double>) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
trainingCompleted() - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
 
trainingCompleted() - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
transferObservership(TopicPartition, int, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Swaps an observer(source) and sync-replica(destination) via the following: (1) Removes observership from the source replica (2) Adds observership to the destination replica (3) Performs a leadership transfer from the destination replica to the source replica if destination replica is a leader
type() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
typeOf(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 

U

uid - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalOptions
 
UNIT_INTERVAL_TO_PERCENTAGE - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
 
UnknownVersionException - Exception in com.linkedin.kafka.cruisecontrol.metricsreporter.exception
Unknown version during Serialization/Deserialization.
UnknownVersionException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.metricsreporter.exception.UnknownVersionException
 
untrackSortedReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Untrack the sorted replicas with the given name to release memory.
untrackSortedReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
Untrack the sorted replicas for the given sort name.
unused() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
updateConfig(KafkaConfig, KafkaConfig) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Updates the internal cruiseControl configuration based on dynamic property updates in the broker's KafkaConfig
updateDiskCapacityForBroker(String, String, int, double) - Method in interface com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigResolver
Update the disk capacity for a broker based on rack, host and broker id.
updateDiskCapacityForBroker(String, String, int, double) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityResolver
 
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Update goal state after one round of self-healing / rebalance.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Update goal state.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Update goal state.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Update goal state.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Update goal state after one round of self-healing / rebalance.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Update goal state.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Update goal state after one round of self-healing / rebalance.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
Update goal state after one round of self-healing / rebalance.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
Update goal state after one round of self-healing / rebalance.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Update the current resource that is being balanced if there are still resources to be balanced, finish otherwise.
updateGoalState(ClusterModel, Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Update goal state after one round of self-healing / rebalance.
updateGoalState(ClusterModel, Set<String>) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
 
updateGoalState(ClusterModel, Set<String>) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Validate that all topic placements have been satisfied.
updateModelCoefficient() - Method in class com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters
Trigger the calculation of the model parameters.
updateModelCoefficient() - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
Trigger the calculation of the model parameters.
updateOldestWindowIndex(long) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
Update the oldest window index.
updateOldestWindowIndex(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Update the oldest window index.
updateReplicationFactor(Map<Short, Set<String>>, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
For partitions of specified topics, create or delete replicas in given cluster model to change the partition's replication factor to target replication factor.
updateThrottle(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Update the throttle rate in ZK (for ongoing executions) and set a new throttle value, persisted in memory until the process dies
updateThrottle(long) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Update the throttle used for an ongoing execution.
updateThrottle(Long) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
updateThrottle(Long) - Method in interface io.confluent.databalancer.DataBalanceEngine
Update the replication throttles to be used during proposal execution.
updateThrottle(Long) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
uptimeMs(long) - Method in interface com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotifier
 
uptimeMs(long) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.NoopNotifier
 
uptimeMs(long) - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
USE_LINEAR_REGRESSION_MODEL_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
use.linear.regression.model
userTriggeredStopExecution() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Request the executor to stop any ongoing execution.
userTriggeredStopExecution() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Request the executor to stop any ongoing execution.
utcDateFor(long) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
utilizationMatrix() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
utilizationMatrix() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
This is the utilization matrix generated from ClusterModel.utilizationMatrix().
utilizationPercentage(Broker, Resource) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Get the utilization percentage of the broker for the given resource, or GoalUtils.DEAD_BROKER_UTILIZATION if the broker is dead.
utilizationPercentage() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
Utils - Class in com.linkedin.cruisecontrol.common.utils
 
uuid() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 

V

validate(Map<String, String>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Validate the current configuration values with the configuration definition.
validateAll(Map<String, String>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
validateWindowIndex(long) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
Check if a given window index is valid or not.
validEntities() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
validEntityGroupRatio() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
validEntityGroupRatioByWindowIndex() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
Get the ratio of the entity groups.
validEntityGroups() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
validEntityRatio() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
validEntityRatioByWindowIndex() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
Get the valid entity ratio of independent entities for each window.
validEntityRatioWithGroupGranularityByWindowIndex() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
Get the ratio of entities whose entity group has complete metric sample data.
validPartitionRatioByWindows(MetadataClient.ClusterAndGeneration) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Get the monitored partition percentage in each window.
validPartitionsRatio() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
validTargetState() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
validValues(String, Map<String, Object>) - Method in interface com.linkedin.cruisecontrol.common.config.ConfigDef.Recommender
The valid values for the configuration given the current configuration values.
validWindowIndices() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
Get the valid window indices.
validWindows(MetadataClient.ClusterAndGeneration, double) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Get a sorted set of valid windows in the aggregator.
value() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
value(Object) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
value() - Method in class com.linkedin.cruisecontrol.common.config.types.Password
Returns real password string
value() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
Get the metric value.
ValueComputingStrategy - Enum in com.linkedin.cruisecontrol.metricdef
Define the way to pick the metric values among all the samples in a window.
valueComputingStrategy() - Method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.common.config.ConfigDef.Importance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.common.config.ConfigDef.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.common.config.ConfigDef.Width
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.metricdef.AggregationFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.metricdef.ValueComputingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions.Granularity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.monitor.sampling.aggregator.Extrapolation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator.SampleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionAcceptance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal.ChangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal.ChangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.common.Resource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.detector.AnomalyState.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.TaskType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification.ActionAgent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutorState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric.MetricClassId
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType.MetricScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.model.Broker.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.model.Disk.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters.ModelCoefficient
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.model.ModelParameters.ConfigSetting
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.model.RawAndDerivedResource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef.DefScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.SamplingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner.LoadMonitorTaskRunnerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState.SubState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BrokerRemovalCancellationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.StateMachineInitializer.InitializationMode
Returns the enum constant of this type with the specified name.
values() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
values() - Static method in enum com.linkedin.cruisecontrol.common.config.ConfigDef.Importance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.common.config.ConfigDef.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.common.config.ConfigDef.Width
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.metricdef.AggregationFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.metricdef.ValueComputingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregationOptions.Granularity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.monitor.sampling.aggregator.Extrapolation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator.SampleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionAcceptance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal.ChangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal.ChangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.common.Resource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.detector.AnomalyState.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.TaskType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification.ActionAgent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutorState.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric.MetricClassId
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType.MetricScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.model.Broker.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.model.Disk.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.model.LinearRegressionModelParameters.ModelCoefficient
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.model.ModelParameters.ConfigSetting
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.model.RawAndDerivedResource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef.DefScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.SamplingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner.LoadMonitorTaskRunnerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState.SubState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.operation.BrokerRemovalCancellationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.operation.StateMachineInitializer.InitializationMode
Returns an array containing the constants of this enum type, in the order they are declared.
valuesAndExtrapolations() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregationResult
Get the aggregated metric values and extrapolations (if any) of each entity.
ValuesAndExtrapolations - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
The aggregated metrics for all the windows and the extrapolation information if there is any extrapolation used.
ValuesAndExtrapolations(AggregatedMetricValues, Map<Integer, Extrapolation>) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.ValuesAndExtrapolations
Construct the values and extrapolations.
valuesFor(short) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Get the MetricValues for the given metric id
valuesFor(Collection<Short>, boolean) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Get all the metric values for the given metric ids.
valuesForGroup(String, MetricDef, boolean) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Get a MetricValues which contains the sum of the values for all the metrics of a group in each corresponding window.
valuesWithPrefixOverride(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Put all keys that do not start with prefix and their parsed values in the result map and then put all the remaining keys with the prefix stripped and their parsed values in the result map.
variance() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
The variance of the derived resources.
VERSION - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
VIOLATED - Static variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
violatedGoalsAfterOptimization() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
violatedGoalsBeforeOptimization() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
violatedGoalsByFixability() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations
Get all the goal violations.
ViolationUtils - Class in com.linkedin.kafka.cruisecontrol.detector
 
visible(String, Map<String, Object>) - Method in interface com.linkedin.cruisecontrol.common.config.ConfigDef.Recommender
Set the visibility of the configuration given the current configuration values.
visible() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
visible(boolean) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 

W

WaitingForClusterModel - Class in com.linkedin.kafka.cruisecontrol.async.progress
 
WaitingForClusterModel() - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.WaitingForClusterModel
 
weaker(ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
Combine the requirements of this ModelCompletenessRequirements and another one.
window(int) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.ValuesAndExtrapolations
Get the time window of a specific index.
window() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.SampleExtrapolation
 
WindowIndexedArrays - Class in com.linkedin.cruisecontrol.common
This class helps maintain the window indices in circular arrays.
WindowIndexedArrays() - Constructor for class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
windowMs() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleCompleteness
 
windows() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.ValuesAndExtrapolations
Get the window list for the metric values.
windows() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get the windows list for the load.
WindowState<G,E extends Entity<G>> - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
A class that helps maintain the information of a window.
WindowState(long) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.WindowState
 
with(StateMachineInitializer.InitializationRule<S>) - Method in class io.confluent.databalancer.operation.StateMachineInitializer.Builder
 
WRITE_THROUGHPUT_MULTIPLIER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
write.throughput.multiplier
writeProposalSummary(StringBuilder) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
writeSuperVerbose(StringBuilder) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
writeTo(OutputStream) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Write this AggregatedMetricValues to the output stream to avoid string conversion.
writeTo(OutputStream) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
Write the MetricValues directly into a OutputStream to avoid string conversion.
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Output writing string representation of this class to the stream.
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
Output writing string representation of this class to the stream.
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Output writing string representation of this class to the stream.
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Output writing string representation of this class to the stream.
writeTo(OutputStream) - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Output writing string representation of this class to the stream.
writeVerboseAnalyzerState(StringBuilder) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
writeVerboseExecutorState(StringBuilder) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
writeVerboseMonitorState(StringBuilder) - Method in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 

Y

yammerMetricScopeToTags(String) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricsUtils
Convert a yammer metrics scope to a tags map.
YammerMetricWrapper - Class in com.linkedin.kafka.cruisecontrol.metricsreporter.metric
This class wraps a Yammer MetricName object in order to allow storing the computed tags
YammerMetricWrapper(MetricName) - Constructor for class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.YammerMetricWrapper
 

Z

ZK_CLIENT_NAME - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
ZK_CONNECTION_TIMEOUT - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
ZK_SESSION_TIMEOUT - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
ZOOKEEPER_CONNECT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
zookeeper.connect
ZOOKEEPER_SECURITY_ENABLED_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
zookeeper.security.enabled

_

_analyzerState - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
_anomalyDetectorState - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
_avgReplicasOnAliveBroker - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
_balanceLowerLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
_balanceUpperLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
_balancingConstraint - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
_basicStats - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
_brokerFailureAlertThresholdMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_brokerIdsAboveBalanceUpperLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
_brokerIdsUnderBalanceLowerLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
_brokerMetricSampleStoreTopic - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_brokerStats - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
_cachedJSONResponse - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
_cachedPlaintextResponse - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
_cachedResponse - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
_config - Variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
_consumers - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_defaultValue - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_dependents - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_diskStatsByLogdir - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
_displayName - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_documentation - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_entity - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
_executorState - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
_finished - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
_fixOfflineReplicasOnly - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
_generation - Variable in class com.linkedin.cruisecontrol.common.LongGenerationed
 
_group - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_host - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
_hostFieldLength - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
_hostStats - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
_id - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
_identityEntityMap - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_importance - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_internalConfig - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_isBrokerStatsEstimated - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
_isEstimated - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
_loadingProgress - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_logdirFieldLength - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.BrokerStats
 
_metricDef - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_metricProcessorExecutor - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_minMonitoredPartitionPercentage - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
_minSamplesPerWindow - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_monitoringPeriodMs - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_monitorState - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.CruiseControlState
 
_name - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_notifierStartTimeMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_numWindows - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_numWindows - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
_numWindowsToKeep - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_oldestWindowIndex - Variable in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
_optimizerResult - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.OptimizationResult
 
_orderInGroup - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_partitionMetricSampleStoreTopic - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_producer - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_recommender - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_sampleTime - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
_sampleType - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
_selfHealingEnabled - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_selfHealingEnabledHistoricalDurationMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_selfHealingStateChangeTimeMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_selfHealingThresholdMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_shutdown - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_skipSampleStoreTopicRackAwarenessCheck - Variable in class com.linkedin.kafka.cruisecontrol.monitor.sampling.KafkaSampleStore
 
_slackChannel - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
_slackIcon - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
_slackUser - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
_slackWebhook - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
_state - Variable in class com.linkedin.kafka.cruisecontrol.servlet.response.stats.SingleBrokerStats
 
_succeeded - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
_time - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
_topic - Variable in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
_type - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_validator - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_valuesByMetricId - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
_width - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
_windowMs - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
A B C D E F G H I J K L M N O P R S T U V W Y Z _ 
Skip navigation links