Skip navigation links
A B C D E F G H I J K L M N O P Q 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
 
AbstractDistributionStatsSnapshot - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
 
AbstractDistributionStatsSnapshot(BrokerResourceStats, BrokerResourceStats) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
AbstractExecutorReplicaMovement - Class in com.linkedin.kafka.cruisecontrol.executor
An abstract class that defines an interface for replica movements.
AbstractExecutorReplicaMovement(String, ExecutionTaskManager, Set<Integer>, ReplicationThrottleHelper, ConfluentAdmin, SbkAdminUtils, AtomicBoolean) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
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
 
AbstractTopicPartitionHistory - Class in io.confluent.cruisecontrol.analyzer.history
 
accept(T) - Method in interface com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils.MaybeThrowingConsumer
 
accept(boolean, Throwable) - Method in interface io.confluent.databalancer.operation.BalanceOpExecutionCompletionCallback
 
acceptance() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AcceptanceResult
 
AcceptanceResult - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
AcceptanceResult(ActionAcceptance, String) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.AcceptanceResult
 
accepted() - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AcceptanceResult
 
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
Responses indicating if a BalancingAction is acceptable by the goal(s) during movement.
actionAcceptance(GoalBalancingActionAcceptance, ClusterModel) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
 
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(GoalBalancingActionAcceptance, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
actionAcceptance(GoalBalancingActionAcceptance, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
 
ActionType - Enum in com.linkedin.kafka.cruisecontrol.analyzer
Flags to indicate the type of an action.
actionType - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
actionUuid() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
ACTIVE_BALANCER_COUNT_METRIC_NAME - Static variable in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
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.
add(H) - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
Adds a new TopicPartitionHistory to the pool.
add(T) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
addAll(Collection<? extends T>) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
addBadDiskBroker(Broker) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Record the broker which is unable to host the replica of the partition.
addBroker(Broker) - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
 
addBrokers(MultiBrokerAdditionOperation, BalanceOpExecutionCompletionCallback, String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Add brokers.
addBrokers(Set<Integer>, String, AliveBrokersMetadata) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
addBrokers(Set<Integer>, String, AliveBrokersMetadata) - Method in interface io.confluent.databalancer.DataBalanceEngine
 
addBrokers(Set<Integer>, String, AliveBrokersMetadata) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
addCapacity(Capacity) - Method in class com.linkedin.kafka.cruisecontrol.model.Capacity
 
addErrorMessage(String) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
addExecutionProposals(Collection<ExecutionProposal>, Collection<Integer>, Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Add a collection of execution proposals for execution.
addExecutionProposals(Collection<ExecutionProposal>, Cluster) - 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.
addLoad(Load) - Method in class com.linkedin.kafka.cruisecontrol.model.Load.Builder
 
addLoad(Broker.Strategy, Load) - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
addLoad(Broker.Strategy, AggregatedMetricValues) - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
addMetric(CruiseControlMetric) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
 
addMetricValues(Broker.Strategy, AggregatedMetricValues, List<Long>) - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
addReassigningPartition(TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Marks a #TopicPartition in the cluster model as reassigning.
addSample(MetricSample<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.Strategy, double, double, double, double, double, double, int, int, boolean, double, Map<String, DiskStats>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
addStep(OperationStep) - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
Add a OperationStep to the progress.
addSuspendedTopicPartitionListener(GoalOptimizationHistoryListener<SuspendedTopicPartition>) - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Adds a listener to the suspended topic partition listeners list.
addTaskForBroker(int, int) - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Add tasks for a specific broker.
addTasksToTrace(Collection<ExecutionTask>, ExecutionTask.TaskType) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Add new tasks to ExecutionTaskTracker to trace their execution.
addTenant(Tenant) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Add or update tenant in the cluster.
addTopicPartitionMovementListener(GoalOptimizationHistoryListener<TopicPartitionMovement>) - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Adds a listener to the topic partition movement listeners list.
addValue(long, double) - Method in class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
Append a new value to window
ADMIN_CLIENT_CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
adminClient - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
adminClient() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
adminClient(ConfluentAdmin) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
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
 
adminUtils - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
advanceState(EvenClusterLoadStateMachine.EvenClusterLoadEvent) - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateMachine
 
advanceState(E) - Method in class io.confluent.databalancer.operation.StateMachine
React to an event #E by advancing the state machine.
aggregate(long, long, AggregationOptions<E>, Set<Integer>) - 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(long, long, AggregationOptions<E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Overload of MetricSampleAggregator.aggregate(long, long, AggregationOptions, Set) passes empty set of failed brokers.
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, ModelCompletenessRequirements, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaPartitionMetricSampleAggregator
Collect the aggregated metrics for all the topic partitions
aggregate(Cluster, long, ModelCompletenessRequirements, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Method to aggregate the metrics of replicas in the cluster.
aggregate(Cluster, long, ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
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<E extends Entity> - 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.Cell
 
aliveBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get alive brokers in the cluster, including those which are ineligible for replica movement (i.e.
aliveBrokers() - Method in class io.confluent.databalancer.BrokersMetadataSnapshot
Return the unfenced/alive brokers.
aliveBrokersMatchingAttributes(Map<String, String>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get brokers with matching attributes
aliveBrokersMetadata() - Method in class io.confluent.databalancer.EngineInitializationContext
 
aliveRackIds() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Return a set of rack ids that are alive (at least one broker inside a rack is alive).
all() - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
 
allBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of all brokers in the cluster.
allBrokersWithStateOtherThan(Broker.Strategy) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Returns a set of all brokers in the cluster in any state other than stateToSkip
allMetricValues() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
allocateExecutionId() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskGenerationIdUtils
 
allowedCapacityForBroker(Resource, Capacity) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the total amount of allowed capacity for one broker, in the respective unit of the given Resource (MiB, KB, etc.).
allowedCapacityForBroker(Resource, double) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
allWindows() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
alterBrokerReplicaExclusions(ExclusionOp, Collection<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Alter replica exclusions for a set of brokers.
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
 
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_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, ConfluentAdmin, LoadMonitor, KafkaCruiseControl, Time, DataBalancerMetricsRegistry, ApiStatePersistenceStore, UpdatableSbcGoalsConfig) - 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
 
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
 
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
 
AnomalyStats - Class in com.linkedin.kafka.cruisecontrol.detector
Track interesting statistics about anomaly detection and action.
AnomalyStats(Map<AnomalyType, Double>, double, long, long) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.AnomalyStats
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.
AnomalyType - Enum in com.linkedin.kafka.cruisecontrol.detector.notifier
Flags to indicate the type of an anomaly.
anyUnevenLoadEnabled(KafkaConfig) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
anyUnevenLoadEnabled(String) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
API_STATE_TOPIC_CLEANUP_POLICY - Static variable in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
ApiStatePersistenceStore - Class in io.confluent.databalancer.persistence
This class is responsible for storing and exposing the persistent state of an SBK operation (add broker, remove broker, failed broker detection, even cluster load) 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
 
apply(KafkaCruiseControlConfig) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta
Apply this config delta to the provided KafkaCruiseControlConfig and obtain a new KafkaCruiseControlConfig.
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.
asDouble() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.DataPoint
 
asInt() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.DataPoint
 
assignPartitions(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.DefaultMetricSamplerPartitionAssignor
 
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
 
availableResource(Resource, BalancingConstraint) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
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
 
avg() - Method in class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
 
avgReplicasOnBrokerToBalance - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
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.
balance() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.RebalanceStep
Moves replica around to satisfy the goal.The handler may have updated the cluster model with replica resassignment even if it cannot fully satisfy the goal.
BALANCE_MARGIN - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils
 
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
 
balanceLowerPercent() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
The lower limit of the balance threshold, usually representing a percentage within the range [0.0, 1.0] (0-100%) (with exception to KAFKALESS-761).
balanceLowerValueThreshold - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
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.
BALANCER_DEFAULT_STATE - Static variable in class io.confluent.databalancer.KafkaDataBalanceManager
 
BALANCER_STATE_METRIC_NAME - Static variable in class io.confluent.databalancer.KafkaDataBalanceManager
 
balancerConfigResource() - Static method in class io.confluent.databalancer.KafkaDataBalanceManager
Returns the dynamic ConfigResource that is used when modifying Balancer configs
BalancerEnabledConfig - Class in io.confluent.databalancer
A mutable, thread-safe, up-to-date configuration indicating whether SBC is configured to run BalancerEnabledConfig.isConfiguredAsEnabled() and whether it should run BalancerEnabledConfig.shouldBeEnabled()
BalancerEnabledConfig(boolean, boolean) - Constructor for class io.confluent.databalancer.BalancerEnabledConfig
 
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).
BalancerOperationState - Interface in io.confluent.databalancer.operation
An interface to denote the state of an SBK operation (add broker, remove broker).
BalancerOperationState.BalancerOperationStateCharacteristics - Enum in io.confluent.databalancer.operation
Characteristics of a state machine state, and the general ("Balancer Operation State") types of states present in a BalancerOperationStateMachine..
BalancerResourceManager - Interface in io.confluent.databalancer.event.resource
An interface to enable SbcEvents to provide shared resources, get the current value of a shared resource, or wait on a shared resource to be provided.
balancerStatus() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
balancerStatus(ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<BalancerStatusDescriptionInternal>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
BalancerStatusCallback - Interface in com.linkedin.kafka.cruisecontrol.operation
 
BalancerStatusStateMachine - Class in io.confluent.databalancer.operation
 
BalancerStatusStateMachine(int) - Constructor for class io.confluent.databalancer.operation.BalancerStatusStateMachine
 
BalancerStatusStateMachine(int, Time) - Constructor for class io.confluent.databalancer.operation.BalancerStatusStateMachine
 
BalancerStatusStateMachine.BalancerEvent - Enum in io.confluent.databalancer.operation
An #BalancerOperationEvent that can take place while balancer is starting up or running There are two more events - SBK_MISCONFIGURATION_CORRECTED and SBK_ENABLED that are related to dynamic configuration update, which will be handled separately in a follow up PR.
BalancerStatusStateMachine.BalancerState - Enum in io.confluent.databalancer.operation
All possible states of the balancer component.
balancerStatusTracker() - Method in class io.confluent.databalancer.EngineInitializationContext
 
balancerStatusTracker() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
BalancerStatusTracker - Class in io.confluent.databalancer.operation
This class encapsulates the logic of tracking and advancing the status of the balancer component of the cluster.
BalancerStatusTracker(int, AtomicReference<String>, Time) - Constructor for class io.confluent.databalancer.operation.BalancerStatusTracker
 
balanceUpperPercent() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
The upper limit of the balance threshold, usually representing a percentage within the range [0.0, 1.0] (0-100%) (with exception to KAFKALESS-761).
balanceUpperValueThreshold - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
balancingAction() - Method in enum com.linkedin.kafka.cruisecontrol.analyzer.ActionType
 
BalancingAction - Interface in com.linkedin.kafka.cruisecontrol.analyzer
Represents the load balancing operation over a replica or a partition for Kafka Load GoalOptimizer.
balancingAction() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
Get the type of action that provides balancing.
balancingAction() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
balancingAction() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
 
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
 
balancingConstraint - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
base(Load) - Method in class com.linkedin.kafka.cruisecontrol.model.Load.Builder
 
BaseDistributionGoalMetrics - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
A long-lived object managing the latest optimization run's resource distribution metrics for a given BaseDistributionGoalMetrics.goalName: BaseDistributionGoalMetrics.MAX_RESOURCE_METRIC_NAME - the highest resource usage of any single broker within the cluster during the optimization run.
BaseDistributionGoalMetrics(String, DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
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
 
BasicStats - Class in com.linkedin.kafka.cruisecontrol.monitor
 
basicStats - Variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
basicStats() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
BatchedConfigsFetcher - Class in com.linkedin.kafka.cruisecontrol.common
Because of ByteBuffer leak in Kafka which becomes bad when it returns a huge response, we need to batch DescribeConfigs request instead of sending it all in one shot.
BatchedConfigsFetcher.Builder - Class in com.linkedin.kafka.cruisecontrol.common
A builder class to make sure that BatchedConfigsFetcher is only created with params that make sense.
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
bootstrapServerEndpoint() - Method in class io.confluent.databalancer.EngineInitializationContext
 
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, Host, Cell, BrokerCapacityInfo, boolean, Broker.Strategy) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Broker
Constructor for Broker class.
broker(int) - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Get the broker with the given broker id.
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.monitor.SingleBrokerStats
 
Broker.ResourceComparator - Class in com.linkedin.kafka.cruisecontrol.model
Comparator that sorts brokers in decreasing order of available resource.
Broker.Strategy - Enum in com.linkedin.kafka.cruisecontrol.model
Denotes the strategy of how plan computation should take an existing broker into account.
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_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.config.KafkaCruiseControlConfig
broker.metric.sample.store.topic
BROKER_METRIC_SAMPLE_STORE_TOPIC_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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_REPLICA_EXCLUSION_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
The amount of time to block waiting for a broker replica exclusion operation to complete.
BROKER_REPLICA_EXCLUSION_TIMEOUT_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
BROKER_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
BROKER_STATE - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
BrokerAdditionCallback - Interface in com.linkedin.kafka.cruisecontrol.operation
This class helps track the progress of a single broker addition.
brokerAdditions - Variable in class io.confluent.databalancer.event.SbcListBrokerAdditionsEvent.SbcListBrokerAdditionsEventResult
 
brokerAdditions(ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<List<BrokerAdditionDescriptionInternal>>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
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_EXCLUSION_DETECTED BROKER_EXCLUSION_DETECTED | BROKER_REMOVAL_REQUEST_OVERRIDES | BROKER_REMOVAL_REQUEST_OVERRIDES BROKER_DEMOTION_DETECTED | | BROKER_DEMOTION_DETECTED | | +-------------+ +---------------+-------------+ 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(int, Time) - 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, SingleBrokerBalancerOperationProgressListener<BrokerAdditionStateMachine.BrokerAdditionState>, SingleBrokerBalancerOperationTerminationListener<BrokerAdditionStateMachine.BrokerAdditionState>, AtomicReference<String>, Time) - Constructor for class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
brokerAdditionStateMetricRegistrationHandler() - Method in class io.confluent.databalancer.EngineInitializationContext
 
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
 
BrokerByResourceUtilizationComparator - Class in com.linkedin.kafka.cruisecontrol.model.util
A factory that creates comparator which sorts the brokers by their resource utilization.
BrokerByResourceUtilizationComparator() - Constructor for class com.linkedin.kafka.cruisecontrol.model.util.BrokerByResourceUtilizationComparator
 
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.BrokerCapacityInfoBuilder - Class in com.linkedin.kafka.cruisecontrol.config
 
BrokerCapacityInfoBuilder() - Constructor for class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo.BrokerCapacityInfoBuilder
 
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
 
BrokerChangeEvent - Enum in io.confluent.databalancer
An enum representing different types of changes that can occur with a broker
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
 
BrokerExecutionTaskTracker - Class in com.linkedin.kafka.cruisecontrol.executor
A simple class to be used for tracking the number of ongoing partition movements for all brokers in the cluster, abstracted away from a simple Map.
BrokerExecutionTaskTracker(int) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
 
brokerFailureAlertThresholdMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
BrokerFailureDetector - Class in com.linkedin.kafka.cruisecontrol.detector
This class detects broker failures.
BrokerFailureDetector(KafkaCruiseControlConfig, Admin, LoadMonitor, Queue<Anomaly>, Time, KafkaCruiseControl, UpdatableSbcGoalsConfig, ApiStatePersistenceStore) - 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, GoalsConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
An anomaly to indicate broker failure(s).
brokerForRebalance - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerProposalLeaderboard.Result
 
brokerId - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
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 com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
 
brokerId() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaMetricSample
The id of the broker from which the metrics are from.
brokerId() - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
 
brokerId() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
brokerIds() - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 
brokerIds() - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
brokerIds() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
brokerIdsAboveBalanceUpperLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
brokerIdsUnderBalanceLowerLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
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) - 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
 
brokerMetricTypes() - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
BrokerProposalLeaderboard - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
 
BrokerProposalLeaderboard(int, int) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerProposalLeaderboard
 
BrokerProposalLeaderboard.Result - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
The final resulting leaderboard for this broker.
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.
BrokerRemovalCancellationProposal - Class in io.confluent.databalancer.operation
A class that encapsulates the circumstances of a BrokerRemoval cancellation proposal.
BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder - Class in io.confluent.databalancer.operation
Create a BrokerRemovalCancellationProposal.
BrokerRemovalCancellationProposalBuilder() - Constructor for class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
BrokerRemovalContext - Class in com.linkedin.kafka.cruisecontrol.operation
A mutable set of variables, for a broker removal operation, to be passed around each broker removal phase in #BrokerRemovalPhaseExecutor.
BrokerRemovalContext(Map<Integer, Optional<Long>>, boolean, BrokerRemovalCallback, String, PlanComputationOptions, OperationProgress) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
BrokerRemovalExclusionCancellationData - Class in io.confluent.databalancer.operation
Cancellation data for a BrokerRemovalCancellationProposal due to an exclusion request.
BrokerRemovalExclusionCancellationData(ExclusionOp.OpType, Set<Integer>) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalExclusionCancellationData
 
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(BrokerRemovalContext, CompletableFuture<Void>, CompletableFuture<Void>) - Constructor for class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalFuture
 
brokerRemovalFuture() - Method in class com.linkedin.kafka.cruisecontrol.statemachine.BrokerRemovalTask
 
brokerRemovalFuture(ImmutableSet<Integer>) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
brokerRemovalMetricRegistry() - Method in class io.confluent.databalancer.EngineInitializationContext
 
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
 
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
Returns the latest state for each broker being removed
brokerRemovals(ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<List<BrokerRemovalDescriptionInternal>>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
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/2097985596/Broker+Removal+v2+Multiple+Broker+Removal+With+Debarment+-+Kafka+1-pager An error (which usually moves to an XXX_FAILED state) is a failure that occurs while executing the actual removal (e.g.
BrokerRemovalStateMachine(Set<Integer>) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
BrokerRemovalStateMachine(Set<Integer>, BrokerRemovalStateMachine.BrokerRemovalState) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
BrokerRemovalStateMachine(Set<Integer>, BrokerRemovalStateMachine.BrokerRemovalState, Time) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
BrokerRemovalStateMachine.BrokerRemovalEvent - Enum in io.confluent.databalancer.operation
Events feeding into the BrokerRemovalStateMachine.
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(Set<Integer>, BrokerRemovalStateMachine.BrokerRemovalState, Exception, boolean) - Constructor for class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
BrokerRemovalStateRecordProtoSerde - Class in io.confluent.databalancer.persistence
Handle conversions between a BrokerRemovalStateRecord (what's in the ApiPersistenceStore) and BrokerRemovalStateRecordProto (the actual on-disk protobuf format).
BrokerRemovalStateRecordProtoSerde() - Constructor for class io.confluent.databalancer.persistence.BrokerRemovalStateRecordProtoSerde
 
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 operation state machine.
BrokerRemovalStateTracker(Set<Integer>, MultiBrokerBalancerOperationProgressListener<BrokerRemovalStateMachine.BrokerRemovalState>, MultiBrokerBalancerOperationTerminationListener<BrokerRemovalStateMachine.BrokerRemovalState>, AtomicReference<String>, Time) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
BrokerRemovalStateTracker(Set<Integer>, BrokerRemovalStateMachine.BrokerRemovalState, MultiBrokerBalancerOperationProgressListener<BrokerRemovalStateMachine.BrokerRemovalState>, MultiBrokerBalancerOperationTerminationListener<BrokerRemovalStateMachine.BrokerRemovalState>, AtomicReference<String>, Time) - Constructor for class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
BrokerRemovalTask - Class in com.linkedin.kafka.cruisecontrol.statemachine
 
BrokerRemovalTask(String, KafkaCruiseControl, KafkaCruiseControlContext, GoalsConfig, boolean, Map<Integer, Optional<Long>>, BalanceOpExecutionCompletionCallback, BrokerRemovalCallback) - Constructor for class com.linkedin.kafka.cruisecontrol.statemachine.BrokerRemovalTask
 
BrokerResourceMetric - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
Encapsulates the logic for a single, reusable metric BrokerResourceMetric.metricName which tracks a given BrokerResourceStats snapshot from the BrokerResourceMetric.goalName's optimization run.
BrokerResourceMetric.Builder - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
 
BrokerResourceStats - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A POJO containing a given broker's maximum capacity and current utilization absolute values for a resource.
BrokerResourceStats(double, double, int, Resource) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
BrokerResourceStats(double, double, int, ReplicaDistributionStatsSnapshot.ReplicaResource) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
BROKERS - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
 
brokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Get the collection of brokers in the current cell.
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.monitor.BrokerStats
 
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
brokersEligibleForRebalancing() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Returns set of brokers that are ineligible as source and destination.
brokersEligibleForRemoval - Variable in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent.EligibleBrokers
 
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() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
brokerShutdownManager(BrokerShutdownManager) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
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
 
BrokersMetadataSnapshot - Class in io.confluent.databalancer
A superset of AliveBrokersSnapshot and BrokerRegistration, exposing broker metadata information that both classes offer - like replica exclusions, listeners, epochs.
brokersNotOfStatesMatchingAttributes(Collection<Broker>, EnumSet<Broker.Strategy>, Map<String, String>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Returns a subset of brokerPool, such that the brokers in it have state that is NOT in the provided set of states, and their attributes are an exact match of the attributes in the provided attribute map.
brokersOfStatesMatchingAttributes(Collection<Broker>, EnumSet<Broker.Strategy>, Map<String, String>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Returns a subset of brokerPool, such that the brokers in it have state that is in the provided set of states, and their attributes are an exact match of the attributes in the provided attribute map.
brokersOverThreshold(Collection<Broker>, Resource, double) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
brokerStats(KafkaCruiseControlConfig) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get broker return the broker stats.
BrokerStats - Class in com.linkedin.kafka.cruisecontrol.monitor
Get broker level stats in human readable format.
BrokerStats(KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
brokerStats - Variable in class com.linkedin.kafka.cruisecontrol.monitor.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.IncrementalResourceDistributionGoal
Retrieves the brokers to be balanced sorted by their resource utilization in descending order.
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.SystemTopicEvenDistributionGoal
If new brokers are present, focus on those.
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.CellAwareGoal
 
brokersToBalance(ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
brokersToBalance(ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
brokersToRemove() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
brokersToRemove - Variable in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent
 
brokersToRemoveAndEpochs - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
brokersUnderCapacityLimit(Collection<Broker>, Resource, ClusterModel.CapacityLimitProvider) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
brokersUnderThreshold(Collection<Broker>, Resource, double) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
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.
brokersWithState(Broker.Strategy) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
brokerTaskCount(int) - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Indicate the number of tasks being tracked for a given broker ID.
build() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult.Builder
 
build(String) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Builder
 
build(String) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.DetailedReasonBuilder
 
build(SortedMap<String, String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BrokerResourceMetric.Builder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger.Builder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
 
build(BrokerEndPoint) - Method in class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient.Builder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
build(CloudAdmin) - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.Builder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo.BrokerCapacityInfoBuilder
 
build(KafkaCruiseControlConfig) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig.SbcGoalsConfigBuilder
Build a SbcGoalsConfig with a KafkaCruiseControlConfig that already has the associated goals configured.
build() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta.Builder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
build() - Method in class com.linkedin.kafka.cruisecontrol.model.Load.Builder
 
build(BrokerRemovalCallback, BrokerRemovalContext) - 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() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
build(StateMachineInitializer.InitializationMode) - Method in class io.confluent.databalancer.operation.StateMachineInitializer.Builder
buildAliveBrokerMetadata(ClusterImage, BrokerReplicaExclusionsImage) - Static method in class io.confluent.databalancer.DatabalancerUtils
Return an AliveBrokerSnapshot based on the supplied metadata images.
Builder() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult.Builder
 
builder(TopicPartition, int, double, ActionType) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
Creates a builder for a DetailedProposal.
Builder(String, String, DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BrokerResourceMetric.Builder
 
Builder(ProposalObservabilityTrackingOptions) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats.Builder
 
builder() - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger
 
Builder() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger.Builder
 
Builder() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
 
Builder(KafkaConfig, Time, String, LogContext) - Constructor for class com.linkedin.kafka.cruisecontrol.client.BlockingSendClient.Builder
 
Builder(KafkaCruiseControlConfig, Time, UpdatableSbcGoalsConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.common.MetadataClient.Builder
 
builder() - Static method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
builder() - Static method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
 
builder() - Static method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta
 
Builder() - Constructor for class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta.Builder
 
builder() - Static method in class com.linkedin.kafka.cruisecontrol.model.Load
 
Builder() - Constructor for class com.linkedin.kafka.cruisecontrol.model.Load.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_CONTRIBUTION_WEIGHT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
BYTES_IN_MIB - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
bytesIn() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
bytesOut() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
bytesOutRate - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
bytesOutRate() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 

C

cachedBrokerLoadStats(boolean) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cached load.
cachedPlaintextSelfHealingSummary() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.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
 
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.
canCancel() - Method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionEvent
 
canCancelRemoval() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalEvent
 
cancel(String) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalFuture
Attempt to cancel the broker removal operation future.
cancelBrokerRemoval(Set<Integer>, String) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
Cancels the on-going broker removal operations for the given #brokerIds
cancelBrokerRemoval(Set<Integer>, String) - Method in interface io.confluent.databalancer.DataBalanceEngine
Cancel the on-going broker removal operation for the given brokers #brokerIds
cancelBrokerRemoval(Set<Integer>, String) - 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
cancellationEvent() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
cancellationEvent - Variable in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
cancellationEvent() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
cancellationMode() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
cancellationMode - Variable in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
cancellationMode() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
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.CellAwareGoal
 
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(Map<Resource, Double>) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo.BrokerCapacityInfoBuilder
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
capacity(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the capacity of the broker based on the provided resource.
Capacity - Class in com.linkedin.kafka.cruisecontrol.model
Class to hold capacity information about an entity in the cluster model (like rack, broker, cell, host etc).
Capacity() - Constructor for class com.linkedin.kafka.cruisecontrol.model.Capacity
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Get capacity for the cell.
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
capacity() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
 
CAPACITY_BALANCING_DELTA_PERCENTAGE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
max.capacity.balancing.delta.percentage
CAPACITY_BALANCING_DELTA_PERCENTAGE_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
CAPACITY_BALANCING_DELTA_PERCENTAGE_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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
 
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.
CapacityGoalMetrics - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
A long-lived object managing the latest optimization run's capacity metrics for a given CapacityGoal.name(): CapacityGoalMetrics.NUM_HOT_PARTITIONS_METRIC_NAME - the number of partitions that utilize more than KafkaCruiseControlConfig.HOT_PARTITION_CAPACITY_UTILIZATION_THRESHOLD_CONFIG percentage of the capacity of a single broker, for the respective resource.
CapacityGoalMetrics(String, DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.CapacityGoalMetrics
 
capacityLimit(Capacity) - Method in interface com.linkedin.kafka.cruisecontrol.model.ClusterModel.CapacityLimitProvider
Compute the total amount of allowed capacity in the respective unit of the a resource (MiB, KB, etc.).
CapacityStatsSnapshot - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A snapshot (taken during a single capacity goal's optimization run), containing statistics of resource capacity in a cluster.
CapacityStatsSnapshot(double, Resource, int) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CapacityStatsSnapshot
 
capacityValue - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
CC_RUNNER_TASK_PROCESSING_TIME - Static variable in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
CC_RUNNER_TASKS_COUNT - Static variable in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
CC_STARTUP_RETRY_DELAY_MINUTES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
CC_STARTUP_RETRY_DURATION_HOURS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
ccStartupMode() - Method in enum io.confluent.databalancer.EngineInitializationContext.EngineStartupType
 
cell() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get broker's cell.
Cell - Class in com.linkedin.kafka.cruisecontrol.model
 
Cell(Integer) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Cell
Constructor of the cell class using the given id to identify the cell.
cell(Integer) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the cell with the cell id if it is found in the cluster; null otherwise.
cell() - Method in class com.linkedin.kafka.cruisecontrol.model.Tenant
Return the cell the tenant is assigned to.
CellAwareGoal - Class in io.confluent.cruisecontrol.analyzer.goals
 
CellAwareGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
 
cellBoundariesAreMet(ClusterModel, Set<String>) - Static method in class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
 
cellLoad(List<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Return the cell load of all cells in the cluster.
cellLoad(List<Integer>) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
Submit a cell load request to the CruiseControl layer.
cellLoad(List<Integer>) - Method in interface io.confluent.databalancer.DataBalanceEngine
 
cellLoad(List<Integer>) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
cellLoad(List<Integer>, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<CellLoadDescriptionInternal>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
cellLoadStats(Long, List<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the cell load of the cluster.
cellLoadStats(Long) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
cells() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
cellsById() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
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.
ChainReplicaFilter - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Provides a way to create an aggregate object full of filters of Replica objects.
ChainReplicaFilter(Predicate<Replica>...) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ChainReplicaFilter
 
changeObservership(ClusterModel, TopicPartition, int) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
changeObservership(TopicPartition, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Flips the given replica's observership
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 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.detector.ResourceUtilizationWindow
 
clear() - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Clear the task tracker.
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.Partition
Clear the leader to null and clear followers.
clear() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
 
clear() - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Clears all the goal optimization history.
clear() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
clearAllResourcesAndWaiters() - Method in interface io.confluent.databalancer.event.resource.BalancerResourceManager
Clear all resource values and events waiting on resources.
clearAllResourcesAndWaiters() - Method in class io.confluent.databalancer.event.resource.SbcResourceManager
Forget about all current resource values and resource waiters.
clearGoalOptimizationHistory() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Reset the goal optimization history.
clearLongLivedMetric(Class<?>, String) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
clearShortLivedMetric(Class<?>, String, Map<String, 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
clone(String, Object) - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Returns a clone of the Config with one parameter modified
clone(Map<String, Object>) - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Returns a clone of the Config with the given parameters modified
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(boolean) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorMetricsHandle
Takes care of necessary post facto steps involving the load monitor after the executor finishes its execution.
close() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorMetricsHandle
Takes care of necessary post facto steps involving the load monitor after the executor finishes its execution.
close() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorReservationHandle
 
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.NoopSampler
 
close() - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Close method is called when SBC is disabled, so that we don't leave the two cleaner threads alone.
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
 
closeSilently(AutoCloseable) - 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.ClusterMetadata
 
CLUSTER_GENERATION_ACCEPTABLE_STALENESS_LAG - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
CLUSTER_IMAGE - Static variable in class io.confluent.databalancer.event.resource.SbcResources
 
clusterAndGeneration() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Get the current cluster and generation
ClusterAndGeneration(MetadataClient.ClusterMetadata, int) - Constructor for class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
clusterGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
clusterHasEligibleDestinationBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Checks if cluster has at least one rack eligible as a destination for replica placement.
clusterId() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
The current cluster id.
ClusterMetadata(Cluster, Optional<Map<String, TopicPlacement>>, Map<Integer, String>, Set<TopicPartition>, Set<Tenant>, Map<Integer, List<String>>) - Constructor for class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
 
ClusterModel - Class in com.linkedin.kafka.cruisecontrol.model
A class that holds the information of the cluster, including topology, liveliness 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.CapacityLimitProvider - Interface in com.linkedin.kafka.cruisecontrol.model
A simple call-able interface to provide the capacity limit - total amount of allowed capacity in the respective unit of a given resource (MiB, KB, etc.).
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.IncrementalResourceDistributionGoal
 
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.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.ResourceDistributionAbstractGoal
 
clusterModelCompletenessRequirements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
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.CellAwareGoal
 
clusterModelCompletenessRequirements() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
clusterModelCompletenessRequirements() - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
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
 
ClusterModelStats() - Constructor for class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Constructor for analysis stats.
ClusterModelStatsByResourceUtilizationDeviationComparator - Class in com.linkedin.kafka.cruisecontrol.model.util
Compares ClusterModelStats by resource utilization deviation.
ClusterModelStatsByResourceUtilizationDeviationComparator(String, Resource) - Constructor for class com.linkedin.kafka.cruisecontrol.model.util.ClusterModelStatsByResourceUtilizationDeviationComparator
 
clusterModelStatsComparator() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
Get an instance of ClusterModelStatsComparator for this goal.
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.ReplicaDistributionGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
clusterModelStatsComparator() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
ClusterModelStatsComparator - Interface in com.linkedin.kafka.cruisecontrol.model.util
A comparator that compares two cluster model stats.
clusterModelStatsComparatorByGoalName() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
clusterStatsByGoalName() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
clusterUtilizationAverage(ClusterModel, Resource) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils
Computes the average utilization of the cluster for a given resource.
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.analyzer.goals.metrics - package com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
 
com.linkedin.kafka.cruisecontrol.analyzer.goals.util - package com.linkedin.kafka.cruisecontrol.analyzer.goals.util
 
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.model.util - package com.linkedin.kafka.cruisecontrol.model.util
 
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.statemachine - package com.linkedin.kafka.cruisecontrol.statemachine
 
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
 
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(Broker, Broker) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker.ResourceComparator
 
compare(ClusterModelStats, ClusterModelStats) - Method in class com.linkedin.kafka.cruisecontrol.model.util.ClusterModelStatsByResourceUtilizationDeviationComparator
Compare the ClusterModelStats after and before optimization.
compare(ClusterModelStats, ClusterModelStats) - Method in interface com.linkedin.kafka.cruisecontrol.model.util.ClusterModelStatsComparator
Compare two cluster model stats and determine which stats is preferred.
compare(ClusterModelStats, ClusterModelStats) - Method in class com.linkedin.kafka.cruisecontrol.model.util.NoopClusterModelStatsComparator
 
compare(Replica, Replica) - Method in class com.linkedin.kafka.cruisecontrol.model.util.ReplicaByResourceUtilizationComparator
 
compareTo(CandidateBroker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
compareTo(DetailedProposal) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
compareTo(DetailedProposal.Result) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
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
 
compareTo(TopicPartitionHistory) - Method in interface io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistory
Each TopicPartitionHistory is a comparable object, representing a certain history fact of a TopicPartition.
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<E>, Set<Integer>) - 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(long, long, AggregationOptions<E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Override of MetricSampleAggregator.completeness(long, long, AggregationOptions, Set) passes empty set of failed brokers to original method.
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(BrokerRemovalContext, BrokerRemovalCallback, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>, BrokerRemovalPhase<Void>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhaseBuilder
Returns all the phases chained together in a #CompletableFuture object.
computationUtils() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
computationUtils(PlanComputationUtils) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
compute(OptimizationOptions, BalancingConstraint, double, double) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
Computes the maximum and minimum number of replicas a broker should have, over which distribution goals will attempt to move replicas out of / into the broker in order to achieve balance.
compute(ClusterModel, OptimizationOptions, BalancingConstraint, Resource, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
Computes the low utilization, lower limit and upper limit thresholds based on which a distribution goal will decide whether to move resources.
compute(DistributionThresholdUtils.ReplicaThresholds, List<BrokerResourceStats>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ReplicaDistributionStatsSnapshot
 
compute() - Method in interface com.linkedin.kafka.cruisecontrol.plan.PlanComputable
Compute a reassignment plan
computeDrainBrokersPlan(Set<Integer>, GoalsConfig, OperationProgress, PlanComputationOptions, KafkaCruiseControlContext) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Computes a plan to drain all of the partition replicas off of #removedBrokers
computeEvenClusterLoadPlan(String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Computes and returns an even cluster load plan without executing it.
computeEvenClusterLoadPlan(String, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadPlanInternal>) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
computeEvenClusterLoadPlan(String, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadPlanInternal>) - Method in interface io.confluent.databalancer.DataBalanceEngine
Computes and returns an even cluster load plan without executing it.
computeEvenClusterLoadPlan(ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadPlanInternal>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
computeEvenClusterLoadPlan(String, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadPlanInternal>) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
computeEvenClusterLoadPlan(ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadPlanInternal>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
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 - Variable in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.Builder
 
config() - Method in class com.linkedin.kafka.cruisecontrol.config.UpdatableSbcGoalsConfig
 
config() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
config(KafkaCruiseControlConfig) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
config() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
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
 
ConfigFetchErrorHandler - Interface in com.linkedin.kafka.cruisecontrol
Functional interface to allow custom handling of the errors thrown when AdminClient::describeConfigs throws an error.
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
CONFIGS_IMAGE - Static variable in class io.confluent.databalancer.event.resource.SbcResources
 
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.IncrementalCPUResourceDistributionGoal
 
configure(Map<String, ?>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
 
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.NoopSampler
 
configure(Map<String, ?>) - Method in class io.confluent.cruisecontrol.analyzer.goals.MaxReplicaMovementParallelismGoal
 
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 to CruiseControl and vice versa - 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
consume(String, T, TelemetryConverter.DataPoint) - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.MetricConsumer
 
consume(String, T, TelemetryConverter.Summary) - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.MetricConsumer
 
contains(Object) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
containsAll(Collection<?>) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
containsAny(Set<Integer>, Set<Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Check if set a contains any element in set b.
containsBroker(int) - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
 
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.
context() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
controller() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
The current controller id.
convert(byte[], TelemetryConverter.MetricConsumer<T>) - Method in class io.confluent.cruisecontrol.metricsreporter.OpenCensusConverter
 
convert(byte[], TelemetryConverter.MetricConsumer<T>) - Method in class io.confluent.cruisecontrol.metricsreporter.OpenTelemetryConverter
 
convert(byte[], TelemetryConverter.MetricConsumer<T>) - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter
de-serializes the raw telemetry wire-format (e.g.
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.
convertEmptyToNull(String) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
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
This is performance sensitive code due to SBC consuming partition granularity metrics for disk usage.
convertToString(Object, ConfigDef.Type) - Static method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
count() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.Summary
 
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
CPU_PCT - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
CPU_UTILIZATION_DETECTOR_DURATION_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
CPU_UTILIZATION_DETECTOR_OVERUTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
CPU_UTILIZATION_DETECTOR_UNDERUTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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.
cpuUtil - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
cpuUtil() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
CpuUtilizationDetector - Class in com.linkedin.kafka.cruisecontrol.detector
Monitors CPU utilization of the cluster and raises an Alert if the cluster is deemed to be underutilized or overutilized based on heuristics.
CpuUtilizationDetector(KafkaCruiseControlConfig, Time, DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.CpuUtilizationDetector
 
create(KafkaCruiseControlConfig) - Static method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Creates a GoalOptimizationHistory with given Kafka cruise control configuration.
createAdmin(Map<String, ?>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Create an instance of ConfluentAdmin using the given configurations.
createBroker(String, Integer, String, int, BrokerCapacityInfo, boolean, Broker.Strategy) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Create a broker under this cluster/rack and get the created broker.
createBroker(String, String, int, BrokerCapacityInfo, boolean, Broker.Strategy) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
createCellIfAbsent(Optional<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Create a cell under this cluster.
createClusterModel(long, ModelCompletenessRequirements, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
createClusterModel(long, ModelCompletenessRequirements, OperationProgress, Map<Integer, Broker.Strategy>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cluster load model for a time range from the oldest window index to the end of the time window #to.
createClusterModel(long, ModelCompletenessRequirements, boolean, OperationProgress) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
createClusterModel(long, ModelCompletenessRequirements, boolean, OperationProgress, Map<Integer, Broker.Strategy>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Get the cluster load model for a time range from the oldest window index to the end of the time window #to.
createConsumerForMetricTopic(Properties, String) - Static method in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
createKafkaCruiseControl(Semaphore) - Method in class io.confluent.databalancer.startup.CruiseControlStartable
Checks and initiates the necessary components for starting up the Kafka Cruise Control (#KafkaCruiseControl object and returns an instance of it
createOrDeleteReplicas(Map<Short, Set<String>>, Map<String, List<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.
createRackIfAbsent(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.
createStartupRetryer() - Method in class io.confluent.databalancer.startup.CruiseControlStartable
Creates a OperationRetryer to help startup SBC.
createTime() - Method in class io.confluent.databalancer.operation.StateMachine
 
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, KafkaCruiseControlConfig) - 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(ConfluentDataBalanceEngineContext, EngineInitializationContext) - Constructor for class io.confluent.databalancer.startup.CruiseControlStartable
Creates CruiseControlStartable, the cruise control and configuration factory.
CruiseControlUtils - Class in com.linkedin.cruisecontrol
Utils class for Cruise Control
currentOfflineReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get current offline replicas -- i.e.
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.BalancerStatusTracker
 
currentState() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
currentState() - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
 
currentState() - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
Returns null, if self-healing is disabled and no rebalance is run yet.
currentState - Variable in class io.confluent.databalancer.operation.StateMachine
 
currentState() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
currentStateCreatedAt() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
currentStateException() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
currentStateLastUpdatedAt() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
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) - Constructor for class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
DataBalancerMetricsRegistry(MetricsRegistry, Set<String>) - Constructor for class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
DatabalancerUtils - Class in io.confluent.databalancer
 
DatabalancerUtils() - Constructor for class io.confluent.databalancer.DatabalancerUtils
 
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
 
DEAD_BROKER_CAPACITY - Static variable in class com.linkedin.kafka.cruisecontrol.model.Broker
 
DEAD_BROKER_UTILIZATION - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
 
DEAD_BROKERS_CELL_ID - Static variable in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
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.
deadlineMs() - Method in class io.confluent.cruisecontrol.analyzer.history.AbstractTopicPartitionHistory
 
deadlineMs() - Method in interface io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistory
Retrieves the deadline after which the history item expires.
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_REPLICA_EXCLUSION_TIMEOUT_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BROKER_SAMPLE_STORE_TOPIC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_BYTES_CONTRIBUTION_WEIGHT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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_CELL_ID - Static variable in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
DEFAULT_CPU_BALANCE_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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_BROKER_REPLICA_EXCLUSION_TIMEOUT_MS - 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_CONFIGS_BATCH_SIZE - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_DESCRIBE_CONFIGS_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_BALANCE_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_DISK_CAPACITY_MIN_FREE_SPACE - 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_CLIENT_TIMEOUT_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_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_BALANCE_THRESHOLD - 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_BALANCE_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_PARTITION_METRICS_WINDOW_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_PARTITION_SAMPLE_STORE_TOPIC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_PRODUCER_INBOUND_CAPACITY_THRESHOLD - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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_REQUEST_CONTRIBUTION_WEIGHT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_RESOURCE_UTILIZATION_DETECTOR_INTERVAL_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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_TOPIC_PARTITION_MAXIMUM_MOVEMENTS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_TOPIC_PARTITION_MOVEMENT_EXPIRATION_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_TOPIC_PARTITION_SUSPENSION_MS - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DEFAULT_WRITE_THROUGHPUT_MULTIPLIER - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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
 
defaultPlanComputationOptions() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
defaultPlanComputationOptions(PlanComputationOptions) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
defaultStartState() - Method in class io.confluent.databalancer.operation.StateMachineInitializer
Return the state at which the #StateMachine should start at
defaultValue - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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(KafkaMetricDef) - 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.
degradedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
degradedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
 
delay() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
deleteExpiredValues(long, int) - Method in class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
Delete values that are older than durationMs
deleteReplica(TopicPartition, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Delete a replica from cluster.
deleteTopics(ConfluentAdmin, Set<String>, List<String>) - Static method in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils
Delete the topics to be deleted after verifying their existence.
demotedBrokers() - Method in class io.confluent.databalancer.BrokersMetadataSnapshot
Returns the demoted brokers in the cluster.
demotedBrokers - Variable in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
demotedBrokers() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
dependents - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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.
DESCRIBE_BROKER_REPLICA_EXCLUSION_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
The amount of time to block waiting for a broker replica exclusion operation to complete.
DESCRIBE_BROKER_REPLICA_EXCLUSION_TIMEOUT_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DESCRIBE_CLUSTER_RESPONSE_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
describe.cluster.response.timeout.ms
DESCRIBE_CONFIGS_BATCH_SIZE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DESCRIBE_CONFIGS_RESPONSE_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
describe.configs.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(int) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Describes the Kafka cluster, listing all the online brokers.
describeCurrentlyExcludedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
List brokers with replica exclusions (for any reason)
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
 
deserialize(String, byte[]) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
deserialize(RemoveBroker.BrokerRemovalStateRecordProto) - Static method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecordProtoSerde
 
deserialize(RemoveBroker.RemovalState) - Static method in class io.confluent.databalancer.persistence.BrokerRemovalStateSerializer
 
deserialize(EvenClusterLoad.EvenClusterLoadState) - Static method in class io.confluent.databalancer.persistence.EvenClusterLoadStateSerializer
 
desiredCapacityForBroker(Resource, Capacity) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the total amount of desired capacity for one broker, in the respective unit of the given Resource (MiB, KB, etc.).
desiredIncrementalImprovementPercent(int) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.IncrementalResourceDistributionStatsSnapshot
The incremental balancing threshold of the brokerId, denoting the percentage amount of a given resource we want to move for this broker.
destinationBroker() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
 
destinationBrokerId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the destination broker Id.
destinationBrokerLogdir() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the destination broker logdir.
destinationTopic() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get topic name of the replica to swap with at the destination.
destinationTopicPartition() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the destination topic partition to swap with.
DetailedProposal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A class to hold information surrounding a proposal.
DetailedProposal(TopicPartition, int, double, ActionType, String) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
DetailedProposal.Builder - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
 
DetailedProposal.DetailedReasonBuilder - Interface in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A callable interface for constructing a detailed reason string.
DetailedProposal.Result - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
The result of a DetailedProposal that was generated.
detectionMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
detectResourceUtilization(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.detector.CpuUtilizationDetector
 
detectResourceUtilization(ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.detector.DiskUtilizationDetector
 
detectResourceUtilization(ClusterModel) - Method in interface com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationDetector
 
detectViolations() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolationDetector
Goes through each goal and tries to optimize the cluster model in order to understand if there are any goal violations present.
DISABLED - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalObservabilityTrackingOptions
 
DISABLED_THROTTLE - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
discardIrrelevantAndCacheText() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
Update plaintext response and discards the optimizer result in order to avoid memory pressure.
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_MIN_FREE_SPACE_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Disk capacity: disk.min.free.space.gb
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_MB - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
DISK_PCT - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
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.monitor.SingleBrokerStats
 
DISK_UTILIZATION_DETECTOR_DURATION_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DISK_UTILIZATION_DETECTOR_OVERUTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DISK_UTILIZATION_DETECTOR_RESERVED_CAPACITY_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
DISK_UTILIZATION_DETECTOR_UNDERUTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
diskCapacity - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
diskCapacity() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
diskCapacityByLogDir(Map<String, Double>) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo.BrokerCapacityInfoBuilder
 
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 - Variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
diskStatsByLogdir() - Method in class com.linkedin.kafka.cruisecontrol.monitor.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.
diskUtil - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
diskUtil() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
DiskUtilizationDetector - Class in com.linkedin.kafka.cruisecontrol.detector
Class that monitors disk utilization and raises underutilization/overutilization alerts when appropriate.
DiskUtilizationDetector(KafkaCruiseControlConfig, Time, DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.DiskUtilizationDetector
 
DiskUtilizationDetectorConfig - Class in com.linkedin.kafka.cruisecontrol.config
Wrapper class for storing DiskUtilizationDetector configs
DiskUtilizationDetectorConfig(int, double, double, double) - Constructor for class com.linkedin.kafka.cruisecontrol.config.DiskUtilizationDetectorConfig
 
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;
diskUtilPct() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
displayName - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
DistributionThresholdUtils - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Utilities to help compute the particular balance thresholds for different distribution-type goals (e.g ResourceDistributionGoal, ReplicaDistributionAbstractGoal)
DistributionThresholdUtils() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils
 
DistributionThresholdUtils.ReplicaThresholds - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
A POJO that holds particular thresholds related to the balanced distribution of number of replicas.
DistributionThresholdUtils.ResourcePercentageThresholds - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
A POJO that holds particular thresholds related to the balance of particular Resource distribution, in percentages.
doBalance() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.RebalanceStep
Moves replica around to satisfy the goal.
documentation - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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.
doRebalance(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
(1) REBALANCE BY REPLICA MOVEMENT: Perform optimization via replica movement for the given resource (without breaking the balance for already balanced resources) to ensure rebalance: The load on brokers for the given resource is under the balance limit.
doRebalance(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
Performs the rebalance proposal generation.
doRebalance(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.
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.
drainInterBrokerReplicaMovementTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns a list of execution tasks that move the replicas cross brokers.
drainInterBrokerTasks(BrokerExecutionTaskTracker, Set<TopicPartition>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Drains a chunk of executable inter-broker replica movements away that comply with the concurrency constraint.
drainIntraBrokerTasks(BrokerExecutionTaskTracker) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Drains a chunk of executable intra-broker replica movements that comply with the concurrency constraint.
dropRecentlyRemovedBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Drop the given brokers from the recently removed brokers.
duplicate(BrokerExecutionTaskTracker) - Static method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
 

E

effectiveCapacity - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CapacityStatsSnapshot
 
effectiveRebalancingGoals() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
Return goals that will be used to balance the cluster based on if incremental balancing is enabled or not.
effectiveTriggeringGoals() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
Return goals that will be used to check goal violation based on if incremental balancing is enabled or not.
eligibleBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
 
EligibleBrokers(List<Integer>, List<Integer>) - Constructor for class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent.EligibleBrokers
 
eligibleBrokersReplicaMove(ClusterModel, Resource) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Get a list of sorted (in ascending order by resource) eligible destination brokers having utilization under: (given utilization threshold) * (broker and/or host capacity (see Resource#isHostResource and Resource#isBrokerResource).
eligibleDestinationBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of eligible destination brokers in the cluster.
eligibleDestinationCapacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Capacity
 
eligibleDestinationCapacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
eligibleDestinationUtilization() - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
eligibleSourceAndDestinationBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of brokers in the cluster which are simultaneously eligible sources *and* destinations.
eligibleSourceBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of eligible source brokers in the cluster.
eligibleSourceCapacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Capacity
 
eligibleSourceOrDestinationBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the set of brokers in the cluster which are eligible sources and/or eligible destinations.
eligibleSourceUtilization() - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
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
 
endpointFor(ListenerName) - Method in class io.confluent.databalancer.BrokersMetadataSnapshot
 
endTime() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
EngineInitializationContext - Class in io.confluent.databalancer
 
EngineInitializationContext(KafkaConfig, EngineInitializationContext.EngineStartupType, Optional<AliveBrokersMetadata>, KafkaDataBalanceManager.BrokerRemovalMetricRegistry, Function<Integer, AtomicReference<String>>, BalancerStatusTracker) - Constructor for class io.confluent.databalancer.EngineInitializationContext
 
EngineInitializationContext(KafkaConfig, Optional<Endpoint>, EngineInitializationContext.EngineStartupType, Optional<AliveBrokersMetadata>, KafkaDataBalanceManager.BrokerRemovalMetricRegistry, Function<Integer, AtomicReference<String>>, BalancerStatusTracker) - Constructor for class io.confluent.databalancer.EngineInitializationContext
 
EngineInitializationContext.EngineStartupType - Enum in io.confluent.databalancer
 
engineStartupType() - Method in class io.confluent.databalancer.EngineInitializationContext
 
enqueue(SbcEvent) - Method in class io.confluent.databalancer.event.SbcEventQueue
Enqueue an event for processing on the EventQueue thread.
ensureConstraintsAreMet(GoalConstraints, ClusterModel, Set<String>) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
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.
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.
entities(Collection<String>) - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
Entity - Class in com.linkedin.cruisecontrol.model
The abstract class for an entity.
Entity() - Constructor for class com.linkedin.cruisecontrol.model.Entity
 
entity - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
entity() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
Get the entity this metric sample is corresponding to.
entity(String) - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
EntityCombinator - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Class to generate all combination of entities from groups of entities it is initialized with.
EntityCombinator() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.EntityCombinator
 
EntityFilter<T> - Interface in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
epoch() - Method in class io.confluent.cruisecontrol.analyzer.history.AbstractTopicPartitionHistory
 
epoch() - Method in interface io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistory
Retrieves the epoch of the history item.
epoch() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
Retrieves current epoch.
epochFor(int) - Method in class io.confluent.databalancer.BrokersMetadataSnapshot
Returns the broker epoch for the broker with ID brokerId.
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.GoalOptimizationHistoryOptions
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
 
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.BrokerResourceStats
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Compare the given object with this object.
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
equals(Object) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta
 
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.Cell
 
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.model.Tenant
 
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 com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
 
equals(Object) - Method in class io.confluent.databalancer.BalancerEnabledConfig
 
equals(Object) - Method in class io.confluent.databalancer.event.resource.SbcResource
 
equals(Object) - Method in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent.EligibleBrokers
 
equals(Object) - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
equals(Object) - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
equals(Object) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
errorHandler(ConfigFetchErrorHandler) - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
errorMessages() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
estimateCpuUtil(double, double, double, double, double, 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].
estimationInfo(String) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo.BrokerCapacityInfoBuilder
 
estimationInfo() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
EvenClusterLoadStateMachine - Class in io.confluent.databalancer.operation
State machine to capture current running state of "even cluster load" rebalance operation triggered by GoalViolationDetector.
EvenClusterLoadStateMachine(int, Time) - Constructor for class io.confluent.databalancer.operation.EvenClusterLoadStateMachine
 
EvenClusterLoadStateMachine(int, EvenClusterLoadStateMachine.EvenClusterLoadState, Time) - Constructor for class io.confluent.databalancer.operation.EvenClusterLoadStateMachine
 
EvenClusterLoadStateMachine(int, EvenClusterLoadStateMachine.EvenClusterLoadState, long, long, Time, Exception) - Constructor for class io.confluent.databalancer.operation.EvenClusterLoadStateMachine
Used when restoring a state machine from persisted state.
EvenClusterLoadStateMachine.EvenClusterLoadEvent - Enum in io.confluent.databalancer.operation
 
EvenClusterLoadStateMachine.EvenClusterLoadState - Enum in io.confluent.databalancer.operation
All possible states of the even cluster load component.
evenClusterLoadStateManager() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
Returns instance of EvenClusterLoadStateManager used in registering events to the even cluster load state machine.
EvenClusterLoadStateManager - Class in io.confluent.databalancer.operation
This class manages both current rebalance state and one-before-current rebalance (called previous) run of "any uneven load" goal violation.
EvenClusterLoadStateManager(int, Time, ApiStatePersistenceStore, boolean) - Constructor for class io.confluent.databalancer.operation.EvenClusterLoadStateManager
 
evenClusterLoadStateManagers(EvenClusterLoadStateManager) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
Sets instances of EvenClusterLoadStateManager created in AnomalyDetector to handle requests when self healing is enabled/disabled for GOAL_VIOLATION anomaly type.
EvenClusterLoadStateProgressListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for listener for the progress of the balancer operation - EvenClusterLoad
EvenClusterLoadStateRecord - Class in io.confluent.databalancer.persistence
An internal, persisted representation of a EvenClusterLoad operation state.
EvenClusterLoadStateRecord(EvenClusterLoadStateMachine.EvenClusterLoadState, Long, Long, Exception, EvenClusterLoadStateMachine.EvenClusterLoadState, Long, Long, Exception) - Constructor for class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
EvenClusterLoadStateSerializer - Class in io.confluent.databalancer.persistence
A simple helper to serialize #EvenClusterLoadStateMachine.EvenClusterLoadState
EvenClusterLoadStateSerializer() - Constructor for class io.confluent.databalancer.persistence.EvenClusterLoadStateSerializer
 
evenClusterLoadStatus(KafkaConfig) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
evenClusterLoadStatus(KafkaConfig) - Method in interface io.confluent.databalancer.DataBalanceEngine
Return status of the goal violation detector triggered self balancing.
evenClusterLoadStatus() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
evenClusterLoadStatus(KafkaConfig) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
evenClusterLoadStatus(ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadStatusDescriptionInternal>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
evenClusterLoadStatusDescription(boolean) - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
 
evenLoadBalancingError() - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateMachine
 
evenLoadBalancingError(Exception) - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateMachine
 
eventContext - Variable in class io.confluent.databalancer.event.SbcEvent
 
eventException - Variable in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
eventException() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
eventQueue() - Method in class io.confluent.databalancer.SbcContext
 
eventWaiters(SbcResource<?>) - Method in class io.confluent.databalancer.event.resource.SbcResourceManager
Access the list of events waiting on an SbcResource.
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.BalancerStatusTracker
 
exception() - Method in class io.confluent.databalancer.operation.BrokerAdditionStateManager
 
exception() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
excludedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Returns the set of broker ids that have replica exclusions placed on them (i.e are excluded from having new replicas placed on them)
excludedBrokersForLeadership(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
Set the brokers that will be excluded for leadership moves.
excludedBrokersForLeadership() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
excludedBrokersForLeadership() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
excludedBrokersForReplicaMove(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
Set the brokers that will be excluded for replica moves.
excludedBrokersForReplicaMove() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
excludedBrokersForReplicaMove() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
excludedTopics(Set<String>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
Set the topics that will be excluded for optimization.
excludedTopics() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
excludedTopics() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
excludedTopicsPattern() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
Return the regex pattern used to match excluded topics.
exclusionData() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
EXCLUSIONS_IMAGE - Static variable in class io.confluent.databalancer.event.resource.SbcResources
 
execute(T) - Method in interface com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils.MaybeThrowingConsumer
 
execute(Duration) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalFuture
Executes the broker removal
execute(BrokerRemovalContext) - 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(BrokerRemovalContext) - 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.
executeOptimizationsOverHardProposals() - Method in class com.linkedin.kafka.cruisecontrol.config.GoalsConfig
Signals if the execution of soft goals following the execution of hard goals that have generated proposals should happen.
executeProposals(Collection<ExecutionProposal>, Set<Integer>, Set<Integer>, LoadMonitor, String, BalanceOpExecutionCompletionCallback) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Initialize proposal execution and start execution.
executeRemoval(Set<ExecutionProposal>, Set<Integer>, String, BalanceOpExecutionCompletionCallback, KafkaCruiseControlContext) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Execute the given balancing proposals for remove operations.
executeSilently(T, KafkaCruiseControlUtils.MaybeThrowingConsumer<T>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Execute an action to close/shutdown a resource silently by ignoring any exception that is thrown.
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
 
ExecutionMetricsReporter - Class in com.linkedin.kafka.cruisecontrol.executor
This class aims at encapsulating all execution related metrics to achieve the following: - single stop for checking what kind of metrics are available and how they are calculated.
ExecutionMetricsReporter(DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
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>) - 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
The state of a balancing proposal.
ExecutionTask.TaskType - Enum in com.linkedin.kafka.cruisecontrol.executor
 
ExecutionTaskGenerationIdUtils - Class in com.linkedin.kafka.cruisecontrol.executor
 
ExecutionTaskGenerationIdUtils() - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskGenerationIdUtils
 
executionTaskManager - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
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, Time, DataBalancerMetricsRegistry, MetadataClient, long, ExecutorNotifier, AnomalyDetector, ConfluentAdmin, ReplicationThrottleHelper) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.Executor
Package private for unit testing.
executor() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
executor(Executor) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
Executor.ExecutionTaskWaiter - Interface in com.linkedin.kafka.cruisecontrol.executor
 
Executor.PartitionReplicas - Class in com.linkedin.kafka.cruisecontrol.executor
 
EXECUTOR_NOTIFIER_CLASS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
EXECUTOR_REFRESH_TIME_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
EXECUTOR_REFRESH_TIME_MS_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
EXECUTOR_REFRESH_TIME_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
executorFuture(Future<?>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
executorFuture() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
Executor future is only present once Executor initiates rebalance plan execution.
ExecutorInterBrokerReplicaMovement - Class in com.linkedin.kafka.cruisecontrol.executor
An abstraction over the inter-broker replica movements that are done as part of an Executor execution.
ExecutorInterBrokerReplicaMovement(String, ExecutionTaskManager, Set<Integer>, ReplicationThrottleHelper, ConfluentAdmin, SbkAdminUtils, AtomicBoolean, Set<Integer>, LoadMonitor, Cluster, Time, long) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorInterBrokerReplicaMovement
 
ExecutorIntraBrokerReplicaMovement - Class in com.linkedin.kafka.cruisecontrol.executor
An abstraction over the intra-broker replica movements that are done as part of an Executor execution.
ExecutorIntraBrokerReplicaMovement(String, ExecutionTaskManager, Set<Integer>, ReplicationThrottleHelper, ConfluentAdmin, SbkAdminUtils, AtomicBoolean) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorIntraBrokerReplicaMovement
 
executorIsReserved() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
ExecutorLeadershipReplicaMovement - Class in com.linkedin.kafka.cruisecontrol.executor
An abstraction over the leadership movements that are done as part of an Executor execution.
ExecutorLeadershipReplicaMovement(String, ExecutionTaskManager, Set<Integer>, ReplicationThrottleHelper, ConfluentAdmin, SbkAdminUtils, AtomicBoolean) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorLeadershipReplicaMovement
 
ExecutorMetricsHandle - Class in com.linkedin.kafka.cruisecontrol.executor
Takes care of metrics sampling pre and post the proposals execution starts.
ExecutorMetricsHandle(LoadMonitor, String) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorMetricsHandle
 
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.
ExecutorReservationHandle - Class in com.linkedin.kafka.cruisecontrol.executor
A helper auto closeable class for acquiring the Executor's reservation.
ExecutorReservationHandle(Executor, Time) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.ExecutorReservationHandle
Acquires the Executor's reservation
ExecutorState - Class in com.linkedin.kafka.cruisecontrol.executor
 
ExecutorState.State - Enum in com.linkedin.kafka.cruisecontrol.executor
 
expandArrayFromTheBeginning(double[], int) - Static method in class com.linkedin.cruisecontrol.common.utils.Utils
Given an input array and wanted size, it extends the length of the array by filling up values of 0 in the beginning of the array.
expectedCellForTenant(ClusterModel, String) - Static method in class io.confluent.databalancer.DatabalancerUtils
Returns cell a tenant partitions are supposed to be in.
expectedUtilizationFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Load
 
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.
expectedUtilizationInEligibleSourceBrokersFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
explainLastComparison() - Method in class com.linkedin.kafka.cruisecontrol.model.util.ClusterModelStatsByResourceUtilizationDeviationComparator
 
explainLastComparison() - Method in interface com.linkedin.kafka.cruisecontrol.model.util.ClusterModelStatsComparator
This is a method to get the reason for the last comparison.
explainLastComparison() - Method in class com.linkedin.kafka.cruisecontrol.model.util.NoopClusterModelStatsComparator
 
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.BrokerFailureDetector
Package-private for testing This function is not thread-safe and should not be used otherwise.
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) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
Fetch the partition metric samples for a given period.
fetchSbcClusterSnapshot(Collection<String>) - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Provides SbcClusterSnapshot containing the latest snapshot of the topics and nodes in the cluster.
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
 
filterEntities(Set<Replica>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ChainReplicaFilter
Filters out replicas from the provided set based on the registered filters.
filterEntities(Set<T>) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.EntityFilter
Filter entities out of the provided set by modifying it in place.
filterEntities(Set<Replica>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NoOpReplicaFilter
This operation is a NoOp.
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.
filterReplicas(Broker, boolean, boolean, boolean, EntityFilter<Replica>) - 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.internals.BrokerProposalLeaderboard
Drains the leaderboard and returns the result.
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard
Drains the underlying leaderboards
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.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.ResourceDistributionAbstractGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
finish() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
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.CellAwareGoal
 
finish() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
finish() - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
finished - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
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
 
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
 
fixBrokerFailures(Set<Integer>, GoalsConfig, 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.
FIXED - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
 
fixOfflineReplicasOnly - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
fixOfflineReplicasOnly - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
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
FOLLOWER_NW_IN_RATE - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
followerBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that followers reside in.
followerBytesInRate - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
followerBytesInRate() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
followers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get follower replicas.
followUpEvents() - Method in class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
 
forceRefreshClusterAndGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
forceRefreshMetadata(int) - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Force-refresh metadata, paying no attention to how recently it has been refreshed, and bound the wait time for the call.
forceRefreshMetadata() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Force-refresh metadata, paying no attention to how recently it has been refreshed.
forEach(Consumer<? super T>) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
forId(byte) - Static method in enum com.linkedin.kafka.cruisecontrol.metricsreporter.metric.RawMetricType
 
from(Load) - Static method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
Create a utilization class that can accumulate load from different entities in different state.
from(Load, Broker.Strategy) - Static method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
Create a utilization class that represents load of a single entity that is in the specified state.
fromBytes(byte[]) - Static method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 

G

generateCcTopicExclusionRegex(KafkaConfig) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
generateCcTopicExclusionRegex(List<String>, List<String>) - Static method in class io.confluent.databalancer.DatabalancerUtils
The function forms a regex expression by performing OR operation on the topic names and topic prefixes considering each of these as string literals.
generateChainedReplicaMovementStrategies(List<String>) - Static method in interface com.linkedin.kafka.cruisecontrol.executor.strategy.ReplicaMovementStrategy
A helper method to compose ReplicaMovementStrategies together.
generateClientConfigs() - Method in class io.confluent.databalancer.startup.CruiseControlStartable
Generate client configs for the Admin client used by SBC when starting up SBC.
generateCruiseControlConfig() - Method in class io.confluent.databalancer.startup.CruiseControlStartable
Given a #KafkaConfig, generate an appropriate #KafkaCruiseControl to bring up CruiseControl internally.
generateEventId() - Method in class io.confluent.databalancer.SbcContext
 
generatePlaintext(boolean, String) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
Generates the plaintext summary of the optimization result.
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
generateString(boolean) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
Generate a string representation of the proposal stats.
generateTable(List<String>, List<List<String>>) - Method in class io.confluent.databalancer.utils.TableGenerator
Generates a tabular-formatted string with the given input data.
generateTable(List<String>, List<List<String>>, int) - Method in class io.confluent.databalancer.utils.TableGenerator
Generates a tabular-formatted string with the given input data.
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 - Variable in class com.linkedin.cruisecontrol.common.LongGenerationed
 
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.
get() - Method in class io.confluent.databalancer.utils.RetryableResult.Failure
 
get() - Method in interface io.confluent.databalancer.utils.RetryableResult
Return the result of the retriable operation if the operation succeeds.
get() - Method in class io.confluent.databalancer.utils.RetryableResult.Incomplete
 
get() - Method in class io.confluent.databalancer.utils.RetryableResult.Success
 
getAllBrokerRemovalStateRecords() - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
getAllBrokersInCluster(Admin) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
getAllTopicsInCluster(Admin) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
getAnomalyDetector() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
getBalanceEngine() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
getBalancerStatusTracker() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
getBalancerStatusTracker() - Method in interface io.confluent.databalancer.DataBalanceEngineContext
 
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
getBrokerId(KafkaConfig) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
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(ImmutableSet<Integer>) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
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
A Populate the analysis stats with this cluster and given balancing constraint.
getConfigEntry(Config, String) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
getConfigs() - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher
Return configuration of the entities specified by BatchedConfigsFetcher.configResources list.
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
 
getConfiguredLogDirs(KafkaConfig) - Static method in class io.confluent.databalancer.DatabalancerUtils
Get the log directories from the Kafka Config.
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.
getCpuOptimizationMetric() - Method in class com.linkedin.kafka.cruisecontrol.detector.CpuUtilizationDetector
 
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.
getDiskOptimizationMetric() - Method in class com.linkedin.kafka.cruisecontrol.detector.DiskUtilizationDetector
 
getDouble(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
getDurationMs() - Method in class com.linkedin.kafka.cruisecontrol.config.ResourceUtilizationCommonConfig
 
getEntityConfigs(Admin, KafkaCruiseControlConfig, ConfigResource.Type, Time, String, ConfigFetchErrorHandler) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Fetches configuration for the resource specified by resourceName and resourceType argument.
getEntityConfigs(Admin, KafkaCruiseControlConfig, ConfigResource.Type, Time, Collection<String>, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
This method returns configurations for all the resources specified by the resourceNames and resourceType argument.
getEvenClusterLoadStateManager() - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
getEvenClusterLoadStateManager() - Method in interface io.confluent.databalancer.DataBalanceEngineContext
 
getEvenClusterLoadStateRecord() - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
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
 
getExecutorShutdownConsumerWithTimeout(long) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
A helper method for shutting down executor services in conjunction with executeSilently
getFailedBrokers() - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
getIconEmoji() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
getInt(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
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.
getJsonArray() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
getJSONString() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
 
getJsonStructure(boolean) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
getJsonStructure() - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Return an object that can be further used to encode into JSON
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() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
Return an object that can be further be used to encode into JSON
getJsonStructure(boolean) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
getJsonStructure() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
getJSONStructure() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
getJsonStructureForLoad() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
 
getKafkaBalanceManager() - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
getKafkaConfig() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
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
 
getMetricValue() - Method in enum com.linkedin.kafka.cruisecontrol.detector.notifier.ResourceUtilizationAlertType
 
getNewReplicaLoadFromLeader() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Get the expected load if we add a new replica to the replica set.
getObserverDistribution() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the distribution of observer replicas in the cluster.
getOverutilizationThreshold() - Method in class com.linkedin.kafka.cruisecontrol.config.ResourceUtilizationCommonConfig
 
getPartitionMoves(ClusterModel, Set<Goal>, List<Replica>, Iterable<List<Broker>>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Move a partition to a set of brokers and return the valid moves if one can be found.
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
 
getProposals(GoalsConfig, ModelCompletenessRequirements, OperationProgress, boolean, boolean, boolean, boolean) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Optimize a cluster workload model.
getProposals(ClusterModel, GoalsConfig, boolean, boolean, KafkaCruiseControlContext) - Method in class com.linkedin.kafka.cruisecontrol.ProposalGenerator
 
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.
getReplicasForPartitions(Collection<TopicPartition>) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Returns the replicas for a given set of partitions.
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.
getRequiredInputStreamConfig(Map<String, ?>, String) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Get a configured class by its key.
getReservedCapacity() - Method in class com.linkedin.kafka.cruisecontrol.config.DiskUtilizationDetectorConfig
 
getSamples(Cluster, Set<PartitionInfo>, long, 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<PartitionInfo>, long, long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampler
 
getSamples(Cluster, Set<PartitionInfo>, long, 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
 
getTenantId(Replica) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
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
 
getUnderutilizationThreshold() - Method in class com.linkedin.kafka.cruisecontrol.config.ResourceUtilizationCommonConfig
 
getUsername() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackMessage
 
gigabytesToMebibytes(double) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
Given gb gigabytes, convert it to mebibytes.
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.analyzer.OptimizationResult
 
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_TAG - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
GOAL_VIOLATION_DELAY_ON_NEW_BROKER_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.violation.delay.on.broker.addition
GOAL_VIOLATION_DELAY_ON_NEW_BROKER_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
GOAL_VIOLATION_DELAY_ON_NEW_BROKERS_MS_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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_REMOVED_BROKERS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goal.violation.exclude.recently.removed.brokers
GoalBalancingActionAcceptance - Interface in com.linkedin.kafka.cruisecontrol.analyzer.goals
This interface declare methods that check whether the given action is acceptable by the implementing goals in the given state of the cluster.
GoalConfigChangeListener(String) - Constructor for class com.linkedin.kafka.cruisecontrol.config.GoalConfigChangeNotifier.GoalConfigChangeListener
 
GoalConfigChangeNotifier - Interface in com.linkedin.kafka.cruisecontrol.config
 
GoalConfigChangeNotifier.GoalConfigChangeListener - Class in com.linkedin.kafka.cruisecontrol.config
A listener that can get registered to run whenever the goal config is updated.
GoalConstraints - Enum in io.confluent.databalancer
Represents which goal's constraints are to be verified.
goalName - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
goalName(String) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger.Builder
 
goalNamesWithProposals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
GoalOptimizationHistory - Class in io.confluent.cruisecontrol.analyzer.history
This class keeps track of the past movements with regard to TopicPartitions.
GoalOptimizationHistoryListener<H extends TopicPartitionHistory> - Interface in io.confluent.cruisecontrol.analyzer.history
This interface should be implemented by any parties interested in consuming from GoalOptimizationHistory.
GoalOptimizationHistoryOptions - Class in com.linkedin.kafka.cruisecontrol.analyzer
Options related to goal optimization history tracking.
goalOptimizationHistoryOptions(GoalOptimizationHistoryOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
Set the GoalOptimizationHistoryOptions to enable goal optimization history tracking with the configurations in the provided options object.
goalOptimizationHistoryOptions() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
Returns the goal optimization history tracking options if goal optimization history tracking is enabled, otherwise returns nothing.
GoalOptimizationLogger - Class in io.confluent.cruisecontrol.analyzer.history
Generates log upon receiving the notification from GoalOptimizationHistory about some TopicPartition have breached the maximum allowed repeated movements.
GoalOptimizationLogger() - Constructor for class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationLogger
Create a GoalOptimizationLogger and register it with the provided GoalOptimizationHistory.
GoalOptimizationResult - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
GoalOptimizationResult.Builder - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
GoalOptimizer - Class in com.linkedin.kafka.cruisecontrol.analyzer
A class for optimizing goals in the given order of priority.
GoalOptimizer(KafkaCruiseControlConfig, DataBalancerMetricsRegistry, UpdatableSbcGoalsConfig, GoalOptimizationHistory) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizer
Constructor for Goal Optimizer takes the goals as input.
goalOptimizer() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
goalOptimizer(GoalOptimizer) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
goalProposals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
GoalResult(String, Exception) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.GoalViolations.GoalResult
 
goals() - Method in class com.linkedin.kafka.cruisecontrol.config.GoalsConfig
 
GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
goals
goalsConfig() - Method in interface com.linkedin.cruisecontrol.detector.Anomaly
Returns the goals that will be used to fix this anomaly.
GoalsConfig - Class in com.linkedin.kafka.cruisecontrol.config
An immutable representation of a configured set of SBC Goals along with their ModelCompletenessRequirements.
GoalsConfig(List<Goal>) - Constructor for class com.linkedin.kafka.cruisecontrol.config.GoalsConfig
 
GoalsConfig(List<Goal>, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.config.GoalsConfig
 
goalsConfig() - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailures
 
goalsConfig() - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolations
 
goalsWithMovements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult
 
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, UpdatableSbcGoalsConfig, KafkaCruiseControl.CcStartupMode, DataBalancerMetricsRegistry) - 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, GoalsConfig) - 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
 
group - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
group() - Method in class com.linkedin.cruisecontrol.model.Entity
 
group() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
group() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
group() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
Make replica entity part of a "topic" group.
groups() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
Get the groups for the configuration

H

handle() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorMetricsHandle
Takes care of necessary prerequisite steps involving the load monitor before executing the executor.
handleAdminClientException(RuntimeException) - Static method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
This looks for cause of ExecutionException and then gets its cause and throws that instead.
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.
handleError(ConfigResource, Exception) - Method in interface com.linkedin.kafka.cruisecontrol.ConfigFetchErrorHandler
This method will be invoked when fetching a config for the resource parameter results in an error.
handleEvent() - Method in class io.confluent.databalancer.event.SbcAlteredExclusionsEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcBalancerStatusEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcBrokerFailureEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcComputeEvenClusterLoadPlanEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcConfigUpdateEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcEvenLoadStatusEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcEvent
The "business logic" of an SbcEvent.
handleEvent() - Method in class io.confluent.databalancer.event.SbcKraftBrokerAdditionEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcKRaftScheduleBrokerRemovalEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcKraftStartupEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcLeaderUpdateEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcListBrokerAdditionsEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcListBrokerRemovalsEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcMetadataUpdateEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcResignationEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcShutdownEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcTriggerEvenClusterLoadEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcZkBrokerAdditionEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcZkBrokerHealthChangeEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcZkConfigUpdateEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcZkScheduleBrokerRemovalEvent
 
handleEvent() - Method in class io.confluent.databalancer.event.SbcZkStartupEvent
 
handleEvent() - Method in class io.confluent.databalancer.SbcCellLoadEvent
 
handleExcludeTopicsConfig(List<String>, List<String>, String) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
handleGoalConfigUpdate(SbcGoalsConfigDelta) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
handleHealModeConfig(boolean) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
handleTask(Task) - Method in class com.linkedin.kafka.cruisecontrol.statemachine.StateMachineProcessor
 
handleThrottleConfig(Long) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
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.GoalOptimizationHistoryOptions
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerAndSortedReplicas
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
hashCode() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta
 
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.Cell
 
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.model.Tenant
 
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 com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
 
hashCode() - Method in class io.confluent.databalancer.BalancerEnabledConfig
 
hashCode() - Method in class io.confluent.databalancer.event.resource.SbcResource
Return a hash value for this SbcResource.
hashCode() - Method in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent.EligibleBrokers
 
hashCode() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
hashCode() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
hashCode() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
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.
hasReassigningPartitions() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
hasReplicaAction() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
hasReplicaChange() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult
Whether this goal optimization run contains any sort of replica movements (e.g leadership change, removed replica, etc)
hasReplicaOfPartition(TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
hasSkippedExecution() - Method in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalPhase
 
hasSkippedExecution() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase
 
hasUpdate() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta
 
headers() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
HIDDEN - Static variable in class com.linkedin.cruisecontrol.common.config.types.Password
 
historyEpoch() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizationHistoryOptions
Epoch of the goal optimization history tracking.
host() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
Host - Class in com.linkedin.kafka.cruisecontrol.model
 
HOST - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
host() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerEntity
 
HOST - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
host - Variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
host() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
hostFieldLength - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
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.monitor.BrokerStats
 
hostStats - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
HOT_PARTITION_CAPACITY_UTILIZATION_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
hot.partition.capacity.utilization.threshold
HOT_PARTITION_CAPACITY_UTILIZATION_THRESHOLD_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
hotPartitionUtilizationThreshold() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
 

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.Cell
Get the cell Id.
id() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
Get the rack id.
id - Variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
id() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
identityEntityMap - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
ignore(String) - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
 
ignore() - Static method in class com.linkedin.kafka.cruisecontrol.detector.notifier.AnomalyNotificationResult
 
ignoredBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the ignored brokers in the cluster.
ignoredDestinationCapacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Capacity
 
ignoredDestinationUtilization() - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
ignoredSourceCapacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Capacity
 
ignoredSourceUtilization() - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
ignoreUnknownTopicOrPartitionException(boolean) - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
immigrantReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the immigrant replicas (The replicas that are moved here).
ImmutableSet<T> - Class in io.confluent.databalancer.utils
An explicit wrapper around Collections.unmodifiableSet(Set).
ImmutableSet() - Constructor for class io.confluent.databalancer.utils.ImmutableSet
 
ImmutableSet(Collection<? extends T>) - Constructor for class io.confluent.databalancer.utils.ImmutableSet
 
importance - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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
 
includeSynonyms(boolean) - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
INCREMENTAL_BALANCING_DEFAULT_GOALS_LIST - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_ENABLED_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
incremental.balancing.enabled
INCREMENTAL_BALANCING_ENABLED_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_ENABLED_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
incremental.balancing.goals.config
INCREMENTAL_BALANCING_GOALS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_LOWER_BOUND_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
incremental.balancing.lower.bound
INCREMENTAL_BALANCING_LOWER_BOUND_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_LOWER_BOUND_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_STEP_RATIO_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
incremental.balancing.step.ratio
INCREMENTAL_BALANCING_STEP_RATIO_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INCREMENTAL_BALANCING_STEP_RATIO_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
incrementalBalancingEnabled(boolean) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig.SbcGoalsConfigBuilder
 
incrementalBalancingGoals() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
Retrieve the incremental balancing goals.
incrementalBalancingGoals(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig.SbcGoalsConfigBuilder
 
IncrementalCPUResourceDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
IncrementalCPUResourceDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalCPUResourceDistributionGoal
 
IncrementalResourceDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
SOFT GOAL: Balance Resource distribution over brokers incrementally.
IncrementalResourceDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
 
IncrementalResourceDistributionGoalMetrics - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
A long-lived object managing the latest optimization run's incremental resource distribution metrics for a given ResourceDistributionAbstractGoal.name().
IncrementalResourceDistributionGoalMetrics(String, DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.IncrementalResourceDistributionGoalMetrics
 
IncrementalResourceDistributionStatsSnapshot - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A snapshot containing various statistics surrounding an IncrementalResourceDistributionGoal.
IncrementalResourceDistributionStatsSnapshot(Map<Integer, Double>, double, double, double) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.IncrementalResourceDistributionStatsSnapshot
 
incrementalStepRatio() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.IncrementalResourceDistributionStatsSnapshot
 
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
 
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(Integer, KafkaCruiseControl.CcStartupMode) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
init() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
 
init(KafkaCruiseControlConfig) - Static method in class com.linkedin.kafka.cruisecontrol.model.ModelParameters
 
init() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
 
init() - Method in class com.linkedin.kafka.cruisecontrol.statemachine.StateMachineProcessor
 
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>, TopicAdmin) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Initialize states that this goal requires -- e.g.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - 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, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
 
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - 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, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Initialize the utilization thresholds.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.MovementExclusionGoal
 
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - 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, Optional<OptimizationMetrics>) - 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, Optional<OptimizationMetrics>) - 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, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
Initiates replica distribution abstract goal.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
 
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
Initialize the state of this goal.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
Initialize states that this goal requires -- e.g.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Initiates this goal.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
Initialize states that this goal requires -- e.g.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
Make sure that all non-excluded topics have replication factor smaller than the size of the largest cell.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - 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.
initGoalState(ClusterModel, OptimizationOptions, Optional<OptimizationMetrics>) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
InitializationRule(S, S) - Constructor for class io.confluent.databalancer.operation.StateMachineInitializer.InitializationRule
 
initialize() - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
Initialize the #BalancerStatusTracker by setting the current state and notify the listener if it's the initial balancer state.
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.
initialResourceDistribution - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
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.
instance() - Static method in class io.confluent.databalancer.utils.RetryableResult.Failure
 
instance() - Static method in class io.confluent.databalancer.utils.RetryableResult.Incomplete
 
inSyncReplicas() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImageReplicaInfo
 
interBrokerDataToMove() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResultReplicaMovements
 
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
 
INTERNAL_REBALANCING_GOALS_CONFIG_NAME - Static variable in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
 
INTERNAL_TRIGGERING_GOALS_CONFIG_NAME - Static variable in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
 
internalConfig - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
internalGoalsConfigName(String) - Static method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Given the higher-level BalancerConfigs name for an SBC goal config, return the lower-level internal one that is used within KafkaCruiseControlConfig.
INTRA_BROKER_GOALS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
intra.broker.goals
intraBrokerDataToMove() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResultReplicaMovements
 
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
 
INVALID_REPLICA_ASSIGNMENT_RETRY_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
invalid.replica.assignment.retry.timeout.ms
INVALID_REPLICA_ASSIGNMENT_RETRY_TIMEOUT_MS_DEFAULT - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
INVALID_REPLICA_ASSIGNMENT_RETRY_TIMEOUT_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
invalidateMetricsWindows() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Notify the metric sample aggregators that all metrics should be dropped until the current timestamp.
invalidateMetricWindowsUntil(long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Notify the metric sample aggregators that metrics before a given time should be dropped (for example, due to a rebalance occurring).
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.analyzer.history - package io.confluent.cruisecontrol.analyzer.history
 
io.confluent.cruisecontrol.metricsreporter - package io.confluent.cruisecontrol.metricsreporter
 
io.confluent.databalancer - package io.confluent.databalancer
 
io.confluent.databalancer.event - package io.confluent.databalancer.event
 
io.confluent.databalancer.event.resource - package io.confluent.databalancer.event.resource
 
io.confluent.databalancer.metadata - package io.confluent.databalancer.metadata
 
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
 
io.confluent.databalancer.utils - package io.confluent.databalancer.utils
 
IS_LEADER - Static variable in class com.linkedin.kafka.cruisecontrol.model.ModelUtils
 
isAccepted - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
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 - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
isBrokerStatsEstimated() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
isCapacityEstimated() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
isCellAlive() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Checks if cell has at least one alive brokers.
isCellEligible() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Checks if cell has at least one broker eligible for replica placement (alive & not-excluded).
isCellEnabled() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Return a boolean indicating if Cell is enabled on the cluster.
isConfiguredAsEnabled() - Method in class io.confluent.databalancer.BalancerEnabledConfig
 
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.
isCurrentStateNull() - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
Returns whether current state is null.
isDisabled() - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
 
isEligible() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Denotes whether the broker is eligible for any kinds of movements
isEligibleDestination() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Check whether the broker is eligible as a destination broker
isEligibleDestination() - Method in enum com.linkedin.kafka.cruisecontrol.model.Broker.Strategy
Denotes whether the broker is eligible as a destination broker - have replicas/leaders/partitions moved into it.
isEligibleDestination() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
isEligibleDestination() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
 
isEligibleSource() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Check whether the broker is eligible as a source broker
isEligibleSource() - Method in enum com.linkedin.kafka.cruisecontrol.model.Broker.Strategy
Denotes whether the broker is eligible as a source broker - have replicas/leaders/partitions moved away from it.
isEmpty() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
Check if the AggregatedMetricValues contains value for any metrics.
isEmpty() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard.Result
 
isEmpty() - Method in class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
 
isEmpty() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
Returns true if the pool contains no elements.
isEmpty() - Method in class io.confluent.databalancer.BrokersMetadataSnapshot
 
isEmpty() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
isEnabled - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalObservabilityTrackingOptions
 
isEqual(AggregatedMetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
 
isEqual(MetricValues) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricValues
 
isEqual(double, double) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Returns true if d1 = d2, false otherwise.
isEqual(Load) - Method in class com.linkedin.kafka.cruisecontrol.model.Load
 
isEstimated() - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo
 
isEstimated - Variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
isEstimated() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
isExcludedForReplicaPlacement() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Denotes whether the broker is excluded.
isExtrapolatedAtWindowIndex(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
Check if the window at the given window index is extrapolated.
isFailed() - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
isFailedOrAborted() - Method in enum io.confluent.databalancer.operation.EvenClusterLoadStateMachine.EvenClusterLoadState
 
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.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.ResourceDistributionAbstractGoal
 
isHardGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
This goal will not fail optimization if it can't be satisfied.
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.CellAwareGoal
 
isHardGoal() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
isHardGoal() - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
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.
isIncrementalBalancingEnabled() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
Retrieve the configuration on incremental balancing enabling.
isInitialized() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
 
isInitialized() - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
 
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
isLarger(double, double) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Returns true if d1 > d2, false otherwise.
isLeader() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Check the leadership status of the broker.
isLeader() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
 
isLoadAboveBalanceLowerLimit(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
Determine whether the resource utilization of the provided broker is above balance lower limit.
isLoadAboveBalanceLowerLimitAfterChange(Load, Broker, ResourceDistributionAbstractGoal.ChangeType) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
isLoadUnderBalanceUpperLimit(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
Determine whether the resource utilization of the provided broker is under balance upper limit.
isLoadUnderBalanceUpperLimitAfterChange(Load, Broker, ResourceDistributionAbstractGoal.ChangeType) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
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.
isRebalanceByMovingLoadInCompleted(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
 
isRebalanceByMovingLoadInCompleted(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
isRebalanceByMovingLoadInCompleted(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
isRebalanceByMovingLoadOutCompleted(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
 
isRebalanceByMovingLoadOutCompleted(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
isRebalanceByMovingLoadOutCompleted(Broker) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
isReservedByOther() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Whether the Executor's is reserved (paused) by another thread.
isSmaller(double, double) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerUtils
Returns true if d1 < d2, false otherwise.
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
 
isSuccesful() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult
 
isSuccess() - Method in enum io.confluent.databalancer.operation.BalancerOperationState.BalancerOperationStateCharacteristics
 
isSuccess() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Return a boolean indicating whether the state represents a successful completion of the operation.
isTerminal() - Method in enum io.confluent.databalancer.operation.BalancerOperationState.BalancerOperationStateCharacteristics
 
isTerminal() - Method in interface io.confluent.databalancer.operation.BalancerOperationState
Boolean indicating whether a state is terminal or not.
isTerminal() - Method in enum io.confluent.databalancer.operation.BalancerStatusStateMachine.BalancerState
 
isTerminal() - Method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionState
Returns boolean indicating whether the state is terminal.
isTerminal() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Returns boolean indicating whether the state is terminal.
isTerminal() - Method in enum io.confluent.databalancer.operation.EvenClusterLoadStateMachine.EvenClusterLoadState
 
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
 
iterator() - Method in class io.confluent.databalancer.utils.ImmutableSet
 

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

K

KAFKA_CONFIG - Static variable in class io.confluent.databalancer.event.resource.SbcResources
 
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.
kafkaConfig() - Method in class io.confluent.databalancer.EngineInitializationContext
 
kafkaConfig() - Method in class io.confluent.databalancer.SbcContext
 
KafkaCruiseControl - Class in com.linkedin.kafka.cruisecontrol
The main class of Cruise Control.
KafkaCruiseControl(Integer, KafkaCruiseControlConfig, DataBalancerMetricsRegistry, BlockingSendClient.Builder, KafkaCruiseControl.CcStartupMode) - Constructor for class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Construct the Cruise Control
KafkaCruiseControl(Integer, KafkaCruiseControlConfig, LoadMonitor, GoalOptimizer, Executor, AnomalyDetector, BrokerShutdownManager, StateMachineProcessor, GoalOptimizationHistory, ProposalGenerator, ConfluentAdmin, Time, KafkaCruiseControl.CcStartupMode, EvenClusterLoadStateManager) - Constructor for class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Public for test mock injection
KafkaCruiseControl.CcStartupMode - Enum in com.linkedin.kafka.cruisecontrol
 
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
 
kafkaCruiseControlConfig() - Method in class io.confluent.databalancer.startup.CruiseControlStartable
 
kafkaCruiseControlContext - Variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
 
KafkaCruiseControlContext - Class in com.linkedin.kafka.cruisecontrol
 
KafkaCruiseControlContext.KafkaCruiseControlContextBuilder - Class in com.linkedin.kafka.cruisecontrol
 
KafkaCruiseControlContextBuilder() - Constructor for class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
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.
KafkaCruiseControlUtils.MaybeThrowingConsumer<T> - Interface in com.linkedin.kafka.cruisecontrol
Creates a Consumer that accepts methods that can throw checked exceptions.
KafkaDataBalanceManager - Class in io.confluent.databalancer
 
KafkaDataBalanceManager(KafkaConfig, Optional<Endpoint>, DataBalancerMetricsRegistry, Time) - Constructor for class io.confluent.databalancer.KafkaDataBalanceManager
Create a KafkaDataBalanceManager.
kafkaDataBalanceManager() - Method in class io.confluent.databalancer.SbcContext
 
kafkaMetricDef() - Method in class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
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
 
kafkaMetricDefsForRawMetricType(RawMetricType) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
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.
KafkaReplicaMetricSampleAggregator - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator
The metrics sample aggregator for replicas.
KafkaReplicaMetricSampleAggregator(KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Construct the metric sample aggregator.
kill(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Kill the task.
knownBrokers() - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Return the set of brokers that are being tracked.

L

labels() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.Labeled
 
lastArrayIndex() - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
lastUpdateTime() - Method in class io.confluent.databalancer.operation.StateMachine
 
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
 
latestInvalidWindowIndex - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
leader() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the leader replica.
LEADER_ACTION_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
executor.leader.action.timeout.ms
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_NW_IN_RATE - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
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
 
leaderboardByBroker() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard.Result
 
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
 
leaderBytesInRate - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
leaderBytesInRate() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
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.
LEADERS - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
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
 
leadershipUtilizationForNwResources() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
legitMove(Replica, Broker, ClusterModel, ActionType) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Check whether the proposed inter-broker action is legit.
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
 
length(long) - Method in class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
Returns length of the window in milliseconds given current timestamp
listTargetReplicasBeingReassigned(Optional<Set<TopicPartition>>) - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
Lists the partitions being reassigned in the cluster.
load() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the broker load of the broker.
load(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the broker load of the broker based on the provided resource.
load() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Get the cell load information.
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.Builder - Class in com.linkedin.kafka.cruisecontrol.model
This builder allows us to create a new Load with a base Load, load to add and load to subtract.
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.
loadCapacities(String) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
loadCapacities(JsonReader) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityConfigFileResolver
 
loadGeneration() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelGeneration
 
loadMonitor(LoadMonitor) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
loadMonitor() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
LoadMonitor - Class in com.linkedin.kafka.cruisecontrol.monitor
The LoadMonitor monitors the workload of a Kafka cluster.
LoadMonitor(KafkaCruiseControlConfig, MetadataClient, CloudAdmin, Time, DataBalancerMetricsRegistry, UpdatableSbcGoalsConfig) - 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, KafkaReplicaMetricSampleAggregator, KafkaPartitionMetricSampleAggregator, KafkaBrokerMetricSampleAggregator, MetadataClient, 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
 
LOG - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
LOG - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ReplicaDistributionStatsSnapshot
 
log - Static variable in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.RebalanceStep
 
LOG - Static variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
LOG - Static variable in class io.confluent.databalancer.event.resource.SbcResourceManager
 
LOG - Static variable in class io.confluent.databalancer.event.SbcEvent
 
LOG - Static variable in class io.confluent.databalancer.event.SbcKraftBrokerAdditionEvent
 
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
logdirFieldLength - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
logLevel() - Method in class io.confluent.databalancer.event.SbcBalancerStatusEvent
 
logLevel() - Method in class io.confluent.databalancer.event.SbcEvenLoadStatusEvent
 
logLevel() - Method in class io.confluent.databalancer.event.SbcEvent
Denotes the log level that will be used to log any common logs as part of this event processing.
logLevel() - Method in class io.confluent.databalancer.event.SbcListBrokerAdditionsEvent
 
logLevel() - Method in class io.confluent.databalancer.event.SbcListBrokerRemovalsEvent
 
logLevel() - Method in class io.confluent.databalancer.event.SbcMetadataUpdateEvent
Override the log level for this event to DEBUG, as there are a lot of them being generated.
logPrefix(String) - Static method in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalCallback
Returns a standardized prefix for logging anything related to the removal operation
logResourceDistribution() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger
 
logUnused() - Method in class com.linkedin.cruisecontrol.common.config.AbstractConfig
Log warnings for any unused configurations
LONG_LIVED_METRICS_WHITE_LIST - Static variable in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
LongGenerationed - Class in com.linkedin.cruisecontrol.common
 
LongGenerationed(long) - Constructor for class com.linkedin.cruisecontrol.common.LongGenerationed
 
lowerBalanceThresholdValue - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
lowUtilizationPercent() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
Returns the low utilization threshold for this goal, usually representing a percentage within the range [0.0, 1.0] (0-100%) (with exception to KAFKALESS-761).
lowUtilizationThreshold(Resource, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the low utilization threshold for a resource.
lowUtilizationValueThreshold - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 

M

mapResourceLabels(Map<String, String>) - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.MetricConsumer
mapResourceLabels gets called once for every new set of new resource labels decoded by the TelemetryConverter and the value of the Optional returned by this method will get passed through with each call to consume() for all the metrics corresponding to that set of resource labels.
markOriginalOffline() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
Package private for unit test.
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.
markTasksToBeRetried(List<ExecutionTask>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Mark the given tasks as to be retried.
markUnsuccessfulOptimization() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult.Builder
Marks that the goal was not met during this optimization run
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_REPLICAS_PER_BROKER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Broker replica capacity: max.replicas
MAX_RESOURCE_METRIC_NAME - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
MAX_UUID_LENGTH - Static variable in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalCallback
 
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
 
maxBrokerResource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
maxBrokerResource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
maxBrokerResource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
MAXIMUM_CAPACITY_DEVIATION_PERCENTAGE - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
 
maxNumberOfProposals - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalObservabilityTrackingOptions
 
maxNumProposalsPerLeaderboard() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard.Result
Return the maximum number of proposals kept per leaderboard.
MaxReplicaMovementParallelismGoal - Class in io.confluent.cruisecontrol.analyzer.goals
A goal which limits the maximum number of replicas that can move for a given partition at one time.
MaxReplicaMovementParallelismGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.MaxReplicaMovementParallelismGoal
 
MaxReplicaMovementParallelismGoal(BalancingConstraint) - Constructor for class io.confluent.cruisecontrol.analyzer.goals.MaxReplicaMovementParallelismGoal
Used by tests
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.
maxResource(BrokerResourceStats, BrokerResourceStats) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
maybeAddBroker(int) - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Add a broker ID to the map for tracking.
maybeApplyBalancingAction(ClusterModel, Replica, Collection<Broker>, ActionType, Set<Goal>, OptimizationOptions, Optional<DetailedProposal.Builder>) - 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.
maybeApplyBalancingAction(ClusterModel, Replica, Collection<Broker>, ActionType, Set<Goal>, OptimizationOptions, DetailedProposal.DetailedReasonBuilder, Optional<DetailedProposal.Builder>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Same with this#maybeApplyBalancingAction(ClusterModel, Replica, Collection, ActionType, Set, OptimizationOptions, Optional with the additional functionality of providing a string as the reason of movement.
maybeCancel(BrokerRemovalCancellationProposal) - Method in class io.confluent.databalancer.operation.BrokerRemovalStateTracker
Requests cancellation of the broker removal state tracking by setting a terminal canceled state
maybeClearOngoingAnomalyDetectionTimeMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
maybeDeleteSampleStoreTopic(KafkaCruiseControlConfig, Semaphore) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStoreTopicCleanUp
 
maybeEnableOrDisable(Boolean, Optional<AliveBrokersMetadata>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Given a new config value sbcEnabledConfigValue and an optional aliveBrokersMetadataOptional, potentially enable or disable SBC depending on whether the value differs from the current state of SBC and the presence of demoted brokers in the cluster.
maybeEnableOrDisable(AliveBrokersMetadata) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Given a new broker's metadata aliveBrokersMetadata, potentially enable or disable SBC depending on the existence of demoted brokers and their interaction with the configured SBC enabled value.
maybeGetResourceValue(SbcResource<R>) - Method in interface io.confluent.databalancer.event.resource.BalancerResourceManager
Return the current value of a resource, if any.
maybeGetResourceValue(SbcResource<R>) - Method in class io.confluent.databalancer.event.resource.SbcResourceManager
Look up the current value of the given SbcResource.
maybeInvalidateWindowsBeforeTime(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Invalidate metric windows before a given timestamp.
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.
maybeReexecuteTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
Conditionally re-executes the on-going tasks
maybeReexecuteTasks() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorIntraBrokerReplicaMovement
 
maybeRefreshMetadata() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Refresh the metadata.
maybeRefreshMetadata(int) - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient
Refresh the metadata, but bound the wait time for the call.
maybeRegisterEvent(EvenClusterLoadStateMachine.EvenClusterLoadEvent, Exception) - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
 
maybeShutdownBrokers(Map<Integer, Optional<Long>>) - Method in class com.linkedin.kafka.cruisecontrol.server.BrokerShutdownManager
Ensures that the given brokers are shut down by initiating shutdown via an #InitiateShutdownRequest and awaiting their shutdown.
maybeUpdate(boolean, boolean) - Method in class io.confluent.databalancer.BalancerEnabledConfig
Conditionally updates the config if the supplied values are different than the existing ones.
maybeUpdateConfigValue(boolean) - Method in class io.confluent.databalancer.BalancerEnabledConfig
Conditionally updates the config's enabled variable.
maybeUpdateDemotedBrokers(boolean) - Method in class io.confluent.databalancer.BalancerEnabledConfig
Conditionally updates the config's demoted brokers presence variable.
maybeUpdateStateOnSelfHealingEnabled() - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
Initialize the current even cluster load status on initial enabling of self-healing.
meanTimeBetweenAnomaliesMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyStats
 
meanTimeToStartFixMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyStats
 
meanUtilizationPercent() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
Returns the mean utilization threshold within the range [0.0, 1.0] for this goal as calculated as part of this optimization run.
meanUtilizationPercentage() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.IncrementalResourceDistributionStatsSnapshot
 
meanUtilizationValueThreshold - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
meetCompletenessRequirements(List<Goal>, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Check if the completeness requirements are met for the given goals.
meetCompletenessRequirements(MetadataClient.ClusterAndGeneration, ModelCompletenessRequirements, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Check whether the monitored load meets the load requirements.
meetCompletenessRequirements(MetadataClient.ClusterAndGeneration, ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
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_CLIENT_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metadata.client.timeout.ms
METADATA_TTL_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
metadata.ttl
metadataChanged(MetadataClient.ClusterMetadata, MetadataClient.ClusterMetadata) - 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.Builder - Class in com.linkedin.kafka.cruisecontrol.common
 
MetadataClient.ClusterAndGeneration - Class in com.linkedin.kafka.cruisecontrol.common
 
MetadataClient.ClusterMetadata - Class in com.linkedin.kafka.cruisecontrol.common
 
metadataTimeoutMs - Variable in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.Builder
 
metadataTtlMs - Variable in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.Builder
 
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
 
metricDef - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
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
 
metricDefId(MetricDef, KafkaMetricDef) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
MetricFetcherManager - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
The class manages the metric fetchers.
MetricFetcherManager(KafkaCruiseControlConfig, KafkaReplicaMetricSampleAggregator, KafkaPartitionMetricSampleAggregator, KafkaBrokerMetricSampleAggregator, MetadataClient, Time, DataBalancerMetricsRegistry, BrokerCapacityConfigResolver, MetricSampler) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
Create a metric fetcher manager.
metricIds() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.AggregatedMetricValues
 
metricInfo(KafkaMetricDef) - 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 resource.
MetricInfo(KafkaMetricDef, short) - Constructor for class com.linkedin.cruisecontrol.metricdef.MetricInfo
 
metricInfoForResource(Resource) - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
Get all the metric info for the given resource.
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
MetricSample<E extends Entity> - 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<E extends Entity> - Class in com.linkedin.cruisecontrol.monitor.sampling.aggregator
MetricSampleAggregationResult(long, MetricSampleCompleteness<E>) - Constructor for class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregationResult
 
MetricSampleAggregator<E extends Entity> - 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<E extends Entity> - 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.
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
 
metricsRegistry - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
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.
MIB_IN_GB - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
MIN_NUM_VALID_WINDOWS_FOR_SELF_HEALING - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
 
MIN_RESOURCE_METRIC_NAME - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
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_VALID_PARTITION_RATIO_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
min.valid.partition.ratio
minBrokerResource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
minBrokerResource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
minBrokerResource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
minMonitoredPartitionPercentage - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
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
 
minResource(BrokerResourceStats, BrokerResourceStats) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.AbstractDistributionStatsSnapshot
 
minRetentionTimeMs - Variable in class com.linkedin.kafka.cruisecontrol.SbkTopicUtils.SbkTopicConfig
 
minSamplesPerWindow - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
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
 
ModelCompletenessRequirements - Class in com.linkedin.kafka.cruisecontrol.monitor
This class is created to describe the requirements of the model.
ModelCompletenessRequirements(int, double, boolean, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
Constructor for the requirements.
ModelCompletenessRequirements(int, double, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
(Convenience) Constructor for the requirements of goals that don't require topic placement data.
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
 
ModelUtils - Class in com.linkedin.kafka.cruisecontrol.model
The util class for model.
modifiedExclusions - Variable in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal
 
modifiedExclusions - Variable in class io.confluent.databalancer.operation.BrokerRemovalExclusionCancellationData
 
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.
monitoredPercentage(Set<ReplicaEntity>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Get the valid replica percentage across all the windows.
monitoredWindows() - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
monitoringPeriodMs - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
MonitorUtils - Class in com.linkedin.kafka.cruisecontrol.monitor
A util class for Monitor.
move(Executor.ExecutionTaskWaiter) - Method in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
Moves the replicas according to the specific movement
move(Executor.ExecutionTaskWaiter) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorInterBrokerReplicaMovement
 
move(Executor.ExecutionTaskWaiter) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorIntraBrokerReplicaMovement
 
move(Executor.ExecutionTaskWaiter) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorLeadershipReplicaMovement
 
moveImmigrantsOnly - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
MovementExclusionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
MovementExclusionGoal is a hard blocking goal which forbids replica moves-out from ineligible source broker or move-in to ineligible destination broker.
MovementExclusionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.MovementExclusionGoal
 
movementReason() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
 
moveReplicaToEnd(Replica) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Move a replica to the end of the replica list.
movesAccepted() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
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
 
MultiBrokerBalancerOperationProgressListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for a listener for the progress of a balancer operation consisting of multiple brokers (as opposed to the single-broker #SingleBrokerBalancerOperationProgressListener
MultiBrokerBalancerOperationTerminationListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for a listener that gets called when a balancer atomic operation consisting of multiple brokers reaches a terminal state.
multiEntityListBalancedIterable(List<List<T>>, int) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.EntityCombinator
The method picks totalEntitiesToSelect elements from entities and tries to keep the skew of min/max number of elements from each list to 1.
multiEntityListIterable(LinkedHashMap<List<T>, Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.EntityCombinator
Method to create an iterator over multiple list of entities.

N

name - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
name() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
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.IncrementalCPUResourceDistributionGoal
 
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.MovementExclusionGoal
 
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.ProducerInboundCapacityGoal
 
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.ResourceDistributionAbstractGoal
Get the name of this goal.
name() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
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() - Method in class com.linkedin.kafka.cruisecontrol.config.GoalConfigChangeNotifier.GoalConfigChangeListener
 
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.CellAwareGoal
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.CrossRackMovementGoal
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.MaxReplicaMovementParallelismGoal
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
name() - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
name() - Method in class io.confluent.databalancer.event.SbcEvent
The name of the event.
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
 
neededResource() - Method in class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
 
needsResource(SbcResource<?>) - Static method in class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
Factory method to get the result object.
needsResource() - Method in class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
 
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.
newEpoch(long) - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
Update the epoch and unblock waiting threads.
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
 
newHistogram(Class<?>, String) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
Register or gets the latest registered histogram.
newIncrementalBalancingEnabled(Boolean) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta.Builder
 
newIncrementalBalancingGoals(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta.Builder
 
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
 
newMeter(Class<?>, String, String, TimeUnit, Map<String, String>) - Method in class io.confluent.databalancer.metrics.DataBalancerMetricsRegistry
 
newObservers() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
newRebalancingGoals(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta.Builder
 
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
 
newTriggeringGoals(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta.Builder
 
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.analyzer.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.
nodes() - Method in class com.linkedin.kafka.cruisecontrol.common.KafkaCluster
A collection of nodes that consist the Kafka Cluster.
nodes() - Method in class com.linkedin.kafka.cruisecontrol.common.SbcClusterSnapshot
 
noGoalViolationsFound() - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
This method is invoked when Goal violation detector performs goal violation checks and doesn't find any goal violation.
NONE - Static variable in class io.confluent.databalancer.event.resource.SbcResources
A sentinel value to indicate a non-existent resource.
NonEmptyString() - Constructor for class com.linkedin.cruisecontrol.common.config.ConfigDef.NonEmptyString
 
NonExistentBrokerException(String) - Constructor for exception com.linkedin.kafka.cruisecontrol.model.ClusterModel.NonExistentBrokerException
 
nonExistentBrokers - Variable in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent.EligibleBrokers
 
NoopClusterModelStatsComparator - Class in com.linkedin.kafka.cruisecontrol.model.util
A no-op stats comparator for goals that don't care about cluster stats by treating all cluster models same/equal.
NoopClusterModelStatsComparator(String) - Constructor for class com.linkedin.kafka.cruisecontrol.model.util.NoopClusterModelStatsComparator
 
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
 
NoOpReplicaFilter - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
 
NoOpReplicaFilter() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.NoOpReplicaFilter
 
NoopSampler - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
 
NoopSampler() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.NoopSampler
 
noTaskInProgress(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
 
notifierStartTimeMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
notifyBrokerChange(Set<Integer>, BrokerChangeEvent) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Receive a notification about a set of brokers changedBrokers that have changed according to some BrokerChangeEvent event.
notifyBrokerChange(Set<Integer>, BrokerChangeEvent) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
notifyBrokerChange(Set<Integer>, BrokerChangeEvent) - Method in interface io.confluent.databalancer.DataBalanceEngine
Notify CruiseControl of some BrokerChangeEvent in a set of brokers.
notifyBrokerChange(Set<Integer>, BrokerChangeEvent) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
Notify CruiseControl of some BrokerChangeEvent for a set of brokers.
notifyBrokerStartup(AliveBrokersMetadata, Set<Integer>, Set<Integer>) - Method in class io.confluent.databalancer.event.SbcAbstractBrokerAdditionEvent
Notify SBC of the new brokers starting up
notifyDeadBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
notifyDeadBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailureDetector
 
notifyDeadBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolationDetector
Be told of brokers that have left the cluster.
notifyNewBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
 
notifyNewBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.detector.BrokerFailureDetector
 
notifyNewBrokers(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.detector.GoalViolationDetector
Be told of new brokers.
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
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.
numberOfMovements(TopicPartition) - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Retrieves the recorded number of movements of a TopicPartition.
numBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of brokers for the cluster instance that the object was populated with.
numBrokersAboveLowerBoundThreshold() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.IncrementalResourceDistributionStatsSnapshot
 
numBrokersUnderLowUtilizationThreshold() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot
 
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(short) - Method in class com.linkedin.kafka.cruisecontrol.config.BrokerCapacityInfo.BrokerCapacityInfoBuilder
 
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
 
numHotPartitions - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CapacityStatsSnapshot
 
numInterBrokerPartitionMovementsToBeRetried() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numInterBrokerPartitionMovementsToBeRetried() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the number of inter-broker tasks that are yet to be retried
numInterBrokerReplicaMovements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResultReplicaMovements
 
numIntraBrokerPartitionMovementsToBeRetried() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the number of intra-broker tasks that are yet to be retried
numIntraBrokerReplicaMovements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResultReplicaMovements
 
numLeaderReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get the number of leader replicas on this broker.
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
 
numLeaderReplicasOnEligibleSourceBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the total number of leader replicas on all source eligible brokers.
numLeaders - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
numLeaders() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
numLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResultReplicaMovements
 
numLeadershipMovementsToBeRetried() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the number of leadership movement tasks that are yet to be retried
numPartitionCells(Partition) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
 
numPartitionsWithOfflineReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of number of partitions with offline replicas in the cluster.
numPendingInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns the number of execution tasks that are pending to be executed
numPendingInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the number of pending inter-broker tasks that have not yet been executed
numPendingIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numPendingIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the number of pending intra-broker tasks that have not yet been executed
numPendingLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
numPendingLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the number of pending leadership movement tasks that have not yet been executed
numRemainingInterBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the total number of inter-broker tasks that are left to be executed
numRemainingIntraBrokerPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the total number of intra-broker tasks that are left to be executed
numRemainingLeadershipMovements() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
Returns the total number of inter-broker tasks that are left to be executed
numReplicas() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
Return total number of replicas in this cell.
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
 
numReplicas - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
numReplicas() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
numReplicas() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImagePartitionSnapshot
 
numReplicasInCluster() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get number of replicas for the cluster instance that the object was populated with.
numReplicasLowerLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
 
numReplicasOfTopicInBroker(String) - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
Get number of replicas from the given topic in this broker.
numReplicasOnEligibleSourceBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the total number of replicas in all eligible source brokers (see ClusterModel.eligibleSourceBrokers().
numReplicasRequiredByAttributeGroup(TopicPlacement) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Return the total number of replicas that should be present on a rack regardless of observer/sync-replica status
numReplicasUpperLimit - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
 
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.AnomalyStats
 
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.Cell
Get the number of replicas with the given topic name in this cell.
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.
numTopicReplicasOnEligibleSourceBrokers(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the number of replicas on eligible source brokers with the given topic name in cluster.
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
 
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 - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
numWindows - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
numWindows() - Method in class com.linkedin.kafka.cruisecontrol.model.Load
Get the number of windows in the load.
numWindowsToKeep - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
numWindowsWithExtrapolation() - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.RawMetricValues
 
NW_OUT_RATE - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 

O

observers() - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor.PartitionReplicas
 
observers() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImageReplicaInfo
 
of(long, long, Set<TopicPartition>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizationHistoryOptions
 
of(Admin, KafkaCruiseControlConfig, ConfigResource.Type, Time) - Static method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher
 
of(Integer, KafkaCruiseControlConfig, Time, KafkaCruiseControl.CcStartupMode) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
of(Resource, boolean) - Static method in class com.linkedin.kafka.cruisecontrol.model.util.BrokerByResourceUtilizationComparator
Creates a Comparator that compares Broker by their resource utilization in normal or reversed order.
of(Resource) - Static method in class com.linkedin.kafka.cruisecontrol.model.util.ReplicaByResourceUtilizationComparator
Creates a ReplicaByResourceUtilizationComparator that compares the given Resource.
of(AliveBrokersSnapshot) - Static method in class io.confluent.databalancer.BrokersMetadataSnapshot
Build a BrokersMetadataSnapshot from a given AliveBrokersSnapshot.
of(Map<Integer, BrokerRegistration>, Set<Integer>) - Static method in class io.confluent.databalancer.BrokersMetadataSnapshot
Build a BrokersMetadataSnapshot from a given map of registered brokers and set of excluded brokers.
of(T) - Static method in class io.confluent.databalancer.utils.RetryableResult.Success
 
ofFailedDescription(Throwable) - Static method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
offlineReplicas() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImageReplicaInfo
 
ofSuccessfulDescription(List<Integer>) - Static method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
ofUnexistingPartition() - Static method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
Used in cases where the underlying partition was not returned from the describe topics call.
oldestWindowIndex - Variable in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
 
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
 
onAlteredExclusions(Set<Integer>, Set<Integer>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
onAlteredExclusions(Set<Integer>, Set<Integer>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
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
 
onBrokerHealthChange(Set<Integer>, Set<Integer>, AliveBrokersMetadata) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Attempts to disable SBC if demoted brokers exist.
onBrokerHealthChange(Set<Integer>, Set<Integer>, AliveBrokersMetadata) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
onBrokersFailure(Set<Integer>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
onBrokersFailure(Set<Integer>) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
onBrokersStartup(Set<Integer>, Set<Integer>, AliveBrokersMetadata) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
onBrokersStartup(Set<Integer>, Set<Integer>, AliveBrokersMetadata) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
onChange(SbcGoalsConfig) - Method in class com.linkedin.kafka.cruisecontrol.config.GoalConfigChangeNotifier.GoalConfigChangeListener
The method that gets called whenever the goals configuration changes.
onDeactivation(BalancerStatusStateMachine.BalancerEvent) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
onDeactivation(BalancerStatusStateMachine.BalancerEvent) - Method in interface io.confluent.databalancer.DataBalanceEngine
To be called when this DataBalanceEngine should stop execution.
onDeactivation(BalancerStatusStateMachine.BalancerEvent) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
onDemandBalancednessScoreAfter() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
onDemandBalancednessScoreBefore() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
onElection(AliveBrokersMetadata, Optional<ConfigurationsImage>) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Start-up the DataBalanceManager.
onElection(AliveBrokersMetadata) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
onExpiredHistory(SuspendedTopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.ProposalGenerator
 
onExpiredHistory(H) - Method in interface io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistoryListener
Called when history item is expired.
onFailureThen(RebalanceStep) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.RebalanceStep
 
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.AnomalyStats
 
onLeaderUpdate(LeaderAndEpoch) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
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.
onMetadataImageUpdate(MetadataDelta, MetadataImage) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
onNewHistory(SuspendedTopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.ProposalGenerator
 
onNewHistory(H) - Method in interface io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistoryListener
Called when new history item is recorded.
onProgressChanged(S, Long, Long, Exception, S, Long, Long, Exception) - Method in interface io.confluent.databalancer.operation.EvenClusterLoadStateProgressListener
Called whenever the state of the balancer operation EvenClusterLoad changes.
onProgressChanged(Set<Integer>, S, Exception) - Method in interface io.confluent.databalancer.operation.MultiBrokerBalancerOperationProgressListener
Called whenever the state of the balancer operation operation changes.
onProgressChanged(EvenClusterLoadStateMachine.EvenClusterLoadState, Long, Long, Exception, EvenClusterLoadStateMachine.EvenClusterLoadState, Long, Long, Exception) - Method in class io.confluent.databalancer.operation.PersistEvenClusterLoadStateListener
 
onProgressChanged(Set<Integer>, BrokerRemovalStateMachine.BrokerRemovalState, Exception) - Method in class io.confluent.databalancer.operation.PersistRemoveApiStateListener
 
onProgressChanged(int, S, Exception) - Method in interface io.confluent.databalancer.operation.SingleBrokerBalancerOperationProgressListener
Called whenever the state of the balancer operation operation changes.
onResignation() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
When the broker ceases to be the primary DataBalancer in the cluster.
onResignation() - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
onTerminalState(Set<Integer>, S, Exception) - Method in interface io.confluent.databalancer.operation.MultiBrokerBalancerOperationTerminationListener
Called when the state of a balancer operation reaches a terminal point
onTerminalState(int, S, Exception) - Method in interface io.confluent.databalancer.operation.SingleBrokerBalancerOperationTerminationListener
Called when the state of a balancer operation reaches a terminal point
onUpdatedEpoch(long) - Method in class com.linkedin.kafka.cruisecontrol.ProposalGenerator
Update the history epoch of proposal generator and clear the suspended topic partitions with outdated epoch.
onUpdatedEpoch(long) - Method in interface io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistoryListener
Called when epoch is bumped.
open(long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
Open this metric sample with a timestamp denoting the timestamp of the oldest metric contained in this sample.
OpenCensusConverter - Class in io.confluent.cruisecontrol.metricsreporter
 
OpenCensusConverter() - Constructor for class io.confluent.cruisecontrol.metricsreporter.OpenCensusConverter
 
OpenTelemetryConverter - Class in io.confluent.cruisecontrol.metricsreporter
 
OpenTelemetryConverter() - Constructor for class io.confluent.cruisecontrol.metricsreporter.OpenTelemetryConverter
 
operation() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorNotification
 
operationInProgress(ExecutorState.State, ExecutionTaskTracker.ExecutionTasksSummary, int, int, int, String, 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.BrokerRemovalContext
 
OperationRetryer<T> - Class in io.confluent.databalancer.utils
A helper class that retries a given operation up to the denoted max retry Duration.
OperationRetryer(Time, Duration, Duration, String) - Constructor for class io.confluent.databalancer.utils.OperationRetryer
 
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
 
OptimizationMetrics - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
 
OptimizationMetrics(DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
 
optimizationOptions(OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger.Builder
 
OptimizationOptions - Class in com.linkedin.kafka.cruisecontrol.analyzer
A class to indicate options intended to be used during optimization of goals.
OptimizationOptions.Builder - Class in com.linkedin.kafka.cruisecontrol.analyzer
 
OptimizationResult - Class in com.linkedin.kafka.cruisecontrol.analyzer
OptimizationResult is used to store an externally-readable (by humans) result of an OptimizationResult.
OptimizationResult(OptimizerResult) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
 
optimizationResult() - Method in class com.linkedin.kafka.cruisecontrol.RebalanceResult
 
OptimizationResult.PlaintextSummary - Class in com.linkedin.kafka.cruisecontrol.analyzer
 
optimizationResultBuilder - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
optimizations(ClusterModel, GoalsConfig, OptimizationOptions) - 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, Optional<OptimizationMetrics>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
The entry-point to a goal, this method mutates the given #ClusterModel object by optimizing it in accordance to the goal
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, Optional<OptimizationMetrics>) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.Goal
The method will be given a cluster model.
optimizerResult - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
 
optimizerResult() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
 
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.RebalanceResult
 
OptimizerResultReplicaMovements - Class in com.linkedin.kafka.cruisecontrol.analyzer
Contains all replica movement statistics of an SBC-computed even cluster load plan.
OptimizerResultReplicaMovements(Set<ExecutionProposal>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResultReplicaMovements
 
opType - Variable in class io.confluent.databalancer.operation.BrokerRemovalExclusionCancellationData
 
orderInGroup - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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
overrideInterBrokerTasksWithOrdering(Collection<ExecutionTask>, Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskPlanner
Overrides the existing inter-broker replica movements with a given set of ExecutionTasks.

P

parallelStream() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
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(TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Partition
Constructor for Partition class.
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.config.KafkaCruiseControlConfig
partition.metric.sample.store.topic
PARTITION_METRIC_SAMPLE_STORE_TOPIC_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
PARTITION_METRICS_WINDOW_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
partition.metrics.windows.ms
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Check whether the given action is acceptable by this goal.
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalBalancingActionAcceptance
Checks if the action on the partition specified by the PartitionBalancingAction is acceptable.
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.MovementExclusionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundUsageDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Check whether given partition move is acceptable by this goal.
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
Accept iff all replica brokers will be in the same cell after the move
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.CrossRackMovementGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.MaxReplicaMovementParallelismGoal
All replica in a PartitionBalancingAction should belong to same partition.
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
partitionActionAcceptance(PartitionBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalBalancingActionAcceptance
Check if requirements of this goal are not violated if this partition action is applied to the given cluster state, false otherwise.
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
The partition moves proposed by this goal should already be honoring rack awareness, so the method trivially returns true.
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.AbstractAcceptanceGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
partitionActionSelfSatisfied(ClusterModel, PartitionBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
PartitionBalancingAction - Class in com.linkedin.kafka.cruisecontrol.analyzer
 
PartitionBalancingAction(Map<Replica, Broker>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
Create a partition balancing action that will move all replica of a partition from one set of brokers to another set of brokers.
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
 
partitionHasReplicaOnIgnoredBroker(Partition) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
 
partitionId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the partition Id that is impacted by the balancing action.
partitionId() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
partitionId() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImagePartitionSnapshot
 
partitionInfoSnapshot(TopicsMetadataSnapshot.PartitionSnapshot) - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot
 
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
 
partitionMetricDef() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
partitionMetricDefId(KafkaMetricDef) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
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
 
partitionMovesAccepted() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
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
 
PartitionReplicas(List<Integer>, List<Integer>) - Constructor for class com.linkedin.kafka.cruisecontrol.executor.Executor.PartitionReplicas
 
partitionsBeingReassigned(SbkAdminUtils) - Static method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Returns the TopicPartitions currently being reassigned
partitionsByTopic() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot
 
partitionsByTopicPartition() - Method in class com.linkedin.kafka.cruisecontrol.common.SbcClusterSnapshot
 
partitionSyncBrokers() - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Get the set of brokers that contain sync(non-observer) replicas of the partition
partitionSyncBrokersOfStateOtherThan(Broker.Strategy) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
Returns all sync brokers of the partition with state other than the one provided.
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, Map<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
 
pending() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Mark the task back in the pending state.
performLeadershipMovement(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
performReplicaMovement(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
PersistEvenClusterLoadStateListener - Class in io.confluent.databalancer.operation
An implementation of #EvenClusterLoadStateProgressListener that persists all state updates for EvenClusterLoad operation to disk.
PersistEvenClusterLoadStateListener(ApiStatePersistenceStore) - Constructor for class io.confluent.databalancer.operation.PersistEvenClusterLoadStateListener
 
PersistRemoveApiStateListener - Class in io.confluent.databalancer.operation
An implementation of #MultiBrokerBalancerOperationProgressListener that persists all state updates for a single broker removal operation to disk
PersistRemoveApiStateListener(ApiStatePersistenceStore, boolean) - Constructor for class io.confluent.databalancer.operation.PersistRemoveApiStateListener
 
placementPolicy() - Method in class com.linkedin.kafka.cruisecontrol.model.Tenant
Return the placement policy.
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.BrokerRemovalContext
 
PlanComputationOptions - Class in com.linkedin.kafka.cruisecontrol
 
PlanComputationOptions(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
 
planExecutionException() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
Return the exception, if any, generated by the plan execution phase.
planExecutionException(Exception) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
Save the exception generated by plan execution.
planExecutionSuccess() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
Check the status of the plan execution phase of broker removal.
planExecutionSuccess(boolean) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
Set the state of the plan execution phase of broker removal.
PNW_OUT_RATE - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
populateAllPartitionLoads(Map<PartitionEntity, ValuesAndExtrapolations>, Map<ReplicaEntity, ValuesAndExtrapolations>, Cluster, ClusterModel, Map<TopicPartition, Map<Integer, String>>, GeneratingClusterModel, Set<TopicPartition>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitor
Populate all the given partition metrics in the cluster model.
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
 
potentialBytesOutRate - Variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
potentialBytesOutRate() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
potentialLeadershipLoadFor(Integer) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Get the leadership load for given broker id.
potentialLeadershipUtilizationFor(Integer) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
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.
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.
prepend(SbcEvent) - Method in class io.confluent.databalancer.event.SbcEventQueue
Prepend an event to the front of the SBC EventQueue.
prevArrayIndex(int) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
The previous array index of a given array index.
previousState() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
previousStateCreatedAt() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
previousStateException() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
previousStateLastUpdatedAt() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
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<PartitionInfo>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.CruiseControlMetricsProcessor
Process all the added CruiseControlMetric to get the MetricSampler.Samples
PRODUCER_IN_CAPACITY_BYTES_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
PRODUCER_INBOUND_CAPACITY_THRESHOLD_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
producer.inbound.capacity.threshold
ProducerInboundCapacityGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
A hard goal which triggers on producer clients' inbound traffic to partition leaders
ProducerInboundCapacityGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProducerInboundCapacityGoal
Constructor for Producer Inbound Capacity Goal.
progress() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
progressCallback - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
proposal - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
proposal() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
ProposalGenerator - Class in com.linkedin.kafka.cruisecontrol
 
ProposalGenerator(KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.ProposalGenerator
 
ProposalLeaderboard - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
Tracks the top N most impactful DetailedProposal.Result separated by broker and acceptance.
ProposalLeaderboard(ProposalObservabilityTrackingOptions) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard
 
ProposalLeaderboard.Result - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
The final resulting leaderboard for each broker.
ProposalObservabilityTrackingOptions - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
Options that enable the tracking of the top ProposalObservabilityTrackingOptions.maxNumberOfProposals most impactful proposals generated by a goal.
ProposalObservabilityTrackingOptions(boolean, int) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalObservabilityTrackingOptions
 
proposalReady() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
proposals - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
proposals(Set<ExecutionProposal>) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
proposalsAccepted() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
proposalsAcceptedPercent() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
proposalsGenerated() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
proposalsRejected() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
proposalsRejectedPercent() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
proposalStats(ProposalStats) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult.Builder
 
proposalStats() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult
 
ProposalStats - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
A class to track the results of Goal optimization (specifically proposal generation and acceptance) for a single goal in Self-Balancing, for reporting after the fact.
ProposalStats.Builder - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
A builder to build a ProposalStats object.
proposalStatsBuilder - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
proposalStatsByGoalName() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
proposalSummary(String) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
 
proposalTrackingOptions() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Top proposal tracking enables goals to track the top ProposalObservabilityTrackingOptions.maxNumberOfProposals proposals they generated, separated by the ones that were accepted and rejected.
proposalTrackingOptions() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalCPUResourceDistributionGoal
Top proposal tracking enables goals to track the top ProposalObservabilityTrackingOptions.maxNumberOfProposals proposals they generated, separated by the ones that were accepted and rejected.
proposingGoal() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
 
provideResource(SbcResource<R>, R) - Method in interface io.confluent.databalancer.event.resource.BalancerResourceManager
Provide a resource.
provideResource(SbcResource<R>, R) - Method in class io.confluent.databalancer.event.resource.SbcResourceManager
Provide the given SbcResource (associate the SbcResource name with a value).
putBrokerRemovalFuture(ImmutableSet<Integer>, 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
 
putRemovalRecord(BrokerRemovalStateRecord) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
 

Q

quantile() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.QuantileValue
quantile of a distribution
quantiles() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.Summary
 

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, liveliness 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.
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
readyGoals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.AnalyzerState
 
reason - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
reasonOfLatestPauseOrResume() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
 
reassigningPartitions() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
reassigningPartitions() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
Returns the partitions that are currently being reassigned
reassigningPartitions() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
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, produce-in 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.ResourceDistributionAbstractGoal
Main entry point for proposing the movements to balance the given broker.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
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.CellAwareGoal
For each replica in the broker, if the replicas of its partition are not all in the same cell, try to move them to the leader cell.
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.
rebalanceForBroker(Broker, ClusterModel, Set<Goal>, OptimizationOptions) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
rebalanceForEvenClusterLoad(GoalsConfig, boolean, ModelCompletenessRequirements, OperationProgress, boolean, String, boolean, boolean, Collection<String>, boolean) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Performs a general rebalance on the cluster for the even cluster load task.
RebalanceResult - Class in com.linkedin.kafka.cruisecontrol
Result of a rebalance operation request, including information about the plan proposal that was computed and whether or not the plan was executed.
RebalanceResult(OptimizerResult, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.RebalanceResult
 
RebalanceStep - Interface in com.linkedin.kafka.cruisecontrol.analyzer.goals
rebalancingGoals() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
Retrieve the non-incremental rebalancing goals config.
rebalancingGoals(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig.SbcGoalsConfigBuilder
 
RECEIVE_BUFFER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
receive.buffer.bytes
recentlyRemovedBrokers - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
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
 
recentlyRemovedBrokers(KafkaCruiseControlContext) - Static method in class com.linkedin.kafka.cruisecontrol.ProposalGenerator
Get the set of broker IDs that have recently been removed from the cluster via a removeBrokers call.
recommendedValues() - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
recommendedValues(List<Object>) - Method in class com.linkedin.cruisecontrol.common.config.ConfigValue
 
recommender - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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.
record(TopicPartitionMovement) - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationHistory
Records a new TopicPartitionMovement and perform necessary subsequent actions:
recordCapacityStats(CapacityGoal, CapacityStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
Given a CapacityStatsSnapshot, record the appropriate threshold values that a capacity hard-goal uses to perform its optimization run.
recordDistributionBalanceStats(ResourceDistributionAbstractGoal, ResourceDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
Given a ResourceDistributionStatsSnapshot, record the appropriate threshold values that a distribution soft-goal uses to perform its optimization run.
recordDistributionBalanceStats(ReplicaDistributionAbstractGoal, ReplicaDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
Given a ReplicaDistributionStatsSnapshot, record the appropriate threshold values that a replica distribution soft-goal uses to perform its optimization run.
recordIncrementalDistributionBalanceStats(IncrementalResourceDistributionGoal, IncrementalResourceDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.OptimizationMetrics
Given a ResourceDistributionStatsSnapshot, record the appropriate threshold values that a distribution soft-goal uses to perform its optimization run.
recordMetric(CruiseControlMetric) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
recordReplicaChange(String) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult.Builder
 
recordTopicPartitionMovement(TopicPartitionMovement) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult.Builder
 
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.
registerCancelledReassignmentsGauge(Supplier<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
registerEnabledEventIfDisabled() - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
If balancer was disabled and we are enabling it again, move the state machine to STARTING state by sending BALANCER_ENABLED event.
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(BalancerStatusStateMachine.BalancerEvent) - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
 
registerEvent(BalancerStatusStateMachine.BalancerEvent, Exception) - Method in class io.confluent.databalancer.operation.BalancerStatusTracker
 
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
 
registerEvent(EvenClusterLoadStateMachine.EvenClusterLoadEvent) - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
 
registerEvent(EvenClusterLoadStateMachine.EvenClusterLoadEvent, Exception) - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
 
registerExecutionStartedGauge(Supplier<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
registerExecutionStoppedGauge(Supplier<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
registerFailedReassignmentCancellationsGauge(Supplier<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
registerFilter(Predicate<Replica>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ChainReplicaFilter
Adds a filter to the filter chain.
registerFilter(Predicate<T>) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.EntityFilter
Register a filter.
registerFilter(Predicate<Replica>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NoOpReplicaFilter
A NoOp register.
registerListener(GoalConfigChangeNotifier.GoalConfigChangeListener) - Method in interface com.linkedin.kafka.cruisecontrol.config.GoalConfigChangeNotifier
Registers a listener that gets notified when the goal configs change.
registerListener(GoalConfigChangeNotifier.GoalConfigChangeListener) - Method in class com.linkedin.kafka.cruisecontrol.config.UpdatableSbcGoalsConfig
Register a GoalConfigChangeNotifier.GoalConfigChangeListener that will be called whenever the goal config is updated.
registerMetrics(Class<?>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
registerMetrics(Class<?>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.CapacityGoalMetrics
 
registerMetrics(Class<?>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.ResourceDistributionGoalMetrics
 
rejectingGoal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AcceptanceResult
 
rejectingGoalCount() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
For a given goal, it stores information about what other goals did reject its proposals and how many times exactly.
reloadInterBrokerTasksToBeRetried(Cluster) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Reloads the inter-broker tasks that are queued up for retries
relocateLeadership(TopicPartition, int, int) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
(1) Removes leadership from source replica.
relocateReplica(ClusterModel, TopicPartition, int, int) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
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.
remainingInterBrokerDataToMoveByDestinationBroker() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
 
remainingInterBrokerDataToMoveByDestinationBroker() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
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.
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
remove(Object) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
removeAll(Collection<?>) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
removeBrokerRemovalFuture(ImmutableSet<Integer>) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
Clean up a stored (in memory) future of the broker removal operation
removeBrokers(Map<Integer, Optional<Long>>, boolean, BalanceOpExecutionCompletionCallback, BrokerRemovalCallback, String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Broker removal consists of 4 steps: 1.
removeBrokers(Map<Integer, Optional<Long>>, boolean, String) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
removeBrokers(Map<Integer, Optional<Long>>, boolean, String) - Method in interface io.confluent.databalancer.DataBalanceEngine
Schedules the removal of a set of brokers
removeBrokers(Map<Integer, Optional<Long>>, boolean, String) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
Request is invalid if its get handled by SBK while its not controller.
removeEntities(Set<E>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Remove the given set of entities from the MetricSampleAggregator.
removeEntityGroup(Set<String>) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Remove the given set of entity groups from the MetricSampleAggregator.
removeIf(Predicate<? super T>) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
removeReplica(int, TopicPartition) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Remove and get removed replica from the cluster.
removeTaskForBroker(int, int) - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Remove N tasks from the accounting for a broker.
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(TopicPartition, Broker, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Replica
The constructor for an online replica without disk information.
Replica(TopicPartition, Broker, boolean, boolean, Disk, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Replica
A constructor for a replica.
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
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CapacityGoal
Check whether the given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskCapacityGoal
 
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DiskUsageDistributionGoal
 
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalBalancingActionAcceptance
Checks if the action on the replica specified by the ReplicaBalancingAction is acceptable.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
Check whether given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskCapacityGoal
Check whether the given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IntraBrokerDiskUsageDistributionGoal
Check whether given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, 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.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderReplicaDistributionGoal
Check whether the given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.MovementExclusionGoal
 
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundCapacityGoal
 
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkInboundUsageDistributionGoal
 
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.PotentialNwOutGoal
Check whether given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
Check whether given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Check whether given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionGoal
Check whether the given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Check whether given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.TopicReplicaDistributionGoal
Check whether the given action is acceptable by this goal.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
Accept iff partition has only one replica, or if destination cell is same as source cell.
replicaActionAcceptance(ReplicaBalancingAction, 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.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.MaxReplicaMovementParallelismGoal
Brokers can have up to NUM_CONCURRENT_PARTITION_MOVEMENTS_PER_BROKER incoming/outgoing at one time; if a partition has multiple replicas moving at once, each new destination replica counts as a movement, to avoid overwhelming the source.
replicaActionAcceptance(ReplicaBalancingAction, 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.
replicaActionAcceptance(ReplicaBalancingAction, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalBalancingActionAcceptance
Check if requirements of this goal are not violated if this replica action is applied to the given cluster state, false otherwise.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalResourceDistributionGoal
Check if requirements of this goal are not violated if this action is applied to the given cluster state.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.LeaderBytesInDistributionGoal
 
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.RackAwareGoal
As the list of eligible brokers were passed in by RackAwareGoal.rebalanceForBroker(Broker, ClusterModel, Set, OptimizationOptions) method of this class, any replica movement will be valid and should be acceptable.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
 
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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.
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - 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
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.CellAwareGoal
 
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
 
replicaActionSelfSatisfied(ClusterModel, ReplicaBalancingAction) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
replicaBalancePercentage() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get replica balance percentage for ReplicaDistributionGoal.
ReplicaBalancingAction - Class in com.linkedin.kafka.cruisecontrol.analyzer
Represents the load balancing operation over a replica for Kafka Load GoalOptimizer.
ReplicaBalancingAction(TopicPartition, Integer, Integer, ActionType) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Constructor for creating a balancing proposal with given topic partition, source and destination broker id, and balancing action type.
ReplicaBalancingAction(TopicPartition, Integer, Integer, ActionType, TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
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.
ReplicaBalancingAction(TopicPartition, Disk, Disk, ActionType) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Constructor for creating a balancing proposal with given topic partition, source and destination disk (on the same broker), and balancing action type.
ReplicaBalancingAction(TopicPartition, Disk, Disk, ActionType, TopicPartition) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
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.
ReplicaByResourceUtilizationComparator - Class in com.linkedin.kafka.cruisecontrol.model.util
Sort replicas by utilization value in descending order.
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.
ReplicaCapacityGoal(Random) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
 
ReplicaCapacityGoal(BalancingConstraint) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaCapacityGoal
Public for testing.
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
 
ReplicaDistributionGoalMetrics - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
 
ReplicaDistributionGoalMetrics(String, DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.ReplicaDistributionGoalMetrics
 
ReplicaDistributionStatsSnapshot - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A snapshot (taken during a single replica distribution goal's optimization run), containing statistics of replica distribution in a cluster.
ReplicaDistributionStatsSnapshot(BrokerResourceStats, BrokerResourceStats, DistributionThresholdUtils.ReplicaThresholds) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ReplicaDistributionStatsSnapshot
 
ReplicaDistributionStatsSnapshot.ReplicaResource - Enum in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
 
ReplicaEntity - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
The Entity class representing a Replica used by MetricSampleAggregator
ReplicaEntity(PartitionInfo, int, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
 
replicaExclusions() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
replicaExclusions() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
 
replicaExclusions() - Method in class io.confluent.databalancer.BrokersMetadataSnapshot
Returns the active broker replica placement exclusions in the cluster
replicaExclusionStatus() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
Return the exclusion status for this state
replicaExclusionStatus() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
replicaFilter() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.NetworkOutboundUsageDistributionGoal
This goal should ignore moving follower replicas that do not have FFF load, i.e.
replicaFilter() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
Filter out replicas that are not relevant to the balancing algorithm of the goal.
replicaMetricDef() - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
replicaMetricDefId(KafkaMetricDef) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
 
ReplicaMetricSample - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling.holder
The class that hosts all the metric samples for a replica of a partition.
ReplicaMetricSample(int, PartitionInfo, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaMetricSample
Create a Sample for the replica of the partition tp residing on the broker brokerId.
replicaMetricSamples() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.Samples
 
replicaMovementParallelism() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
replicaMovements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
ReplicaMovementStrategy - Interface in com.linkedin.kafka.cruisecontrol.executor.strategy
 
replicaMoves() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
Get the replica moves.
ReplicaPlacementGoal - Class in io.confluent.cruisecontrol.analyzer.goals
 
ReplicaPlacementGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Constructor used by tests
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.executor.Executor.PartitionReplicas
 
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.Cell
Get the list of replicas in the cell.
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.
REPLICAS - Static variable in class com.linkedin.kafka.cruisecontrol.monitor.BasicStats
 
replicas() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImageReplicaInfo
 
replicaSet - Variable in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
This represents the list of all node ids for all replicas.
replicasNotInCell(Cell) - Method in class com.linkedin.kafka.cruisecontrol.model.Partition
 
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.
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
 
ReplicaThresholds(int, int) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
 
replicaThresholds() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ReplicaDistributionStatsSnapshot
 
replicaThresholds - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ReplicaDistributionAbstractGoal
 
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
 
reportExecutionTime(long) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
reportProposals(Collection<ExecutionProposal>) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionMetricsReporter
 
REQUEST_CONTRIBUTION_WEIGHT_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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
 
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
 
requiredParallelism() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
 
requireLessLoad - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
requirements() - Method in class com.linkedin.kafka.cruisecontrol.config.GoalsConfig
requireMoreLoad - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
requiresTopicPlacement - Variable in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.Builder
 
requiresTopicPlacements() - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
 
reservationHandle() - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
reserveAndAbortOngoingExecutions(Duration, String) - 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.
reserveAndAbortOngoingExecutions(Duration, boolean, String) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
An overloaded variant of Executor.reserveAndAbortOngoingExecutions(Duration, String) that provides the option to explicitly tell whether metrics should be invalidated or not.
reserveAndAbortOngoingExecutions(Executor, Time, Duration, Duration, boolean, String) - Static method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorReservationHandle
Attempts to acquire a reservation on the given executor, blocking other threads from executing proposals and, if successfully reserved, aborts all of its ongoing executions.
resetDetectorState() - Method in class com.linkedin.kafka.cruisecontrol.detector.CpuUtilizationDetector
 
resetDetectorState() - Method in class com.linkedin.kafka.cruisecontrol.detector.DiskUtilizationDetector
 
resetDetectorState() - Method in interface com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationDetector
 
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.cruisecontrol.metricdef.MetricInfo
 
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.DistributionThresholdUtils.ResourcePercentageThresholds
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalCPUResourceDistributionGoal
 
resource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
resource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CapacityStatsSnapshot
 
resource - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
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.ProducerInboundCapacityGoal
 
resource() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
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
 
resource() - Method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
The metric resource of the Kafka metric def.
RESOURCE_UTILIZATION_DETECTOR_ENABLED_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
RESOURCE_UTILIZATION_DETECTOR_INTERVAL_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
resourceBalancePercentage(Resource) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Get the balance percentage for the requested resource.
ResourceComparator(Resource, BalancingConstraint) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Broker.ResourceComparator
 
ResourceDistributionAbstractGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
This class contains shared logic that could be used in balancing a Kafka cluster w.r.t its resource utilization distribution.
ResourceDistributionAbstractGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
ResourceDistributionAbstractGoal.ChangeType - Enum in com.linkedin.kafka.cruisecontrol.analyzer.goals
Whether bring load in or bring load out.
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
 
ResourceDistributionGoalMetrics - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics
A long-lived object managing the latest optimization run's resource distribution metrics for a given BaseDistributionGoalMetrics.goalName: All of the metrics defined in BaseDistributionGoalMetrics.
ResourceDistributionGoalMetrics(String, DataBalancerMetricsRegistry, Class<?>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.ResourceDistributionGoalMetrics
 
ResourceDistributionLogger - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.util
 
ResourceDistributionLogger.Builder - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.util
 
ResourceDistributionStatsSnapshot - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A snapshot (taken during a single resource distribution goal's optimization run), containing statistics of resource usage in a cluster.
ResourceDistributionStatsSnapshot.ResourceValueThresholds - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals.internals
A POJO that holds particular thresholds related to the balance of particular Resource distribution, in absolute values.
resourceLoad - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
resourceManager() - Method in class io.confluent.databalancer.SbcContext
 
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
 
resourceToPartitionMetricIds(Resource) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
Used in testing partition sample aggregator.
resourceToPartitionMetricInfo(Resource) - Static method in enum com.linkedin.kafka.cruisecontrol.monitor.metricdefinition.KafkaMetricDef
Used in testing partition sample aggregator.
ResourceUtilizationAlertType - Enum in com.linkedin.kafka.cruisecontrol.detector.notifier
Enum that defines resource utilization alert types and corresponding metric values.
ResourceUtilizationCommonConfig - Class in com.linkedin.kafka.cruisecontrol.config
Wrapper class for storing common configs for detectors implementing ResourceUtilizationDetector
ResourceUtilizationCommonConfig(int, double, double) - Constructor for class com.linkedin.kafka.cruisecontrol.config.ResourceUtilizationCommonConfig
 
ResourceUtilizationDetector - Interface in com.linkedin.kafka.cruisecontrol.detector
Interface for detectors that use ClusterModel to get resource utilization information.
ResourceUtilizationHandler - Class in com.linkedin.kafka.cruisecontrol.detector
Class for monitoring cluster resource utilization.
ResourceUtilizationHandler(KafkaCruiseControlConfig, LoadMonitor, Time, DataBalancerMetricsRegistry) - Constructor for class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationHandler
 
resourceUtilizationStats() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
Get resource utilization stats for the cluster instance that the object was populated with.
ResourceUtilizationWindow - Class in com.linkedin.kafka.cruisecontrol.detector
Utility class for storing utilization values in a rolling window.
ResourceUtilizationWindow() - Constructor for class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
 
resourceValueThresholds() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot
 
ResourceValueThresholds(double, double, double, double, Resource) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
ResourceVisitor<T> - Interface in com.linkedin.kafka.cruisecontrol.common
Visitor for the resource enum to be able to act on different resources.
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcBalancerStatusEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcComputeEvenClusterLoadPlanEvent
Responds to the client with an error or a value.
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcEvenLoadStatusEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcEvent
This method is invoked when an operation completes (the SbcEvent.SbcEventHandlerResult does not indicate that any resources are needed to continue.
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcInternalEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcListBrokerAdditionsEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcListBrokerRemovalsEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.event.SbcTriggerEvenClusterLoadEvent
 
respondToClient(ApiError, SbcEvent.SbcEventHandlerResult) - Method in class io.confluent.databalancer.SbcCellLoadEvent
 
Result(int, List<DetailedProposal.Result>, List<DetailedProposal.Result>) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerProposalLeaderboard.Result
 
result(boolean) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
Result(DetailedProposal, boolean) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
Result(Map<Integer, BrokerProposalLeaderboard.Result>, int) - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard.Result
 
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.
retainAll(Collection<?>) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
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<String>) - 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
 
RetryableOperation<T> - Interface in io.confluent.databalancer.utils
An operation that can be retried via OperationRetryer
RetryableResult<T> - Interface in io.confluent.databalancer.utils
Implementation of this interface is returned by the operation being retired to control next step in OperationRetryer.
RetryableResult.Failure<T> - Class in io.confluent.databalancer.utils
An instance of this Class is returned by RetryableOperation to indicate that the operation should no longer be retried.
RetryableResult.Incomplete<T> - Class in io.confluent.databalancer.utils
An instance of this Class is returned by RetryableOperation to indicate that the operation should be retried.
RetryableResult.Success<T> - Class in io.confluent.databalancer.utils
An instance of this Class is returned by RetryableOperation to indicate successful completion of a RetryableOperation.
reverselySortedIterator() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
 
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.detector.ResourceUtilizationHandler
 
run() - Method in class com.linkedin.kafka.cruisecontrol.statemachine.BrokerRemovalTask
 
run() - Method in interface com.linkedin.kafka.cruisecontrol.statemachine.Task
 
run() - Method in class io.confluent.databalancer.event.SbcEvent
Concrete, final implementation of Event.run().
run() - Method in interface io.confluent.databalancer.utils.RetryableOperation
Run the underlying operation.
running(int, Map<Long, Float>, int, int, Map<TopicPartition, List<SampleExtrapolation>>, String) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.LoadMonitorState
 
runWithRetries(RetryableOperation<T>) - Method in class io.confluent.databalancer.utils.OperationRetryer
Runs the given RetryableOperation with an unlimited amount of retries, waiting OperationRetryer.retryWaitDuration between retries and retrying for a duration up to OperationRetryer.maxRetryDuration

S

sampleCloseTime - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
sampleCloseTime() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
The time upon which the sample was closed.
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
 
sampleOpenTime - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
sampleOpenTime() - Method in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
The time upon which the sample was opened.
Samples(Set<ReplicaMetricSample>, Set<PartitionMetricSample>, Set<BrokerMetricSample>) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricSampler.Samples
 
SampleStoreTopicCleanUp - Class in com.linkedin.kafka.cruisecontrol.monitor.sampling
 
SampleStoreTopicCleanUp() - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.sampling.SampleStoreTopicCleanUp
 
sampleType - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
sampling(int, Map<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.
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.
save(Map<Integer, Long>) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
Save list of failed brokers to the persistence store.
save(EvenClusterLoadStateRecord) - Method in class io.confluent.databalancer.persistence.ApiStatePersistenceStore
Method to save EvenClusterLoad status
SBC_ENGINE - Static variable in class io.confluent.databalancer.event.resource.SbcResources
 
SbcAbstractBrokerAdditionEvent - Class in io.confluent.databalancer.event
An SbcEvent that is generated whenever brokers join the Kafka cluster, and may need to be added.
SbcAbstractBrokerAdditionEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcAbstractBrokerAdditionEvent
 
SbcAbstractScheduleBrokerRemovalEvent - Class in io.confluent.databalancer.event
An SbcEvent that is generated whenever an explicit user request to remove brokers from the cluster is processed.
SbcAbstractScheduleBrokerRemovalEvent(SbcContext, List<Integer>, boolean, ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Constructor for class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent
 
SbcAbstractScheduleBrokerRemovalEvent.EligibleBrokers - Class in io.confluent.databalancer.event
 
SbcAbstractStartupEvent - Class in io.confluent.databalancer.event
An SbcEvent generated whene it is time to start SBC up.
SbcAbstractStartupEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcAbstractStartupEvent
 
SbcAlteredExclusionsEvent - Class in io.confluent.databalancer.event
An event that is generated wheneven SBC is notified that replica exclusions are altered.
SbcAlteredExclusionsEvent(SbcContext, Set<Integer>, Set<Integer>) - Constructor for class io.confluent.databalancer.event.SbcAlteredExclusionsEvent
 
SbcBalancerStatusEvent - Class in io.confluent.databalancer.event
 
SbcBalancerStatusEvent(SbcContext, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<BalancerStatusDescriptionInternal>) - Constructor for class io.confluent.databalancer.event.SbcBalancerStatusEvent
 
SbcBrokerFailureEvent - Class in io.confluent.databalancer.event
An SbcEvent that is generated whenever SBC is notified of brokers that have failed (left the cluster while still owning partitions).
SbcBrokerFailureEvent(SbcContext, Set<Integer>) - Constructor for class io.confluent.databalancer.event.SbcBrokerFailureEvent
 
SbcCellLoadEvent - Class in io.confluent.databalancer
 
SbcCellLoadEvent(SbcContext, List<Integer>, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<CellLoadDescriptionInternal>) - Constructor for class io.confluent.databalancer.SbcCellLoadEvent
 
SbcClusterSnapshot - Class in com.linkedin.kafka.cruisecontrol.common
SbcClusterSnapshot is light-weight POJO snapshot in time of a described Kafka cluster from the point view of SBC.
SbcClusterSnapshot(Collection<Node>, Map<TopicPartition, PartitionInfo>) - Constructor for class com.linkedin.kafka.cruisecontrol.common.SbcClusterSnapshot
 
SbcComputeEvenClusterLoadPlanEvent - Class in io.confluent.databalancer.event
An SBC event that asks SBC to compute an even cluster load plan.
SbcComputeEvenClusterLoadPlanEvent(SbcContext, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadPlanInternal>) - Constructor for class io.confluent.databalancer.event.SbcComputeEvenClusterLoadPlanEvent
 
SbcConfigUpdateEvent - Class in io.confluent.databalancer.event
A sub-event of SbcMetadataUpdateEvent, containing a config delta update to be applied to SBC.
SbcConfigUpdateEvent(SbcContext, ConfigurationsDelta) - Constructor for class io.confluent.databalancer.event.SbcConfigUpdateEvent
 
SbcContext - Class in io.confluent.databalancer
Layer-specific data for use by SBC operations.
SbcContext(KafkaDataBalanceManager, SbcEventQueue, BalancerResourceManager, KafkaConfig, Time) - Constructor for class io.confluent.databalancer.SbcContext
 
SbcDataBalanceManager - Class in io.confluent.databalancer
The initial entry class for Self-Balancing Clusters (SBC), which implements the DataBalanceManager interface.
SbcDataBalanceManager(KafkaConfig, Optional<Endpoint>) - Constructor for class io.confluent.databalancer.SbcDataBalanceManager
Creates a SbcDataBalanceManager and conditionally set bootstrap server endpoint.
SbcEvenLoadStatusEvent - Class in io.confluent.databalancer.event
 
SbcEvenLoadStatusEvent(SbcContext, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<EvenClusterLoadStatusDescriptionInternal>) - Constructor for class io.confluent.databalancer.event.SbcEvenLoadStatusEvent
 
SbcEvent - Class in io.confluent.databalancer.event
An abstract event that can be submitted to the SbcEventQueue.
SbcEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcEvent
 
SbcEvent.SbcEventHandlerResult - Class in io.confluent.databalancer.event
A simple class to represent the success/failure of event handlers.
SbcEventHandlerResult() - Constructor for class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
The "event is completed" result.
SbcEventQueue - Class in io.confluent.databalancer.event
The basic SBC Event Queue.
SbcEventQueue(DataBalancerMetricsRegistry) - Constructor for class io.confluent.databalancer.event.SbcEventQueue
Create the SbcEventQueue.
SbcGoalsConfig - Class in com.linkedin.kafka.cruisecontrol.config
An immutable snapshot of the configured set of SBC Goals along with their ModelCompletenessRequirements.
SbcGoalsConfig(List<Goal>, List<Goal>, boolean, List<Goal>) - Constructor for class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
SbcGoalsConfig(GoalsConfig, GoalsConfig, boolean, GoalsConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
SbcGoalsConfig.SbcGoalsConfigBuilder - Class in com.linkedin.kafka.cruisecontrol.config
 
SbcGoalsConfigDelta - Class in com.linkedin.kafka.cruisecontrol.config
An immutable object representing a change of goals which can be applied to the existing SbcGoalsConfig.
SbcGoalsConfigDelta.Builder - Class in com.linkedin.kafka.cruisecontrol.config
 
SbcInternalEvent - Class in io.confluent.databalancer.event
An extension of SbcEvent that is intended for use by internal events that don't need to respond to clients and so don't need to implement the SbcEvent.respondToClient(ApiError, SbcEventHandlerResult)} method.
SbcInternalEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcInternalEvent
 
SbcKraftBrokerAdditionEvent - Class in io.confluent.databalancer.event
 
SbcKraftBrokerAdditionEvent(SbcContext, Set<Integer>) - Constructor for class io.confluent.databalancer.event.SbcKraftBrokerAdditionEvent
 
SbcKRaftScheduleBrokerRemovalEvent - Class in io.confluent.databalancer.event
 
SbcKRaftScheduleBrokerRemovalEvent(SbcContext, List<Integer>, boolean, ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Constructor for class io.confluent.databalancer.event.SbcKRaftScheduleBrokerRemovalEvent
 
SbcKraftStartupEvent - Class in io.confluent.databalancer.event
The startup event for KRaft clusters.
SbcKraftStartupEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcKraftStartupEvent
 
SbcLeaderUpdateEvent - Class in io.confluent.databalancer.event
 
SbcLeaderUpdateEvent(SbcContext, OptionalInt) - Constructor for class io.confluent.databalancer.event.SbcLeaderUpdateEvent
 
SbcListBrokerAdditionsEvent - Class in io.confluent.databalancer.event
 
SbcListBrokerAdditionsEvent(SbcContext, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<List<BrokerAdditionDescriptionInternal>>) - Constructor for class io.confluent.databalancer.event.SbcListBrokerAdditionsEvent
 
SbcListBrokerAdditionsEvent.SbcListBrokerAdditionsEventResult - Class in io.confluent.databalancer.event
 
SbcListBrokerAdditionsEventResult(List<BrokerAdditionDescriptionInternal>) - Constructor for class io.confluent.databalancer.event.SbcListBrokerAdditionsEvent.SbcListBrokerAdditionsEventResult
 
SbcListBrokerRemovalsEvent - Class in io.confluent.databalancer.event
 
SbcListBrokerRemovalsEvent(SbcContext, ClusterBalanceManager.BalanceManagerStatusQueryClientCallback<List<BrokerRemovalDescriptionInternal>>) - Constructor for class io.confluent.databalancer.event.SbcListBrokerRemovalsEvent
 
SbcMetadataUpdateEvent - Class in io.confluent.databalancer.event
An SbcEvent generated whenever a KRaft Metadata Update arrives.
SbcMetadataUpdateEvent(SbcContext, MetadataDelta, MetadataImage) - Constructor for class io.confluent.databalancer.event.SbcMetadataUpdateEvent
 
SbcResignationEvent - Class in io.confluent.databalancer.event
The SbcEvent implementing resignation of the SBC component.
SbcResignationEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcResignationEvent
 
SbcResource<T> - Class in io.confluent.databalancer.event.resource
An SbcResource is some sort of entity that can be waited on in the BalancerResourceManager and which works with the SbcEventQueue.
SbcResourceManager - Class in io.confluent.databalancer.event.resource
This class is used for resource management at the SBC top-level.
SbcResourceManager(SbcEventQueue) - Constructor for class io.confluent.databalancer.event.resource.SbcResourceManager
 
SbcResources - Class in io.confluent.databalancer.event.resource
 
SbcResources() - Constructor for class io.confluent.databalancer.event.resource.SbcResources
 
SbcResourceUtils - Class in io.confluent.databalancer.event.resource
 
SbcResourceUtils() - Constructor for class io.confluent.databalancer.event.resource.SbcResourceUtils
 
SbcShutdownEvent - Class in io.confluent.databalancer.event
The SbcEvent to handle complete shutdown of SBC (called when the hosting broker is shutdown).
SbcShutdownEvent(SbcContext) - Constructor for class io.confluent.databalancer.event.SbcShutdownEvent
 
SbcTriggerEvenClusterLoadEvent - Class in io.confluent.databalancer.event
 
SbcTriggerEvenClusterLoadEvent(SbcContext, ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Constructor for class io.confluent.databalancer.event.SbcTriggerEvenClusterLoadEvent
 
SbcZkBrokerAdditionEvent - Class in io.confluent.databalancer.event
 
SbcZkBrokerAdditionEvent(SbcContext, Set<Integer>, Set<Integer>, AliveBrokersMetadata) - Constructor for class io.confluent.databalancer.event.SbcZkBrokerAdditionEvent
 
SbcZkBrokerHealthChangeEvent - Class in io.confluent.databalancer.event
An SbcEvent generated whenever there is a broker health change (some brokers become less-preferred leaders).
SbcZkBrokerHealthChangeEvent(SbcContext, Set<Integer>, Set<Integer>, AliveBrokersMetadata) - Constructor for class io.confluent.databalancer.event.SbcZkBrokerHealthChangeEvent
 
SbcZkConfigUpdateEvent - Class in io.confluent.databalancer.event
A ZK-only SbcEvent that is generated whenever the broker's KafkaConfig changes.
SbcZkConfigUpdateEvent(SbcContext, KafkaConfig, KafkaConfig) - Constructor for class io.confluent.databalancer.event.SbcZkConfigUpdateEvent
 
SbcZkScheduleBrokerRemovalEvent - Class in io.confluent.databalancer.event
 
SbcZkScheduleBrokerRemovalEvent(SbcContext, List<Integer>, boolean, TopicsMetadataSnapshot, AliveBrokersMetadata, ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Constructor for class io.confluent.databalancer.event.SbcZkScheduleBrokerRemovalEvent
 
SbcZkStartupEvent - Class in io.confluent.databalancer.event
The SBC startup event for ZooKeeper-based clusters.
SbcZkStartupEvent(SbcContext, AliveBrokersMetadata) - Constructor for class io.confluent.databalancer.event.SbcZkStartupEvent
 
SbkAdminUtils - Class in com.linkedin.kafka.cruisecontrol.common
 
SbkAdminUtils(ConfluentAdmin, KafkaCruiseControlConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
 
sbkAdminUtils(SbkAdminUtils) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
sbkAdminUtils() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
SbkAdminUtils.ReplicaDescription - Class in com.linkedin.kafka.cruisecontrol.common
A description of a certain TopicPartition's replicas
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(BrokerRemovalRequest, AliveBrokersMetadata) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
scheduleKraftBrokerRemoval(List<Integer>, boolean, ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
scheduleZkBrokerRemoval(List<Integer>, boolean, TopicsMetadataSnapshot, AliveBrokersMetadata, ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
score() - Method in class com.linkedin.kafka.cruisecontrol.model.ReplicaWrapper
 
scoreFunction() - Method in class com.linkedin.kafka.cruisecontrol.model.SortedReplicas
 
seal() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats.Builder
Build a ProposalStats object and seals this ProposalStats.Builder shut, rendering it unable to have more statistics added to it.
SEC_TO_MS - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
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
 
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 - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
selfHealingEnabled() - Method in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
selfHealingEnabled(boolean) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
selfHealingEnabled() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
selfHealingEnabledHistoricalDurationMs - Variable 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
 
selfHealingStateChangeTimeMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
selfHealingThresholdMs - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
selfSatisfied(ClusterModel, GoalBalancingActionAcceptance) - Method in interface com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
 
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, GoalBalancingActionAcceptance) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
selfSatisfied(ClusterModel, GoalBalancingActionAcceptance) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
 
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
 
serialize(String, CruiseControlMetric) - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.MetricSerde
 
serialize(BrokerRemovalStateRecord, boolean) - Static method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecordProtoSerde
 
serialize(BrokerRemovalStateMachine.BrokerRemovalState) - Static method in class io.confluent.databalancer.persistence.BrokerRemovalStateSerializer
 
serialize(EvenClusterLoadStateMachine.EvenClusterLoadState) - Static method in class io.confluent.databalancer.persistence.EvenClusterLoadStateSerializer
 
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
 
setBalancerStatusTracker(BalancerStatusTracker) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngineContext
 
setBrokerRemovalStateTracker(BrokerRemovalCallback) - Method in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalRestartablePhase.BrokerRemovalRestartablePhaseBuilder
 
setCancellationEvent(BrokerRemovalStateMachine.BrokerRemovalEvent) - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
setCancellationMode(BrokerRemovalCancellationMode) - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
setCapacityThreshold(double) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Set alive resource capacity threshold for all resources.
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
setDemotedBrokers(Set<Integer>) - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
setEntityConfigs(Admin, ConfigResource.Type, Collection<String>, AlterConfigOp.OpType, Map<String, String>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
setEntityConfigs(Admin, ConfigResource.Type, Collection<String>, Collection<AlterConfigOp>) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
setEventException(Exception) - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
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
 
setModifiedExclusionsData(BrokerRemovalExclusionCancellationData) - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
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
 
setProps(Properties) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
 
setReplicaExclusions(Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
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
 
setResourceBalancePercentage(double) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.BalancingConstraint
Set a common resource balance percentage for all resources.
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
 
setTopicMetrics(String, RawMetricType, double, long) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.BrokerLoad
 
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.
shouldBeEnabled() - Method in class io.confluent.databalancer.BalancerEnabledConfig
 
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.
shouldExclude(BalancingAction, List<Broker>, Set<String>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
Check whether the replica should be excluded from the rebalance given the excluded topics excludedTopics.
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.CapacityGoal
Return a boolean indicating whether the replica should be excluded for a replica move (single-replica reassignment).
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
shouldExcludeForReplicaMove(Replica) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProducerInboundCapacityGoal
Exclude non-leader replicas for single-replica movement considerations if they're not offline.
shouldMoveReplica(Replica, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
We should move a replica if it has a topic placement specified and there are more replicas on the rack than specified by the constraint.
shouldRetry() - Method in class io.confluent.databalancer.utils.RetryableResult.Failure
 
shouldRetry() - Method in class io.confluent.databalancer.utils.RetryableResult.Incomplete
 
shouldRetry() - Method in interface io.confluent.databalancer.utils.RetryableResult
Returns a boolean indicating if the operation should be retried.
shouldRetry() - Method in class io.confluent.databalancer.utils.RetryableResult.Success
 
shouldShutdown - Variable in class com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalContext
 
shouldShutdown() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
shouldStop() - Method in class io.confluent.databalancer.utils.RetryableResult.Failure
 
shouldStop() - Method in class io.confluent.databalancer.utils.RetryableResult.Incomplete
 
shouldStop() - Method in interface io.confluent.databalancer.utils.RetryableResult
Returns a boolean indicating that the OperationRetryer should no longer retry the operation and return null as a result of the operation.
shouldStop() - Method in class io.confluent.databalancer.utils.RetryableResult.Success
 
shouldTryLeadershipMovement(Resource) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
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 com.linkedin.kafka.cruisecontrol.statemachine.StateMachineProcessor
 
shutdown(KafkaConfig) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
Called when the object is going away for good (end of broker lifetime).
shutdown(KafkaConfig) - 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(KafkaConfig) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
shutdown() - Method in class io.confluent.databalancer.SbcDataBalanceManager
Shutdown the SBC component completely (unlike resignation, which merely makes SBC inactive but ready to resume operation).
SHUTDOWN_ANOMALY - Static variable in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorUtils
 
SHUTDOWN_TIMEOUT_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
shutdownQueue() - Method in class io.confluent.databalancer.event.SbcEventQueue
Synchronously shutdown the SBC event queue.
shutdownTimeoutMs(Map<String, Object>) - Static method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
SingleBrokerBalancerOperationProgressListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for a listener for the progress of a balancer operation for a single broker
SingleBrokerBalancerOperationTerminationListener<S extends BalancerOperationState> - Interface in io.confluent.databalancer.operation
A functional interface for a listener that gets called when a balancer operation (operating on one broker) reaches a terminal state
SingleBrokerStats - Class in com.linkedin.kafka.cruisecontrol.monitor
 
SingleBrokerStats(String, int, Broker.Strategy, double, double, double, double, double, double, int, int, boolean, double, Map<String, DiskStats>) - Constructor for class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
singleDestinationBrokerDataToReceiveInMB() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
singleEntityListIterable(List<T>, int) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.EntityCombinator
Method to create an iterator that permutes all combination of elements in a List.
size() - Method in class com.linkedin.cruisecontrol.metricdef.MetricDef
 
size() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
skipInterCellBalancing() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Return a boolean indicating if inter-cell balancing can be skipped on this cluster.
skippedGoals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
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
 
slackChannel - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
slackIcon - 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
 
slackUser - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
slackWebhook - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SlackSelfHealingNotifier
 
sneakyThrow(Throwable) - Static method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils
 
sortByMetricResourceValue(Resource) - Static method in class com.linkedin.kafka.cruisecontrol.model.ReplicaSortFunctionFactory
 
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.
sortName() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
sourceBroker() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
 
sourceBrokerId() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the source broker id that is impacted by the balancing action.
sourceBrokerLogdir() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the source broker logdir.
spliterator() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
start() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.MetricFetcherManager
 
start() - Method in class com.linkedin.kafka.cruisecontrol.monitor.task.LoadMonitorTaskRunner
Start the metric fetchers and sampling scheduler thread.
START_STATE - Static variable in class io.confluent.databalancer.operation.BrokerRemovalStateMachine
 
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
 
startRebalancing() - Method in class io.confluent.databalancer.operation.EvenClusterLoadStateManager
This method is invoked when we have found goal violations and have a list of proposals that if executed are going to fix the goal violations.
startSbc(AliveBrokersMetadata) - Method in class io.confluent.databalancer.event.SbcAbstractStartupEvent
 
startSbc(AliveBrokersMetadata, Optional<ConfigurationsImage>) - Method in class io.confluent.databalancer.event.SbcAbstractStartupEvent
 
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(ApiStatePersistenceStore) - 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() - Method in class com.linkedin.kafka.cruisecontrol.statemachine.StateMachineProcessor
 
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
 
startupMode() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
startupMode() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
stat() - Method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
 
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() - 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 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, Time) - Constructor for class io.confluent.databalancer.operation.StateMachine
 
StateMachine(int, String, S, long, long, Time) - Constructor for class io.confluent.databalancer.operation.StateMachine
Used when restoring a state machine from persisted state.
StateMachine(Set<Integer>, String, S, Time) - 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.
StateMachineProcessor - Class in com.linkedin.kafka.cruisecontrol.statemachine
Class to use to execute SBC state machines.
StateMachineProcessor() - Constructor for class com.linkedin.kafka.cruisecontrol.statemachine.StateMachineProcessor
 
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.monitor.BrokerStats
 
statsSnapshot(ResourceDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger.Builder
 
status() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
status() - Method in enum io.confluent.databalancer.operation.BalancerStatusStateMachine.BalancerState
 
status() - Method in enum io.confluent.databalancer.operation.BrokerAdditionStateMachine.BrokerAdditionState
Returns the #PartitionReassignmentsStatus for this phase
status() - Method in enum io.confluent.databalancer.operation.EvenClusterLoadStateMachine.EvenClusterLoadState
 
statusUpdateMs() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyState
 
stopExecution(String) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorReservationHandle
Asynchronously stop the execution of execution proposal tasks
stopRequested - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
strategy() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
strategy - Variable in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
strategy() - Method in class com.linkedin.kafka.cruisecontrol.monitor.SingleBrokerStats
 
stream() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
stronger(ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
Combine the requirements of this ModelCompletenessRequirements and another one.
submitProposal(DetailedProposal.Result) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerProposalLeaderboard
Conditionally adds the proposal to the leaderboard if the given proposal is more impactful than the least impactful, or if there is still space on the leaderboard.
submitProposal(DetailedProposal.Result) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ProposalLeaderboard
Conditionally adds the given DetailedProposal.Result to its corresponding broker leaderboard.
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.
subtractLoad(Load) - Method in class com.linkedin.kafka.cruisecontrol.model.Load.Builder
 
subtractLoad(Broker.Strategy, Load) - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
subtractLoad(Broker.Strategy, AggregatedMetricValues) - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
SUCCESS - Static variable in class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
 
sum() - Method in class com.linkedin.kafka.cruisecontrol.detector.ResourceUtilizationWindow
For tests
sum() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.Summary
 
summarize(Map<ExecutionTask.State, Integer>) - Static method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.State
Summarizes the number of movements for each ExecutionTask.State.
summarize(ExecutionTask.TaskType) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker.ExecutionTasksSummary
Returns a string representation of the given TaskType movements.
summary() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult.PlaintextSummary
 
SuspendedTopicPartition - Class in io.confluent.cruisecontrol.analyzer.history
SuspendedTopicPartition models the TopicPartition that should be suspended for reassignments.
SuspendedTopicPartition(TopicPartition, long, long) - Constructor for class io.confluent.cruisecontrol.analyzer.history.SuspendedTopicPartition
Creates a SuspendedTopicPartition with provided topic partition and the suspension duration in milliseconds.
suspendedTopicPartitionListener() - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationLogger
 
suspendedTopicPartitions() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizationHistoryOptions
TopicPartitions in this set are suspended from balancing operations, mainly used for fencing off those partitions with a high number of repeated movements.
suspendedTopicPartitions() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
 
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.
swapsAccepted() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
SystemTopicEvenDistributionGoal - Class in com.linkedin.kafka.cruisecontrol.analyzer.goals
Try to balance system topics evenly across brokers, in the sense of partition counts for each system topic.
SystemTopicEvenDistributionGoal() - Constructor for class com.linkedin.kafka.cruisecontrol.analyzer.goals.SystemTopicEvenDistributionGoal
Default constructor for this goal.

T

TableGenerator - Class in io.confluent.databalancer.utils
A general purpose tabular format output generator.
TableGenerator() - Constructor for class io.confluent.databalancer.utils.TableGenerator
 
tags - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
tags() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.YammerMetricWrapper
 
takeExpired() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
Retrieves and removes one expired TopicPartitionHistory, waiting if necessary until an element with an expired delay is available.
Task - Interface in com.linkedin.kafka.cruisecontrol.statemachine
A Task that can be executed by StateMachineProcessor.
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.
taskHistoryRetentionMs(KafkaConfig) - Static method in class io.confluent.databalancer.DatabalancerUtils
 
taskHistoryRetentionMs() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
taskHistoryRetentionMs() - Method in class io.confluent.databalancer.SbcContext
Get the ApiPersistenceStore Task History Retention Period, which is available in the KafkaConfig.
taskId() - Method in class com.linkedin.kafka.cruisecontrol.statemachine.BrokerRemovalTask
 
taskId() - Method in interface com.linkedin.kafka.cruisecontrol.statemachine.Task
 
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
 
tasksToBeRetried(ExecutionTask.TaskType) - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskTracker
 
TELEMETRY_REPORTER_TOPIC_PATTERN - Static variable in class io.confluent.cruisecontrol.metricsreporter.ConfluentMetricsSamplerBase
 
TelemetryConverter - Interface in io.confluent.cruisecontrol.metricsreporter
TelemetryConverter acts as a thin abstraction to allow converting metrics from both OpenTelemetry (OTLP) and OpenCensus format to cruise-control style metrics without having to duplicate a lot of code.
TelemetryConverter.DataPoint - Interface in io.confluent.cruisecontrol.metricsreporter
 
TelemetryConverter.Labeled - Interface in io.confluent.cruisecontrol.metricsreporter
 
TelemetryConverter.MetricConsumer<T> - Interface in io.confluent.cruisecontrol.metricsreporter
 
TelemetryConverter.QuantileValue - Interface in io.confluent.cruisecontrol.metricsreporter
 
TelemetryConverter.Summary - Interface in io.confluent.cruisecontrol.metricsreporter
 
tenant(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Return optional tenant with the given tenant id if it is found in the cluster.
Tenant - Class in com.linkedin.kafka.cruisecontrol.model
 
Tenant(String, Cell, PartitionPlacementStrategy) - Constructor for class com.linkedin.kafka.cruisecontrol.model.Tenant
Constructor of the tenant class using the tenant id, cell id and placement policy.
TenantAwareGoal - Class in io.confluent.cruisecontrol.analyzer.goals
Tenant aware goal is a hard goal that will ensure all tenant partitions are within one designated cell, given the tenant follows PartitionPlacementStrategy.TENANT_IN_CELL strategy.
TenantAwareGoal() - Constructor for class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
tenantId() - Method in class com.linkedin.kafka.cruisecontrol.model.Tenant
Return tenant id of the tenant.
tenants() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
Returns all tenants in the cluster.
tenants() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
Returns all the tenants in the cluster.
thresholds - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
 
thresholds(DistributionThresholdUtils.ResourcePercentageThresholds) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.util.ResourceDistributionLogger.Builder
 
throttledTopics() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTaskManager
Returns the topics that have had a replication throttle applied
throttleHelper - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
throwableOpt - Variable in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
time - Variable in class com.linkedin.kafka.cruisecontrol.detector.notifier.SelfHealingNotifier
 
time() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext.KafkaCruiseControlContextBuilder
 
time() - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlContext
 
time() - Method in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.CruiseControlMetric
Get the timestamp for this metric.
time() - Method in class io.confluent.databalancer.SbcContext
 
TIME_ZONE - Static variable in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
timeout(int) - Method in class com.linkedin.kafka.cruisecontrol.common.BatchedConfigsFetcher.Builder
 
timestamp() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.Labeled
 
timestampMs() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
 
toAllowCapacityEstimation() - Method in class com.linkedin.kafka.cruisecontrol.PlanComputationOptions
 
toArray() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
toArray(T[]) - Method in class io.confluent.databalancer.utils.ImmutableSet
 
toBalancerOperationStatus() - Method in enum io.confluent.databalancer.operation.BrokerRemovalStateMachine.BrokerRemovalState
 
toBeRetried() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionTask
Mark the task to be retried
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
 
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.
toEvenClusterLoadDescriptionInternal(boolean) - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
toEvenClusterLoadPlan() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult
 
toExcludeRecentlyRemovedBrokers() - Method in class com.linkedin.kafka.cruisecontrol.PlanComputationOptions
 
toHtmlTable() - Method in class com.linkedin.cruisecontrol.common.config.ConfigDef
 
topAcceptedProposals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerProposalLeaderboard.Result
 
topic() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
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 - Variable in class com.linkedin.kafka.cruisecontrol.metricsreporter.metric.TopicMetric
 
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() - Method in class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImagePartitionSnapshot
 
TOPIC_PARTITION_MAXIMUM_MOVEMENTS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
TOPIC_PARTITION_MAXIMUM_MOVEMENTS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
TOPIC_PARTITION_MOVEMENT_EXPIRATION_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
TOPIC_PARTITION_MOVEMENT_EXPIRATION_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
TOPIC_PARTITION_SUSPENSION_MS_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
TOPIC_PARTITION_SUSPENSION_MS_DOC - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
 
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
 
TopicImagePartitionSnapshot(String, int, int) - Constructor for class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImagePartitionSnapshot
 
TopicImageReplicaInfo(PartitionRegistration) - Constructor for class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot.TopicImageReplicaInfo
 
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
 
topicMetrics(String, RawMetricType, boolean) - 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 interface com.linkedin.kafka.cruisecontrol.analyzer.BalancingAction
 
topicPartition - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal
 
topicPartition() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
topicPartition() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get the source 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.
topicPartition() - Method in class io.confluent.cruisecontrol.analyzer.history.AbstractTopicPartitionHistory
 
topicPartition() - Method in interface io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistory
Retrieves the topic partition associated with this history item.
TopicPartitionHistory - Interface in io.confluent.cruisecontrol.analyzer.history
An abstract notion of a history snapshot w.r.t.
TopicPartitionHistoryPool<H extends TopicPartitionHistory> - Class in io.confluent.cruisecontrol.analyzer.history
Maintains a collection of TopicPartitionHistorys.
TopicPartitionHistoryPool() - Constructor for class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
 
TopicPartitionMovement - Class in io.confluent.cruisecontrol.analyzer.history
Tracks timestamp, source broker, destination broker, proposing goal and reason of movement for a topic partition moved by SBC.
TopicPartitionMovement(TopicPartition, int, int, Class<? extends Goal>, String, long, long) - Constructor for class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
Creates a new TopicPartitionMovement and assign the current wall-clock time as its timestamp.
topicPartitionMovementExpirationMs() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizationHistoryOptions
Expiration time of each generated topic partition movement.
topicPartitionMovementListener() - Method in class io.confluent.cruisecontrol.analyzer.history.GoalOptimizationLogger
 
topicPartitionMovements() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult
 
topicPlacements() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
topicPlacements() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
 
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.Cell
Get a set of topic names in the cell.
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
TOPICS_IMAGE - Static variable in class io.confluent.databalancer.event.resource.SbcResources
 
TopicsImageMetadataSnapshot - Class in io.confluent.databalancer.metadata
An implementation of TopicsMetadataSnapshot that leverages the KRaft-provided TopicsImage metadata
TopicsImageMetadataSnapshot(TopicsImage) - Constructor for class io.confluent.databalancer.metadata.TopicsImageMetadataSnapshot
 
TopicsImageMetadataSnapshot.TopicImagePartitionSnapshot - Class in io.confluent.databalancer.metadata
 
TopicsImageMetadataSnapshot.TopicImageReplicaInfo - Class in io.confluent.databalancer.metadata
 
topicsWithReplicationFactorChange() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizerResult
The topics of partitions which are going to be modified by proposals.
topRejectedProposals() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerProposalLeaderboard.Result
 
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.
toRemovalDescriptions() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
Return a BrokerRemovalDescriptionInternal for each broker that's being removed in the removal operation that this record represents.
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.BalancingConstraint
Get string representation of BalancingConstraint.
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.GoalOptimizationHistoryOptions
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ReplicaThresholds
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.DistributionThresholdUtils.ResourcePercentageThresholds
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalOptimizationResult
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.CandidateBroker
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.DetailedProposal.Result
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.IncrementalResourceDistributionStatsSnapshot
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot.ResourceValueThresholds
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult.PlaintextSummary
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.PartitionBalancingAction
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.ReplicaBalancingAction
Get string representation of this balancing proposal.
toString() - Method in class com.linkedin.kafka.cruisecontrol.async.progress.OperationProgress
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterAndGeneration
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.common.MetadataClient.ClusterMetadata
 
toString() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.common.SbkAdminUtils.ReplicaDescription
 
toString() - Method in enum com.linkedin.kafka.cruisecontrol.common.Statistic
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.config.GoalsConfig
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig.SbcGoalsConfigBuilder
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfigDelta
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.config.UpdatableSbcGoalsConfig
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetectorState
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyStats
 
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.BrokerExecutionTaskTracker
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutionProposal
 
toString(int) - Method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.State
 
toString() - Method in enum com.linkedin.kafka.cruisecontrol.executor.ExecutionTask.TaskType
 
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.Cell
 
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.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.model.Tenant
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.BrokerStats
 
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.monitor.sampling.holder.ReplicaEntity
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaMetricSample
 
toString() - Method in class com.linkedin.kafka.cruisecontrol.operation.MultiBrokerAdditionOperation
 
toString() - Method in class io.confluent.cruisecontrol.analyzer.history.SuspendedTopicPartition
 
toString() - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionMovement
 
toString() - Method in class io.confluent.databalancer.BalancerEnabledConfig
 
toString() - Method in class io.confluent.databalancer.event.resource.SbcResource
 
toString() - Method in class io.confluent.databalancer.event.SbcEvent
A simple toString which just returns the name of the event.
toString() - Method in class io.confluent.databalancer.operation.BrokerRemovalCancellationProposal.BrokerRemovalCancellationProposalBuilder
 
toString() - Method in class io.confluent.databalancer.persistence.BrokerRemovalStateRecord
 
toString() - Method in class io.confluent.databalancer.persistence.EvenClusterLoadStateRecord
 
toString() - Method in class io.confluent.databalancer.utils.ImmutableSet
 
toStringCounts() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModelStats
 
totalCapacityFor(Resource) - Method in class com.linkedin.kafka.cruisecontrol.model.Capacity
 
totalNumPartitions(Cluster) - Static method in class com.linkedin.kafka.cruisecontrol.monitor.MonitorUtils
 
totalReplicasMatchingConstraint(Map<String, String>, TopicPartition, ClusterModel) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Computes the number of alive replicas on a rack.
totalUtilization() - Method in interface com.linkedin.kafka.cruisecontrol.model.Utilization
 
tp() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.PartitionEntity
 
tp() - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.holder.ReplicaEntity
 
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.
trackProposalAccepted(ActionType, Optional<DetailedProposal.Result>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats.Builder
Track that a proposal has been accepted.
trackProposalGenerated() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats.Builder
Track that a proposal has been generated.
trackProposalRejected(Optional<String>, Optional<DetailedProposal.Result>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ProposalStats.Builder
Track that a proposal has been rejected, and Optionally indicate what goal rejected it.
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
Overload of ClusterModel.trackSortedReplicas(Collection, String, Function, Function, Function) )} for when all brokers should be considered for replica tracking.
trackSortedReplicas(Collection<Broker>, 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
 
triggeredByGoalViolation(boolean) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationOptions.Builder
Set whether this optimization run was triggered by the automatic goal violation detection check.
triggerEvenClusterLoadTask(String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Serves manual request to run a general rebalance on the cluster for the even cluster load task.
triggerEvenClusterLoadTask(String) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
triggerEvenClusterLoadTask(String) - Method in interface io.confluent.databalancer.DataBalanceEngine
Serves the manual request to run a general rebalance on the cluster for the even cluster load task.
triggerEvenClusterLoadTask() - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
triggerEvenClusterLoadTask(String) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
triggerEvenClusterLoadTask(ClusterBalanceManager.BalanceManagerOperationInvocationClientCallback) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
triggeringGoals(List<String>) - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig.SbcGoalsConfigBuilder
 
triggeringGoals() - Method in class com.linkedin.kafka.cruisecontrol.config.SbcGoalsConfig
Retrieve the non-incremental triggering goals config.
triggerStopExecution(String) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
Request the executor to stop any ongoing execution.
triggerStopExecution(boolean, String) - Method in class com.linkedin.kafka.cruisecontrol.executor.Executor
An overloaded variant of Executor.triggerStopExecution(String) that provides the possibility to optionally invalidate metrics windows.
triggerStopExecution(String) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Request the executor to stop any ongoing execution.
tryAcceptProposal(Set<Goal>, BalancingAction, ClusterModel, Optional<DetailedProposal>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
tryCompute(DistributionThresholdUtils.ResourcePercentageThresholds, Collection<BrokerResourceStats>) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.ResourceDistributionStatsSnapshot
Attempts to compute a ResourceDistributionStatsSnapshot by converting the given DistributionThresholdUtils.ResourcePercentageThresholds to absolute values and evaluating them against the respective lower, upper balance limits and minimum utilization thresholds.
type - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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.BrokerRemovalContext
 
unevenLoadSelfHealingEnabled() - Method in class com.linkedin.kafka.cruisecontrol.detector.AnomalyDetector
Returns whether self-healing is enabled to fix goal violation anomaly.
unfencedClusterImage(BalancerResourceManager) - Static method in class io.confluent.databalancer.event.resource.SbcResourceUtils
Given a BalancerResourceManager, try to fetch a ClusterImage from it which contains at least one unfenced broker.
unit() - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
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
 
untilDeadline(TimeUnit) - Method in class io.confluent.cruisecontrol.analyzer.history.AbstractTopicPartitionHistory
 
untilDeadline(TimeUnit) - Method in interface io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistory
Retrieves the remaining time duration until the history item expires with the given TimeUnit.
untrackSortedReplicas(String) - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
Un-track 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
 
updatableSbcGoalsConfig() - Method in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
Gets or creates a UpdatableSbcGoalsConfig from this config.
UpdatableSbcGoalsConfig - Class in com.linkedin.kafka.cruisecontrol.config
A mutable, thread-safe, up-to-date configuration of the goals SBC uses to both trigger a rebalance and to perform the actual rebalance.
UpdatableSbcGoalsConfig(SbcGoalsConfig) - Constructor for class com.linkedin.kafka.cruisecontrol.config.UpdatableSbcGoalsConfig
Constructor.
update(BrokerResourceStats, BrokerResourceStats, double, double) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
update(CapacityStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.CapacityGoalMetrics
 
update(IncrementalResourceDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.IncrementalResourceDistributionGoalMetrics
 
update(ReplicaDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.ReplicaDistributionGoalMetrics
 
update(ResourceDistributionStatsSnapshot) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.ResourceDistributionGoalMetrics
Given the latest ResourceDistributionStatsSnapshot for this goal's optimization run, update the metrics.
update(SbcGoalsConfig) - Method in class com.linkedin.kafka.cruisecontrol.config.UpdatableSbcGoalsConfig
Update the current goals config with the given SbcGoalsConfig
update(H) - Method in class io.confluent.cruisecontrol.analyzer.history.TopicPartitionHistoryPool
Adds a new TopicPartitionHistory to the pool.
updateConfig(String, Object) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Update the KafkaCruiseControlConfig "key" to "value".
updateConfig(SbcGoalsConfigDelta) - Method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControl
Update Sbc goals config with the provided SbcGoalsConfigDelta.
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.
updateConfig(KafkaConfig) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
 
updateConfig(KafkaConfig, KafkaConfig) - Method in class io.confluent.databalancer.SbcDataBalanceManager
 
updateConfigPermanently(String, Object) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
updateConfigPermanently(SbcGoalsConfigDelta) - Method in class io.confluent.databalancer.ConfluentDataBalanceEngine
 
updateConfigPermanently(String, Object) - Method in interface io.confluent.databalancer.DataBalanceEngine
Update the KafkaCruiseControlConfig "key" to "value" permanently, i.e.
updateConfigPermanently(SbcGoalsConfigDelta) - Method in interface io.confluent.databalancer.DataBalanceEngine
Update the KafkaCruiseControlConfig goal config permanently, i.e.
updateConfigPermanently(String, Object) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
updateConfigPermanently(SbcGoalsConfigDelta) - Method in class io.confluent.databalancer.NoOpDataBalanceEngine
 
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.IncrementalResourceDistributionGoal
Marks the balance as completed after one round of balancing if there are no offline replicas.
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.SystemTopicEvenDistributionGoal
 
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.CellAwareGoal
Validate that all non-excluded partitions are in the same cell
updateGoalState(ClusterModel, Set<String>) - Method in class io.confluent.cruisecontrol.analyzer.goals.ReplicaPlacementGoal
Validate that all topic placements have been satisfied.
updateGoalState(ClusterModel, Set<String>) - Method in class io.confluent.cruisecontrol.analyzer.goals.TenantAwareGoal
 
updateKafkaConfig(Map<String, Object>, Set<String>, KafkaConfig) - Method in class io.confluent.databalancer.KafkaDataBalanceManager
Generate a new KafkaConfig from new changes and set the stored config to this new value..
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(ClusterModel, Map<Short, Set<String>>, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.AbstractGoal
 
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.
updateResource(BrokerResourceStats) - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BrokerResourceMetric
Updates the BrokerResourceStats this metric should track with the latest value.
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
 
upperBalanceThresholdValue - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.metrics.BaseDistributionGoalMetrics
 
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
 
utcDateFor(long) - Static method in class com.linkedin.kafka.cruisecontrol.KafkaCruiseControlUtils
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Broker
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Cell
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.ClusterModel
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Disk
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.DiskStats
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Host
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Rack
 
utilization() - Method in class com.linkedin.kafka.cruisecontrol.model.Replica
 
Utilization - Interface in com.linkedin.kafka.cruisecontrol.model
Class to get utilization information of a resource.
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
 
utilizationRatio() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
Get the utilization ratio, i.e.
utilizationValue - Variable in class com.linkedin.kafka.cruisecontrol.analyzer.goals.internals.BrokerResourceStats
 
Utils - Class in com.linkedin.cruisecontrol.common.utils
 
uuid - Variable in class com.linkedin.kafka.cruisecontrol.executor.AbstractExecutorReplicaMovement
 
uuid() - Method in class com.linkedin.kafka.cruisecontrol.executor.ExecutorState
 
uuid(Set<Integer>, long) - Static method in interface com.linkedin.kafka.cruisecontrol.operation.BrokerRemovalCallback
Creates a unique UUID of the broker removal operation.

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
 
validateAndScheduleRemoval(AliveBrokersMetadata, TopicsMetadataSnapshot) - Method in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent
 
validateEvenBrokerResourceCapacities(Map<Integer, Double>, Resource) - Static method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.GoalUtils
Validates that the given map of broker capacities have the same capacity.
validateIfBrokersCanBeRemoved(TopicsMetadataSnapshot, AliveBrokersMetadata) - Method in class io.confluent.databalancer.event.SbcAbstractScheduleBrokerRemovalEvent
Validate if the given set of brokers can be removed from the cluster.
validatePercentages() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.CpuUsageDistributionGoal
 
validatePercentages() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.IncrementalCPUResourceDistributionGoal
 
validatePercentages() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionAbstractGoal
Whether to verify the validity of the resource utilization percentages.
validatePercentages() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.goals.ResourceDistributionGoal
 
validateWindowIndex(long) - Method in class com.linkedin.cruisecontrol.common.WindowIndexedArrays
Check if a given window index is valid or not.
validator - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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
 
validReplicaRatioByWindows(Set<ReplicaEntity>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Get the monitored replica percentage in each window.
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.
validWindows(MetadataClient.ClusterAndGeneration, double, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Get all replicas in the cluster and check for valid windows for them by calling overloaded KafkaReplicaMetricSampleAggregator.validWindows(Set, double, Set) method.
validWindows(MetadataClient.ClusterAndGeneration, double) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Overload of KafkaReplicaMetricSampleAggregator.validWindows(Set, double, Set) passes empty set of failed broker ids.
validWindows(Set<ReplicaEntity>, double, Set<Integer>) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Get a sorted set of valid windows in the aggregator.
validWindows(Set<ReplicaEntity>, double) - Method in class com.linkedin.kafka.cruisecontrol.monitor.sampling.aggregator.KafkaReplicaMetricSampleAggregator
Overload of KafkaReplicaMetricSampleAggregator.validWindows(Set, double, Set) passes empty set of failedBrokers to original method.
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.
value() - Method in interface io.confluent.cruisecontrol.metricsreporter.TelemetryConverter.QuantileValue
 
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
 
valueComputingStrategyForRawMetricType(RawMetricType) - Static 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(ValueComputingStrategy) - Static method in enum com.linkedin.cruisecontrol.metricdef.AggregationFunction
 
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.internals.ReplicaDistributionStatsSnapshot.ReplicaResource
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.ResourceDistributionAbstractGoal.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.detector.notifier.ResourceUtilizationAlertType
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.KafkaCruiseControl.CcStartupMode
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.Strategy
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.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.task.LoadMonitorTaskRunner.LoadMonitorTaskRunnerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.BrokerChangeEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.EngineInitializationContext.EngineStartupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.GoalConstraints
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BalancerOperationState.BalancerOperationStateCharacteristics
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BalancerStatusStateMachine.BalancerEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.BalancerStatusStateMachine.BalancerState
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.EvenClusterLoadStateMachine.EvenClusterLoadEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.databalancer.operation.EvenClusterLoadStateMachine.EvenClusterLoadState
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.internals.ReplicaDistributionStatsSnapshot.ReplicaResource
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.ResourceDistributionAbstractGoal.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.detector.notifier.ResourceUtilizationAlertType
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.KafkaCruiseControl.CcStartupMode
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.Strategy
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.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.task.LoadMonitorTaskRunner.LoadMonitorTaskRunnerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.BrokerChangeEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.EngineInitializationContext.EngineStartupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.databalancer.GoalConstraints
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.BalancerOperationState.BalancerOperationStateCharacteristics
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.BalancerStatusStateMachine.BalancerEvent
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.BalancerStatusStateMachine.BalancerState
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.EvenClusterLoadStateMachine.EvenClusterLoadEvent
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.EvenClusterLoadStateMachine.EvenClusterLoadState
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.
valuesByMetricId - Variable in class com.linkedin.cruisecontrol.monitor.sampling.MetricSample
 
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.
valuesForResource(Resource, 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 resource 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.
verboseSummary() - Method in class com.linkedin.kafka.cruisecontrol.analyzer.OptimizationResult.PlaintextSummary
A more verbose summary of the optimization result, including the proposals that went into it.
VIOLATED - Static variable in class com.linkedin.kafka.cruisecontrol.analyzer.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.
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
 
visit(ResourceVisitor<T>) - Method in enum com.linkedin.kafka.cruisecontrol.common.Resource
 
visitCpuResource() - Method in interface com.linkedin.kafka.cruisecontrol.common.ResourceVisitor
Take action for a cpu resource.
visitDiskResource() - Method in interface com.linkedin.kafka.cruisecontrol.common.ResourceVisitor
Take action for a disk resource.
visitNetworkInResource() - Method in interface com.linkedin.kafka.cruisecontrol.common.ResourceVisitor
Take action for a n/w in bytes resource.
visitNetworkOutResource() - Method in interface com.linkedin.kafka.cruisecontrol.common.ResourceVisitor
Take action for a n/w out bytes resource.
visitProduceInResource() - Method in interface com.linkedin.kafka.cruisecontrol.common.ResourceVisitor
Take action for a produce-in bytes resource.

W

waitForAnyTaskToFinish(AbstractExecutorReplicaMovement) - Method in interface com.linkedin.kafka.cruisecontrol.executor.Executor.ExecutionTaskWaiter
This method periodically checks Kafka to see if any partition reassignment has finished or not.
WaitingForClusterModel - Class in com.linkedin.kafka.cruisecontrol.async.progress
 
WaitingForClusterModel() - Constructor for class com.linkedin.kafka.cruisecontrol.async.progress.WaitingForClusterModel
 
waitOnResource(SbcResource<?>, SbcEvent) - Method in interface io.confluent.databalancer.event.resource.BalancerResourceManager
Wait for a SbcResource to be provided.
waitOnResource(SbcResource<?>, SbcEvent) - Method in class io.confluent.databalancer.event.resource.SbcResourceManager
Wait for a SbcResourceManager.provideResource(SbcResource, Object) call to be made on a specified SbcResource.
wasExecuted() - Method in class com.linkedin.kafka.cruisecontrol.RebalanceResult
 
weaker(ModelCompletenessRequirements) - Method in class com.linkedin.kafka.cruisecontrol.monitor.ModelCompletenessRequirements
Combine the requirements of this ModelCompletenessRequirements and another one.
width - Variable in class com.linkedin.cruisecontrol.common.config.ConfigDef.ConfigKey
 
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
 
windowIndicesToWindows(Set<Long>, long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Converts from window indices to window by multiplying each index with duration of a window.
windowIndicesToWindows(Map<Long, Float>, long) - Method in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
Convert the key of the original argument from window index to window by multiplying it with the duration of a window and return the resulting map.
windowMs - Variable in class com.linkedin.cruisecontrol.monitor.sampling.aggregator.MetricSampleAggregator
 
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<E extends Entity> - 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
 
withFollowUpEvents(List<SbcEvent>) - Static method in class io.confluent.databalancer.event.SbcEvent.SbcEventHandlerResult
Factory method to get the result object with follow up events.
wouldOverloadBroker(int, int) - Method in class com.linkedin.kafka.cruisecontrol.executor.BrokerExecutionTaskTracker
Indicate if a task with N movements would overload the broker.
WRITE_THROUGHPUT_MULTIPLIER_CONFIG - Static variable in class com.linkedin.kafka.cruisecontrol.config.KafkaCruiseControlConfig
write.throughput.multiplier
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.

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

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
A B C D E F G H I J K L M N O P Q R S T U V W Y Z