AbstractBaseStage | |
AccessOption | |
AgentStateModel | |
AgentStateModelFactory | |
AlertHistory | Maintains a history of alerts that have been fired, as well as actions taken, if any. |
Alerts | Describe alerts and corresponding metrics. |
Alerts.AlertsProperty | Supported fields corresponding to a set of alerts |
AlertStatus | Get characteristics of alerts, whether they were fired, and their context. |
AnalyticsTaskFactory | |
AsyncCallback | |
AsyncCallbackService | |
AsyncCallbackService.AsyncCallbackMessageHandler | |
AttributeName | |
AutoFallbackPropertyStore<T> | Property store that does auto fallback to an old location. |
AutoModeISBuilder | |
AutoRebalanceModeISBuilder | |
AutoRebalancer | This is a Rebalancer specific to full automatic mode. |
AutoRebalanceStrategy | |
AutoRebalanceStrategy.DefaultPlacementScheme | Compute preferred placements based on a default strategy that assigns replicas to nodes as evenly as possible while avoiding placing two replicas of the same partition on any node. |
AutoRebalanceStrategy.ReplicaPlacementScheme | Interface for providing a custom approach to computing a replica's affinity to a node. |
BaseDataAccessor<T> | Generic interface for accessing and manipulating data on a backing store like Zookeeper. |
BasicZkSerializer | Basic path based serializer which ignores the path and delegates serialization into a regular ZkSerializer |
BatchMessageHandler | |
BatchMessageWrapper | default implementation of handling start/end of batch messages |
BestPossibleStateCalcStage | For partition compute best possible (instance,state) pair based on IdealState,StateModel,LiveInstance |
BestPossibleStateOutput | |
BootstrapHandler | |
BootstrapHandler.BootstrapStateModel | |
BootstrapProcess | This process does little more than handling the state transition messages. |
BootstrapProcess.CustomMessageHandlerFactory | |
BuiltInStateModelDefinitions | Helix Built-in State Model Definitions |
ByteArraySerializer |
Cache<T> | |
CallbackHandler | |
ChainedPathZkSerializer | |
ChainedPathZkSerializer.Builder | |
ChangeLog | |
ChangeLogGenerator | |
ChangeLogProcessor | Processes the change log and invokes rsync for every change on the remote machine |
ChangeLogReader | |
ChangeRecord | |
CheckpointFile | |
CLMLogFileAppender | |
ClusterConstraints | All of the constraints on a given cluster and its subcomponents, both physical and logical. |
ClusterConstraints.ConstraintAttribute | Attributes on which constraints operate |
ClusterConstraints.ConstraintType | What is being constrained |
ClusterConstraints.ConstraintValue | Possible special values that constraint attributes can take |
ClusterConstraintsBuilder | |
ClusterDataCache | Reads the data from the cluster using data accessor. |
ClusterEvent | |
ClusterEventBlockingQueue | A blocking queue of ClusterEvent objects to be used by the controller pipeline. |
ClusterExternalViewVerifier | given zk, cluster, and a list of expected live-instances check whether cluster's external-view reaches best-possible states |
ClusterLiveNodesVerifier | |
ClusterMBeanObserver | |
ClusterMessagingService | Provides the ability to |
ClusterRepresentationUtil | |
ClusterResource | Class for server-side resource at "/clusters/{clusterName}"
|
ClusterSetup | |
ClustersResource | Class for server-side resource at "/clusters"
|
ClusterStateVerifier | |
ClusterStateVerifier.BestPossAndExtViewZkVerifier | verifier that verifies best possible state and external view |
ClusterStateVerifier.MasterNbInExtViewVerifier | |
ClusterStateVerifier.Verifier | |
ClusterStateVerifier.ZkVerifier | |
ClusterStatusMonitor | |
ClusterStatusMonitorMBean | |
ClusterVerifier | |
CommandAttribute | |
CommandConfig | |
CommandConfig.Builder | builder for command-config |
CompatibilityCheckStage | controller checks if participant version is compatible |
ConfigAccessor | Provides access to the persistent configuration of the cluster, the instances that live on it, and the logical resources assigned to it. |
ConfigChangeListener | This interface is deprecated. replaced by InstanceConfigChangeListener |
ConfigResource | Class for server-side resource at "/clusters/{clusterName}/configs"
|
ConfigScope |
This class is deprecated.
replaced by HelixConfigScope
|
ConfigScopeBuilder |
This class is deprecated.
replaced by HelixConfigScopeBuilder
|
ConstraintBasedAssignment | Collection of functions that will compute the best possible states given the live instances and an ideal state. |
ConstraintItem | A single constraint and its associated attributes |
ConstraintItemBuilder | |
ConstraintResource | Class for server-side resource at "/clusters/{clusterName}/constraints/{constraintType}"
|
Consumer | |
ConsumerStateModel | |
ConsumerStateModelFactory | |
ConsumerThread | |
ControllerChangeListener | Interface to implement to respond to controller changes. |
ControllerManagerHelper | helper class for controller manager |
ControllerResource | Class for server-side resource at "/clusters/{clusterName}/Controller"
|
ControllerStatusUpdateResource | |
CountTask | |
Criteria | Describes various properties that operations involving Message delivery will follow. |
Criteria.DataSource | |
CriteriaEvaluator | |
CurrentState | Current states of partitions in a resource for an instance. |
CurrentState.CurrentStateProperty | Lookup keys for the current state |
CurrentStateChangeListener | Interface to implement to respond to changes in the current state |
CurrentStateComputationStage | For each LiveInstances select currentState and message whose sessionId matches sessionId from LiveInstance Get Partition,State for all the resources computed in previous State [ResourceComputationStage] |
CurrentStateOutput | The current state includes both current state and pending messages For pending messages, we consider both toState and fromState Pending message prevents controller sending transitions that may potentially violate state constraints @see HELIX-541 |
CurrentStateResource | |
CurrentStatesResource | |
CurrentStateUpdate | |
CustomCodeCallbackHandler | Callback interface to running custom code on Helix participant manager The custom code will be triggered on user specified cluster changes |
CustomCodeInvoker | |
CustomModeISBuilder | |
CustomRebalancer | This is a Rebalancer specific to custom mode. |
Dag | |
Dag.Node | |
DefaultControllerMessageHandlerFactory | |
DefaultControllerMessageHandlerFactory.DefaultControllerMessageHandler | |
DefaultIdealStateCalculator | DefaultIdealStateCalculator tries to optimally allocate master/slave partitions among espresso storage nodes. |
DefaultMessagingService | |
DefaultParticipantErrorMessageHandlerFactory | DefaultParticipantErrorMessageHandlerFactory works on controller side. |
DefaultParticipantErrorMessageHandlerFactory.ActionOnError | |
DefaultParticipantErrorMessageHandlerFactory.DefaultParticipantErrorMessageHandler | |
DefaultSchedulerMessageHandlerFactory | |
DefaultSchedulerMessageHandlerFactory.DefaultSchedulerMessageHandler | |
DefaultSchedulerMessageHandlerFactory.SchedulerAsyncCallback | |
DistClusterControllerStateModel | |
DistClusterControllerStateModelFactory | |
DistributedLeaderElection | do distributed leader election |
DummyParticipant | |
DummyParticipant.DummyMSModelFactory | |
DummyParticipant.DummyMSStateModel |
Emitter | |
Error | Defines an error that occurs in computing a valid ideal state or external view |
ErrorResource | |
ErrorsResource | |
ExampleHelper | |
ExampleProcess | |
ExternalCommand | Wrapper for running commands outside of the JVM |
ExternalCommand | |
ExternalView | External view is an aggregation (across all instances) of current states for the partitions in a resource |
ExternalViewChangeListener | Interface to implement to be notified of changes to the external view |
ExternalViewComputeStage | |
ExternalViewGenerator | |
ExternalViewResource |
FileChangeWatcher | |
FileStore | |
FileStoreStateModel | |
FileStoreStateModelFactory | |
FileSystemWatchService | |
FilterTask | |
FixedTargetTaskRebalancer | A rebalancer for when a task group must be assigned according to partitions/states on a target resource. |
GenericHelixController | Cluster Controllers main goal is to keep the cluster state as close as possible to Ideal State. |
GenericLeaderStandbyModel | |
GenericLeaderStandbyStateModelFactory | |
GenericTaskRebalancer | This class does an assignment based on an automatic rebalancing strategy, rather than requiring assignment to target partitions and states of another resource |
GenericTaskRebalancer.RetryPolicy | |
GroupCommit | Support committing updates to data such that they are ordered for each key |
GroupMessageHandler | |
GZipCompressionUtil |
HealthReportProvider | |
HealthStat | Represents a set of properties that can be queried to determine the health of instances on a Helix-managed cluster |
HealthStat.HealthStatProperty | Queryable health statistic properties |
HelixAdmin | |
HelixAdminWebApp | |
HelixAgentMain | |
HelixBatchMessageTask | |
HelixConfigScope | config-scope that replaces @link ConfigScope |
HelixConfigScope.ConfigScopeProperty | Defines the various scopes of configs, and how they are represented on Zookeeper |
HelixConfigScopeBuilder | config-scope builder that replaces @link ConfigScopeBuilder |
HelixConstants | |
HelixConstants.ChangeType | |
HelixConstants.ClusterConfigType | |
HelixConstants.StateModelToken | |
HelixControllerMain | |
HelixCustomCodeRunner | This provides the ability for users to run a custom code in exactly one process using a LeaderStandBy state model. |
HelixDataAccessor | Interface used to interact with Helix Data Types like IdealState, Config, LiveInstance, Message, ExternalView etc PropertyKey represent the HelixData type. |
HelixDefinedState | helix defined states ERROR : when errors happen during state transitions, transit to ERROR state participant will also invoke state-model.on-err(), ignore errors in state-model.on-err() when drop resource in ERROR state and not disabled, controller sends ERROR->DROPPED transition if errors happen in ERROR->DROPPED transition, participant will disable resource/partition when disable resource/partition in ERROR state, resource/partition will be marked disabled but controller not send any transitions when reset resource/partition in ERROR state and not disabled controller send ERROR->initial-state transition if errors happen in ERROR->initial-state transition, remain in ERROR state DROPPED : when drop resource in a non-ERROR state and not disabled controller sends all the transitions from current-state to initial-state then sends initial-state->DROPPED transition |
HelixException | Base class for an exception thrown by Helix due to inconsistencies caught by Helix itself. |
HelixGroupCommit<T> | |
HelixManager | Class that represents the Helix Agent. |
HelixManagerFactory | Obtain one of a set of Helix cluster managers, organized by the backing system. |
HelixManagerProperties | hold helix-manager properties read from helix-core/src/main/resources/cluster-manager.properties |
HelixManagerShutdownHook | Shutdown hook for helix manager Working for kill -2/-15 NOT working for kill -9 |
HelixProperty | A wrapper class for ZNRecord. |
HelixProperty.HelixPropertyAttribute | |
HelixPropertyListener | |
HelixPropertyStore<T> | |
HelixStageLatencyMonitor | |
HelixStageLatencyMonitorMBean | |
HelixStateMachineEngine | |
HelixStateTransitionHandler | |
HelixStateTransitionHandler.HelixStateMismatchException | |
HelixTask | |
HelixTaskExecutor | |
HelixTaskResult | |
HelixTimerTask | Interface for defining a generic task to run periodically. |
HelixUtil | |
HierarchicalDataHolder<T> | Generic class that will read the data given the root path. |
IdealCalculatorByConsistentHashing | |
IdealCalculatorByConsistentHashing.FnvHash | The default string hash function. |
IdealCalculatorByConsistentHashing.HashFunction | Interface to calculate the hash function value of a string |
IdealState | The ideal states of all partitions in a resource |
IdealState.IdealStateModeProperty | Deprecated. |
IdealState.IdealStateProperty | Properties that are persisted and are queryable for an ideal state |
IdealState.RebalanceMode | The mode used for rebalance. |
IdealStateBuilder | |
IdealStateBuilderExample | |
IdealStateCalculatorByRush | |
IdealStateCalculatorByShuffling | |
IdealStateCalculatorForEspressoRelay | |
IdealStateChangeListener | Interface to implement to listen for changes to the ideal state of resources. |
IdealStateExample | Ideal state json format file used in this example for CUSTOMIZED ideal state mode
{ "id" : "TestDB", "mapFields" : { "TestDB_0" : { "localhost_12918" : "MASTER", "localhost_12919" : "SLAVE", "localhost_12920" : "SLAVE" }, "TestDB_1" : { "localhost_12918" : "MASTER", "localhost_12919" : "SLAVE", "localhost_12920" : "SLAVE" }, "TestDB_2" : { "localhost_12918" : "MASTER", "localhost_12919" : "SLAVE", "localhost_12920" : "SLAVE" }, "TestDB_3" : { "localhost_12918" : "MASTER", "localhost_12919" : "SLAVE", "localhost_12920" : "SLAVE" } }, "listFields" : { }, "simpleFields" : { "IDEAL_STATE_MODE" : "CUSTOMIZED", "NUM_PARTITIONS" : "4", "REPLICAS" : "3", "STATE_MODEL_DEF_REF" : "MasterSlave", "STATE_MODEL_FACTORY_NAME" : "DEFAULT" } } |
IdealStateResource | Class for server-side resource at
"/clusters/{clusterName}/resourceGroups/{resourceName}/idealState"
|
InstanceConfig | Instance configurations |
InstanceConfig.InstanceConfigProperty | Configurable characteristics of an instance |
InstanceConfigChangeListener | Interface to implement to listen for changes to instance configurations. |
InstanceMonitor | Implementation of the instance status bean |
InstanceMonitorMBean | A basic bean describing the status of a single instance |
InstanceResource | |
InstancesResource | |
InstancesResource.ListInstancesWrapper | A wrapper class for quick serialization of the data presented by this call |
InstanceType | CONTROLLER: cluster managing component is a controller PARTICIPANT: participate in the cluster state changes SPECTATOR: interested in the state changes in the cluster CONTROLLER_PARTICIPANT: special participant that competes for the leader of CONTROLLER_CLUSTER used in cluster controller of distributed mode {@HelixControllerMain } |
IntegrationTest | |
IntegrationTestUtil | collection of test utilities for integration tests |
JacksonPayloadSerializer | Serializes and deserializes data of a generic type using Jackson |
JmxDumper | |
JobBean | Bean class used for parsing job definitions from YAML. |
JobConfig | Provides a typed interface to job configurations. |
JobConfig.Builder | A builder for JobConfig . |
JobContext | Provides a typed interface to the context information stored by TaskRebalancer in the
Helix property store. |
JobDag | Provides a convenient way to construct, traverse, and validate a job dependency graph |
JobQueue | A named queue to which jobs can be added |
JobQueue.Builder | Supports creation of a single empty queue |
JobQueueResource | Class for server-side resource at "/clusters/{clusterName}/jobQueues/{jobQueue}"
|
JobQueuesResource | Class for server-side resource at "/clusters/{clusterName}/jobQueues"
|
JobResource | Class for server-side resource at "/clusters/{clusterName}/jobQueues/{jobQueue}/{job}"
|
JoinTask | |
JsonParameters |
LeaderHistory | The history of instances that have served as the leader controller |
LeaderStandbySMD | Helix built-in Leader-standby state model definition |
LeaderStandbySMD.States | |
LeaderStandbyStateModelFactory | |
LeaderStandbyStateModelFactory.LeaderStandbyStateModel | |
LiveInstance | Instance that connects to zookeeper (stored ephemerally) |
LiveInstance.LiveInstanceProperty | Saved properties of a live instance |
LiveInstanceChangeListener | Interface to implement to listen for live instance changes. |
LiveInstanceInfoProvider | Interface to provide additional information about a live instance at creation time |
LocalZKServer | Provides ability to start zookeeper locally on a particular port |
Lock | |
LockFactory | |
LockManagerDemo | |
LockProcess |
NotificationContext | Metadata associated with a notification event and the current state of the cluster |
NotificationContext.MapKey | keys used for object map |
NotificationContext.Type | Valid types of notifications |
OnlineOfflineSMD | Helix built-in Online-offline state model definition |
OnlineOfflineSMD.States | |
OnlineOfflineStateModelFactory | |
OnlineOfflineStateModelFactory.OnlineOfflineStateModel |
ParticipantHealthReportCollector | |
ParticipantHealthReportCollectorImpl | |
ParticipantHealthReportTask | |
ParticipantManagerHelper | helper class for participant-manager |
ParticipantMonitor | |
Partition | A distinct partition of a resource |
PathBasedZkSerializer | |
PathUtils | Path related utilities |
PauseSignal | Represent a pause in the cluster |
PayloadSerializer | Interface for converting back and forth between raw bytes and generic objects |
PerInstanceResourceMonitor | |
PerInstanceResourceMonitor.BeanName | |
PerInstanceResourceMonitorMBean | A bean that describes the resource on each instance |
PersistentStats | Statistics for an instance |
PersistentStats.PersistentStatsProperty | High-level properties to provide context for these statistics |
Pipeline | |
PipelineRegistry | |
PreConnectCallback | Called to allow definition of tasks prior to connecting to Zookeeper |
ProcessMonitorThread | thread for monitoring a pid |
PropertyChangeListener<T> | Callback interface on property changes |
PropertyItem | |
PropertyJsonComparator<T> | |
PropertyJsonSerializer<T> | |
PropertyKey | Key allowing for type-safe lookups of and conversions to HelixProperty objects. |
PropertyKey.Builder | PropertyKey builder for a cluster |
PropertyPathConfig | Utility mapping properties to their Zookeeper locations |
PropertySerializer<T> | Serializer interface for property store |
PropertyStat | |
PropertyStoreException | This exception class can be used to indicate any exception during operation on the propertystore |
PropertyType | Types of data stored on Zookeeper by Helix |
Quickstart |
ReadClusterDataStage | |
Rebalancer | Allows one to come up with custom implementation of a rebalancer. |
RebalanceUtil | |
RedisTaskResultStore | |
Replicator | |
ReportTask | |
Resource | A resource contains a set of partitions and its replicas are managed by a state model |
ResourceAssignment | Represents the assignments of replicas for an entire resource, keyed on partitions of the resource. |
ResourceComputationStage | This stage computes all the resources in a cluster. |
ResourceGroupResource | |
ResourceGroupsResource | |
ResourceMonitor | |
ResourceMonitorMBean | |
ResourceUtil | |
ResourceUtil.ContextKey | Key enums for getting values from context |
ResourceUtil.RequestKey | Key enums for getting values from request |
ResourceUtil.YamlParamKey | Key enums for getting yaml format parameters |
ResourceValidationStage | |
RestAdminApplication | |
RoutingTableProvider | |
RsyncDaemon | |
RsyncInvoker | |
RUSHrHash |
TargetState | Enumeration of target states for a job. |
Task | The interface that is to be implemented by a specific task implementation. |
Task | |
TaskAssignmentStage | |
TaskBean | Describes task-specific configuration, including an arbitrary map of key-value pairs to pass to the task |
TaskCallbackContext | A wrapper for all information about a task and the job of which it is a part. |
TaskCluster | |
TaskConfig | Configuration for an individual task to be run as part of a job. |
TaskConstants | Constants used in the task framework. |
TaskDriver | CLI for scheduling/canceling workflows |
TaskDriver.DriverCommand | Commands which may be parsed from the first argument to main |
TaskExecutionDemo | Demo for execution of task Dag using primitives provided by Helix. |
TaskExecutor | |
TaskFactory | A factory for Task objects. |
TaskFactory | |
TaskPartitionState | Enumeration of the states in the "Task" state model. |
TaskRebalancer | Custom rebalancer implementation for the Task state model. |
TaskResult | The result of a task execution. |
TaskResult.Status | An enumeration of status codes. |
TaskResultStore | |
TaskRunner | A wrapping Runnable used to manage the life-cycle of a user-defined Task
implementation. |
TaskSMD | Helix built-in Task state model definition |
TaskState | Enumeration of current task states. |
TaskStateModel | |
TaskStateModel | |
TaskStateModelFactory | Factory class for TaskStateModel . |
TaskStateModelFactory | |
TaskUtil | Static utility methods. |
Test | |
TestCommand | |
TestCommand.CommandType | |
TestCommand.NodeOpArg | |
TestExecutor | a test is structured logically as a list of commands a command has three parts: COMMAND
| TRIGGER | ARG'S COMMAND could be: modify, verify, start, stop
TRIGGER is optional and consists of start-time, timeout, and expect-value which means
the COMMAND is triggered between [start-time, start-time + timeout] and is triggered
when the value in concern equals to expect-value
ARG's format depends on COMMAND if COMMAND is modify/verify, arg is in form of:
|
TestExecutor.ZnodePropertyType | SIMPLE: simple field change LIST: list field change MAP: map field change ZNODE: entire znode change |
TestTrigger | |
Transition | Defines a transition from one state to another |
Transition |
Worker | Generic Worker that is a HELIX Participant which on start up joins the cluster and waits for state transitions from Helix. |
Workflow | Houses a job dag and config set to fully describe a job workflow |
Workflow.Builder | Build a workflow incrementally from dependencies and single configs, validate at build time |
WorkflowBean | Bean class used for parsing workflow definitions from YAML. |
WorkflowConfig | Provides a typed interface to workflow level configurations. |
WorkflowConfig.Builder | |
WorkflowContext | Typed interface to the workflow context information stored by TaskRebalancer in the Helix
property store
|
WorkflowsResource | |
WriteThroughCache<T> |
YAISCalculator | |
YAMLClusterSetup | Supports HelixAdmin operations specified by a YAML configuration file defining a cluster, resources, participants, etc. |
YAMLClusterSetup.YAMLClusterConfig | Java wrapper for the YAML input file |
YAMLClusterSetup.YAMLClusterConfig.ParticipantConfig | |
YAMLClusterSetup.YAMLClusterConfig.ResourceConfig | |
YAMLClusterSetup.YAMLClusterConfig.ResourceConfig.ConstraintsConfig | |
YAMLClusterSetup.YAMLClusterConfig.ResourceConfig.ConstraintsConfig.StateConstraintsConfig | |
YAMLClusterSetup.YAMLClusterConfig.ResourceConfig.ConstraintsConfig.TransitionConstraintsConfig | |
YAMLClusterSetup.YAMLClusterConfig.ResourceConfig.StateModelConfig |
ZkAsyncCallbacks | |
ZkBaseDataAccessor<T> | |
ZkBaseDataAccessor.AccessResult | struct holding return information |
ZkCacheBaseDataAccessor<T> | |
ZkCacheEventThread | |
ZkCallbackCache<T> | |
ZkChildResource | |
ZkClient | ZKClient does not provide some functionalities, this will be used for quick fixes if any bug found in ZKClient or if we need additional features but can't wait for the new ZkClient jar Ideally we should commit the changes we do here to ZKClient. |
ZKClientPool | |
ZkCopy | Tool for copying a zk/file path to another zk/file path |
ZKDumper | Dumps the Zookeeper file structure on to Disk |
ZKExceptionHandler | |
ZkGrep | utility for grep zk transaction/snapshot logs - to grep a pattern by t1 use: zkgrep --zkCfg zkCfg --by t1 --pattern patterns... |
ZKHelixAdmin | |
ZKHelixDataAccessor | |
ZKHelixManager | |
ZkHelixPropertyStore<T> | |
ZkListener | |
ZkLogCSVFormatter | |
ZKLogFormatter | |
ZKPathDataDumpTask | |
ZkPathResource | |
ZKUtil | |
ZNode | |
ZnodeOpArg | |
ZnodeValue | |
ZNRecord | Generic Record Format to store data at a Node This can be used to store simpleFields mapFields listFields |
ZNRecordAssembler | Constructs ZNRecords from collections of ZNRecords |
ZNRecordBucketizer | Operations to divide a ZNRecord into specified buckets |
ZNRecordDelta | A ZNRecord container that specifies how it should be merged with another ZNRecord |
ZNRecordDelta.MergeOperation | Supported methods of updating a ZNRecord |
ZNRecordJsonSerializer | |
ZNRecordRow | A Normalized form of ZNRecord |
ZNRecordSerializer | |
ZNRecordStreamingSerializer | |
ZNRecordUpdater | Class that specifies how a ZNRecord should be updated with another ZNRecord |
ZNRecordUtil |