Hystrix: Latency and Fault Tolerance for Distributed Systems

A B C D E F G H I K M N O P Q R S T U V W 

A

add(HystrixDynamicProperty<T>) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty.ChainBuilder
 
add(String, T) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty.ChainBuilder
 
addCallback(Runnable) - Method in interface com.netflix.hystrix.strategy.properties.HystrixDynamicProperty
Register a callback to be run if the property is updated.
addCallback(Runnable) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
addEvent(int, HystrixEventType) - Method in class com.netflix.hystrix.ExecutionResult
 
addEvent(HystrixEventType) - Method in class com.netflix.hystrix.ExecutionResult
Creates a new ExecutionResult by adding the defined 'event' to the ones on the current instance.
allowRequest() - Method in interface com.netflix.hystrix.HystrixCircuitBreaker
Every HystrixCommand requests asks this if it is allowed to proceed or not.
allowRequest() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.HystrixCircuitBreakerImpl
 
allowRequest() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.NoOpCircuitBreaker
 
allowSingleTest() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.HystrixCircuitBreakerImpl
 
andCollapserPropertiesDefaults(HystrixCollapserProperties.Setter) - Method in class com.netflix.hystrix.HystrixCollapser.Setter
 
andCollapserPropertiesDefaults(HystrixCollapserProperties.Setter) - Method in class com.netflix.hystrix.HystrixObservableCollapser.Setter
 
andCommandKey(HystrixCommandKey) - Method in class com.netflix.hystrix.HystrixCommand.Setter
 
andCommandKey(HystrixCommandKey) - Method in class com.netflix.hystrix.HystrixObservableCommand.Setter
 
andCommandPropertiesDefaults(HystrixCommandProperties.Setter) - Method in class com.netflix.hystrix.HystrixCommand.Setter
Optional
andCommandPropertiesDefaults(HystrixCommandProperties.Setter) - Method in class com.netflix.hystrix.HystrixObservableCommand.Setter
Optional
andScope(HystrixCollapser.Scope) - Method in class com.netflix.hystrix.HystrixCollapser.Setter
HystrixCollapser.Scope defining what scope the collapsing should occur within
andScope(HystrixObservableCollapser.Scope) - Method in class com.netflix.hystrix.HystrixObservableCollapser.Setter
HystrixObservableCollapser.Scope defining what scope the collapsing should occur within
andThreadPoolKey(HystrixThreadPoolKey) - Method in class com.netflix.hystrix.HystrixCommand.Setter
 
andThreadPoolPropertiesDefaults(HystrixThreadPoolProperties.Setter) - Method in class com.netflix.hystrix.HystrixCommand.Setter
Optional
appendEventToBucket - Static variable in class com.netflix.hystrix.HystrixCollapserMetrics
 
appendEventToBucket - Static variable in class com.netflix.hystrix.HystrixCommandMetrics
 
appendEventToBucket - Static variable in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
asKey(String) - Static method in class com.netflix.hystrix.HystrixCollapserKey.Factory
Retrieve (or create) an interned HystrixCollapserKey instance for a given name.
asKey(String) - Static method in class com.netflix.hystrix.HystrixCommandGroupKey.Factory
Retrieve (or create) an interned HystrixCommandGroup instance for a given name.
asKey(String) - Static method in class com.netflix.hystrix.HystrixCommandKey.Factory
Retrieve (or create) an interned HystrixCommandKey instance for a given name.
asKey(String) - Static method in class com.netflix.hystrix.HystrixThreadPoolKey.Factory
Retrieve (or create) an interned HystrixThreadPoolKey instance for a given name.
asProperty(HystrixPropertiesChainedArchaiusProperty.ChainLink<T>) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 
asProperty(HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 
asProperty(HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 
asProperty(HystrixPropertiesChainedArchaiusProperty.DynamicLongProperty) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 
asProperty(HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 
asProperty(HystrixProperty<T>...) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
When retrieved this will iterate over the contained HystrixProperty instances until a non-null value is found and return that.
asProperty(HystrixProperty<T>, T) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
When retrieved this will return the value from the given HystrixProperty or if that returns null then return the defaultValue.
asProperty(T) - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 

B

BooleanProperty(HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
BooleanProperty(HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty, HystrixPropertiesChainedArchaiusProperty.BooleanProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
BooleanProperty(HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty, HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
BooleanProperty(String, HystrixPropertiesChainedArchaiusProperty.BooleanProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
BooleanProperty(String, HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
bucketAggregator - Static variable in class com.netflix.hystrix.HystrixCollapserMetrics
 
bucketAggregator - Static variable in class com.netflix.hystrix.HystrixCommandMetrics
 
build() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty.ChainBuilder
 

C

cachedObservable - Variable in class com.netflix.hystrix.HystrixCachedObservable
 
call() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixContexSchedulerAction
 
call() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixContextCallable
 
ChainLink() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
No arg constructor - used for end node
ChainLink(HystrixPropertiesChainedArchaiusProperty.ChainLink<T>) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
checkAndFlip() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
circuitBreakerEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether to use a HystrixCircuitBreaker or not.
circuitBreakerErrorThresholdPercentage() - Method in class com.netflix.hystrix.HystrixCommandProperties
Error percentage threshold (as whole number such as 50) at which point the circuit breaker will trip open and reject requests.
circuitBreakerForceClosed() - Method in class com.netflix.hystrix.HystrixCommandProperties
If true the HystrixCircuitBreaker.allowRequest() will always return true to allow requests regardless of the error percentage from HystrixCommandMetrics.getHealthCounts().
circuitBreakerForceOpen() - Method in class com.netflix.hystrix.HystrixCommandProperties
If true the HystrixCircuitBreaker.allowRequest() will always return false, causing the circuit to be open (tripped) and reject all requests.
circuitBreakerRequestVolumeThreshold() - Method in class com.netflix.hystrix.HystrixCommandProperties
Minimum number of requests in the HystrixCommandProperties.metricsRollingStatisticalWindowInMilliseconds() that must exist before the HystrixCircuitBreaker will trip.
circuitBreakerSleepWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties
The time in milliseconds after a HystrixCircuitBreaker trips open that it should wait before trying requests again.
clear(String) - Method in class com.netflix.hystrix.HystrixRequestCache
Clear the cache for a given cacheKey.
close() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestContext
Shutdown HystrixRequestVariableDefault objects in this context.
commandKey - Variable in class com.netflix.hystrix.HystrixCommand.Setter
 
commandKey - Variable in class com.netflix.hystrix.HystrixObservableCommand.Setter
 
commandPropertiesDefaults - Variable in class com.netflix.hystrix.HystrixCommand.Setter
 
commandPropertiesDefaults - Variable in class com.netflix.hystrix.HystrixObservableCommand.Setter
 
com.netflix.hystrix - package com.netflix.hystrix
Core functionality of Hystrix including the HystrixCommand and HystrixCollapser to be extended from.
com.netflix.hystrix.exception - package com.netflix.hystrix.exception
Custom exception implementations.
com.netflix.hystrix.strategy - package com.netflix.hystrix.strategy
Parent package of strategies and plugin management.
com.netflix.hystrix.strategy.concurrency - package com.netflix.hystrix.strategy.concurrency
Strategy definition for concurrency related behavior and default implementation.
construct() - Method in class com.netflix.hystrix.HystrixObservableCommand
Implement this method with code to be executed when AbstractCommand.observe() or AbstractCommand.toObservable() are invoked.
contains(HystrixEventType) - Method in class com.netflix.hystrix.ExecutionResult.EventCounts
 
containsAnyOf(BitSet) - Method in class com.netflix.hystrix.ExecutionResult.EventCounts
 
coreSize() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties
Core thread-pool size that gets passed to ThreadPoolExecutor.setCorePoolSize(int)
counter - Variable in class com.netflix.hystrix.HystrixMetrics
 
counterAggregator - Static variable in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
createCommand(Collection<HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) - Method in class com.netflix.hystrix.HystrixCollapser
Factory method to create a new HystrixCommand<BatchReturnType> command object each time a batch needs to be executed.
createCommand(Collection<HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) - Method in class com.netflix.hystrix.HystrixObservableCollapser
Factory method to create a new HystrixObservableCommand<BatchReturnType> command object each time a batch needs to be executed.
createOrRetrievePublisherForCollapser(HystrixCollapserKey, HystrixCollapserMetrics, HystrixCollapserProperties) - Static method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherFactory
Get an instance of HystrixMetricsPublisherCollapser with the given factory HystrixMetricsPublisher implementation for each HystrixCollapser instance.
createOrRetrievePublisherForCommand(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandMetrics, HystrixCircuitBreaker, HystrixCommandProperties) - Static method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherFactory
Get an instance of HystrixMetricsPublisherCommand with the given factory HystrixMetricsPublisher implementation for each HystrixCommand instance.
createOrRetrievePublisherForThreadPool(HystrixThreadPoolKey, HystrixThreadPoolMetrics, HystrixThreadPoolProperties) - Static method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherFactory
Get an instance of HystrixMetricsPublisherThreadPool with the given factory HystrixMetricsPublisher implementation for each HystrixThreadPool instance.
createWorker() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixContextScheduler
 
com.netflix.hystrix.strategy.eventnotifier - package com.netflix.hystrix.strategy.eventnotifier
Strategy definition for event notification.
com.netflix.hystrix.strategy.executionhook - package com.netflix.hystrix.strategy.executionhook
Strategy definition for execution hook.
com.netflix.hystrix.strategy.metrics - package com.netflix.hystrix.strategy.metrics
Strategy definition for publishing metrics and default implementation.
com.netflix.hystrix.strategy.properties - package com.netflix.hystrix.strategy.properties
Strategy definition for properties and configuration and default implementation.

D

defaultSetter() - Static method in class com.netflix.hystrix.HystrixCollapserProperties
Factory method to retrieve the default Setter.
defaultSetter() - Static method in class com.netflix.hystrix.HystrixCommandProperties
Factory method to retrieve the default Setter.
defaultSetter() - Static method in class com.netflix.hystrix.HystrixThreadPoolProperties
Factory method to retrieve the default Setter.
DynamicBooleanProperty(String, Boolean) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty
 
DynamicIntegerProperty(String, Integer) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty
 
DynamicLongProperty(String, Long) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicLongProperty
 
DynamicStringProperty(String, String) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty
 

E

emitResponse(ResponseType) - Method in interface com.netflix.hystrix.HystrixCollapser.CollapsedRequest
When invoked, any Observer will be OnNexted this value
empty() - Static method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
 
equals(Object) - Method in class com.netflix.hystrix.ExecutionResult.EventCounts
 
EXCEPTION_PRODUCING_EVENT_TYPES - Static variable in enum com.netflix.hystrix.HystrixEventType
List of events that throw an Exception to the caller
execute() - Method in class com.netflix.hystrix.HystrixCollapser
Used for synchronous execution.
execute() - Method in class com.netflix.hystrix.HystrixCommand
Used for synchronous execution of command.
execute() - Method in interface com.netflix.hystrix.HystrixExecutable
Used for synchronous execution of command.
executionIsolationSemaphoreMaxConcurrentRequests() - Method in class com.netflix.hystrix.HystrixCommandProperties
Number of concurrent requests permitted to HystrixCommand.run().
executionIsolationStrategy() - Method in class com.netflix.hystrix.HystrixCommandProperties
What isolation strategy HystrixCommand.run() will be executed with.
executionIsolationThreadInterruptOnTimeout() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether the execution thread should attempt an interrupt (using Future.cancel(boolean)) when a thread times out.
executionIsolationThreadPoolKeyOverride() - Method in class com.netflix.hystrix.HystrixCommandProperties
Allow a dynamic override of the HystrixThreadPoolKey that will dynamically change which HystrixThreadPool a HystrixCommand executes on.
executionIsolationThreadTimeoutInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties
Deprecated.
As of release 1.4.0, replaced by HystrixCommandProperties.executionTimeoutInMilliseconds(). Timeout is no longer specific to thread-isolation commands, so the thread-specific name is misleading. Time in milliseconds at which point the command will timeout and halt execution.

If HystrixCommandProperties.executionIsolationThreadInterruptOnTimeout == true and the command is thread-isolated, the executing thread will be interrupted. If the command is semaphore-isolated and a HystrixObservableCommand, that command will get unsubscribed.

executionOccurred() - Method in class com.netflix.hystrix.ExecutionResult
 
ExecutionResult - Class in com.netflix.hystrix
Immutable holder class for the status of command execution.
ExecutionResult.EventCounts - Class in com.netflix.hystrix
 
executionTimeoutEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether the timeout mechanism is enabled for this command
executionTimeoutInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties
Time in milliseconds at which point the command will timeout and halt execution.

F

Factory() - Constructor for class com.netflix.hystrix.HystrixCircuitBreaker.Factory
 
Factory() - Constructor for class com.netflix.hystrix.HystrixThreadPool.Factory
 
Factory() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 
fallbackEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether HystrixCommand.getFallback() should be attempted when failure occurs.
fallbackIsolationSemaphoreMaxConcurrentRequests() - Method in class com.netflix.hystrix.HystrixCommandProperties
Number of concurrent requests permitted to HystrixCommand.getFallback().
forBoolean() - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty
 
forInteger() - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty
 
forLong() - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty
 
forString() - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty
 
from(HystrixEventType) - Static method in enum com.netflix.hystrix.HystrixEventType.ThreadPool
 
from(HystrixEventType...) - Static method in class com.netflix.hystrix.ExecutionResult
 
from(HystrixRollingNumberEvent) - Static method in enum com.netflix.hystrix.HystrixEventType.Collapser
 
from(HystrixRollingNumberEvent) - Static method in enum com.netflix.hystrix.HystrixEventType
 
from(HystrixRollingNumberEvent) - Static method in enum com.netflix.hystrix.HystrixEventType.ThreadPool
 
from(Observable<R>) - Static method in class com.netflix.hystrix.HystrixCachedObservable
 
from(Observable<R>, AbstractCommand<R>) - Static method in class com.netflix.hystrix.HystrixCachedObservable
 

G

get() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
Return null if the HystrixRequestContext has not been initialized for the current thread.
get() - Method in interface com.netflix.hystrix.strategy.concurrency.HystrixRequestVariable
Retrieve current value or initialize and then return value for this variable for the current request scope.
get() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
Get the current value for this variable for the current request context.
get() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
get() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty
Get the current value from the underlying DynamicProperty
get() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty
Get the current value from the underlying DynamicProperty
get() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicLongProperty
Get the current value from the underlying DynamicProperty
get() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty
Get the current value from the underlying DynamicProperty
get() - Method in interface com.netflix.hystrix.strategy.properties.HystrixProperty
 
get(HystrixConcurrencyStrategy) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableHolder
 
getAllExecutedCommands() - Method in class com.netflix.hystrix.HystrixRequestLog
Retrieve HystrixCommand instances that were executed during this HystrixRequestContext.
getArgument() - Method in interface com.netflix.hystrix.HystrixCollapser.CollapsedRequest
The request argument passed into the HystrixCollapser instance constructor which was then collapsed.
getBatchReturnTypeKeySelector() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Function that returns the key used for matching returned objects against request argument types.
getBatchReturnTypeToResponseTypeMapper() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Function for mapping from BatchReturnType to ResponseType.
getBatchSizeMean() - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getBatchSizePercentile(double) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
Retrieve the batch size for the HystrixCollapser being invoked at a given percentile.
getBlockingQueue(int) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixConcurrencyStrategy
getBoolean(String, Boolean) - Method in interface com.netflix.hystrix.strategy.properties.HystrixDynamicProperties
Requests a property that may or may not actually exist.
getBoolean(String, Boolean) - Method in class com.netflix.hystrix.strategy.properties.HystrixDynamicPropertiesSystemProperties
 
getCacheKey() - Method in class com.netflix.hystrix.HystrixCollapser
Key to be used for request caching.
getCacheKey() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Key to be used for request caching.
getCircuitBreakerEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getCircuitBreakerErrorThresholdPercentage() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getCircuitBreakerForceClosed() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getCircuitBreakerForceOpen() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getCircuitBreakerRequestVolumeThreshold() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getCircuitBreakerSleepWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getCollapserKey() - Method in class com.netflix.hystrix.ExecutionResult
 
getCollapserKey() - Method in class com.netflix.hystrix.HystrixCollapser
Key of the HystrixCollapser used for properties, metrics, caches, reporting etc.
getCollapserKey() - Method in class com.netflix.hystrix.HystrixCollapserMetrics
HystrixCollapserKey these metrics represent.
getCollapserKey() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Key of the HystrixObservableCollapser used for properties, metrics, caches, reporting etc.
getCollapserProperties(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
Get an instance of HystrixCollapserProperties with the given factory HystrixPropertiesStrategy implementation for each HystrixCollapserKey instance.
getCollapserProperties(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Construct an implementation of HystrixCollapserProperties for HystrixCollapser instances with HystrixCollapserKey.
getCollapserPropertiesCacheKey(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Cache key used for caching the retrieval of HystrixCollapserProperties implementations.
getCollapsingEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
Deprecated.
getCommandCount() - Static method in class com.netflix.hystrix.HystrixCounters
Return the number of unique HystrixCommands that have been registered
getCommandExecutionHook() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Retrieve instance of HystrixCommandExecutionHook to use based on order of precedence as defined in HystrixPlugins class header.
getCommandGroup() - Method in class com.netflix.hystrix.HystrixCommandMetrics
HystrixCommandGroupKey of the HystrixCommand these metrics represent.
getCommandGroup() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getCommandKey() - Method in class com.netflix.hystrix.HystrixCommandMetrics
HystrixCommandKey these metrics represent.
getCommandKey() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getCommandProperties(HystrixCommandKey, HystrixCommandProperties.Setter) - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
Get an instance of HystrixCommandProperties with the given factory HystrixPropertiesStrategy implementation for each HystrixCommand instance.
getCommandProperties(HystrixCommandKey, HystrixCommandProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Construct an implementation of HystrixCommandProperties for HystrixCommand instances with HystrixCommandKey.
getCommandPropertiesCacheKey(HystrixCommandKey, HystrixCommandProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Cache key used for caching the retrieval of HystrixCommandProperties implementations.
getCommandRunStartTimeInNanos() - Method in class com.netflix.hystrix.ExecutionResult
 
getCommandRunStartTimeInNanos() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getConcurrencyStrategy() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Retrieve instance of HystrixConcurrencyStrategy to use based on order of precedence as defined in HystrixPlugins class header.
getContextForCurrentThread() - Static method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestContext
 
getCorePoolSize() - Method in class com.netflix.hystrix.HystrixTimerThreadPoolProperties
 
getCoreSize() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
getCoreSize() - Method in class com.netflix.hystrix.HystrixTimerThreadPoolProperties.Setter
 
getCount(HystrixEventType) - Method in class com.netflix.hystrix.ExecutionResult.EventCounts
 
getCumulativeCount(HystrixEventType) - Method in class com.netflix.hystrix.HystrixCommandMetrics
 
getCumulativeCount(HystrixEventType.Collapser) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getCumulativeCount(HystrixEventType.ThreadPool) - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
getCumulativeCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getCumulativeCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixCommandMetrics
 
getCumulativeCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixMetrics
Get the cumulative count since the start of the application for the given HystrixRollingNumberEvent.
getCumulativeCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
getCumulativeCountThreadsExecuted() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Cumulative count of number of threads executed since the start of the application.
getCumulativeCountThreadsRejected() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Cumulative count of number of threads rejected since the start of the application.
getCurrentActiveCount() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getActiveCount()
getCurrentCompletedTaskCount() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getCompletedTaskCount()
getCurrentConcurrencyThunk(HystrixThreadPoolKey) - Static method in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
getCurrentConcurrentExecutionCount() - Method in class com.netflix.hystrix.HystrixCommandMetrics
Current number of concurrent executions of HystrixCommand.run();
getCurrentCorePoolSize() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getCorePoolSize()
getCurrentLargestPoolSize() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getLargestPoolSize()
getCurrentMaximumPoolSize() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getMaximumPoolSize()
getCurrentPoolSize() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getPoolSize()
getCurrentQueueSize() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Current size of BlockingQueue used by the thread-pool
getCurrentRequest() - Static method in class com.netflix.hystrix.HystrixRequestLog
HystrixRequestLog for current request as defined by HystrixRequestContext.
getCurrentRequest(HystrixConcurrencyStrategy) - Static method in class com.netflix.hystrix.HystrixRequestLog
HystrixRequestLog for current request as defined by HystrixRequestContext.
getCurrentTaskCount() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Value from ThreadPoolExecutor.getTaskCount()
getCurrentThreadExecutingCommand() - Static method in class com.netflix.hystrix.Hystrix
Allows a thread to query whether it's current point of execution is within the scope of a HystrixCommand.
getDynamicProperties() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Retrieves the instance of HystrixDynamicProperties to use.
getErrorCount() - Method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
 
getErrorPercentage() - Method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
 
getEventCounts() - Method in class com.netflix.hystrix.ExecutionResult
 
getEventCounts() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getEventNotifier() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Retrieve instance of HystrixEventNotifier to use based on order of precedence as defined in HystrixPlugins class header.
getException() - Method in class com.netflix.hystrix.ExecutionResult
 
getExceptionFromThrowable(Throwable) - Method in class com.netflix.hystrix.HystrixObservableCollapser
 
getExecutedCommands() - Method in class com.netflix.hystrix.HystrixRequestLog
Deprecated.
getExecutedCommandsAsString() - Method in class com.netflix.hystrix.HystrixRequestLog
Formats the log of executed commands into a string usable for logging purposes.
getExecutionEvents() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getExecutionException() - Method in class com.netflix.hystrix.ExecutionResult
 
getExecutionIsolationSemaphoreMaxConcurrentRequests() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getExecutionIsolationStrategy() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getExecutionIsolationThreadInterruptOnTimeout() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getExecutionIsolationThreadTimeoutInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
getExecutionLatency() - Method in class com.netflix.hystrix.ExecutionResult
 
getExecutionObservable() - Method in class com.netflix.hystrix.HystrixCommand
 
getExecutionObservable() - Method in class com.netflix.hystrix.HystrixObservableCommand
 
getExecutionTimeInMilliseconds() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getExecutionTimeMean() - Method in class com.netflix.hystrix.HystrixCommandMetrics
The mean (average) execution time (in milliseconds) for the HystrixCommand.run().
getExecutionTimeoutEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getExecutionTimeoutInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getExecutionTimePercentile(double) - Method in class com.netflix.hystrix.HystrixCommandMetrics
Retrieve the execution time (in milliseconds) for the HystrixCommand.run() method being invoked at a given percentile.
getExecutor() - Method in interface com.netflix.hystrix.HystrixThreadPool
Implementation of ThreadPoolExecutor.
getExecutor() - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
getFailedExecutionException() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getFailureType() - Method in exception com.netflix.hystrix.exception.HystrixRuntimeException
The type of failure that caused this exception to be thrown.
getFallback() - Method in class com.netflix.hystrix.HystrixCommand
If HystrixCommand.execute() or HystrixCommand.queue() fails in any way then this method will be invoked to provide an opportunity to return a fallback response.
getFallbackEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getFallbackException() - Method in exception com.netflix.hystrix.exception.HystrixRuntimeException
The Throwable that was thrown when trying to retrieve a fallback.
getFallbackIsolationSemaphoreMaxConcurrentRequests() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getFallbackMethodName() - Method in class com.netflix.hystrix.HystrixCommand
 
getFallbackMethodName() - Method in class com.netflix.hystrix.HystrixObservableCommand
 
getFallbackObservable() - Method in class com.netflix.hystrix.HystrixCommand
 
getFallbackObservable() - Method in class com.netflix.hystrix.HystrixObservableCommand
 
getGlobalConcurrentThreadsExecuting() - Static method in class com.netflix.hystrix.HystrixCounters
Return the number of currently-executing Hystrix threads
getGroupCount() - Static method in class com.netflix.hystrix.HystrixCounters
Return the number of unique HystrixCommandGroupKeys that have been registered
getHealthCounts() - Method in class com.netflix.hystrix.HystrixCommandMetrics
Retrieve a snapshot of total requests, error count and error percentage.
getImplementingClass() - Method in exception com.netflix.hystrix.exception.HystrixRuntimeException
The implementing class of the HystrixCommand.
getInstance() - Static method in class com.netflix.hystrix.strategy.concurrency.HystrixConcurrencyStrategyDefault
 
getInstance() - Static method in class com.netflix.hystrix.strategy.eventnotifier.HystrixEventNotifierDefault
 
getInstance() - Static method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHookDefault
 
getInstance() - Static method in class com.netflix.hystrix.strategy.HystrixPlugins
 
getInstance() - Static method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherDefault
 
getInstance() - Static method in class com.netflix.hystrix.strategy.properties.HystrixDynamicPropertiesSystemProperties
 
getInstance() - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategyDefault
 
getInstance(HystrixCollapserKey, HystrixCollapserProperties) - Static method in class com.netflix.hystrix.HystrixCollapserMetrics
Get or create the HystrixCollapserMetrics instance for a given HystrixCollapserKey.
getInstance(HystrixCollapserKey, HystrixConcurrencyStrategy) - Static method in class com.netflix.hystrix.HystrixRequestCache
 
getInstance(HystrixCommandKey) - Static method in class com.netflix.hystrix.HystrixCircuitBreaker.Factory
Get the HystrixCircuitBreaker instance for a given HystrixCommandKey or null if none exists.
getInstance(HystrixCommandKey) - Static method in class com.netflix.hystrix.HystrixCommandMetrics
Get the HystrixCommandMetrics instance for a given HystrixCommandKey or null if one does not exist.
getInstance(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandProperties) - Static method in class com.netflix.hystrix.HystrixCommandMetrics
Get or create the HystrixCommandMetrics instance for a given HystrixCommandKey.
getInstance(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandProperties, HystrixCommandMetrics) - Static method in class com.netflix.hystrix.HystrixCircuitBreaker.Factory
Get the HystrixCircuitBreaker instance for a given HystrixCommandKey.
getInstance(HystrixCommandKey, HystrixCommandGroupKey, HystrixThreadPoolKey, HystrixCommandProperties) - Static method in class com.netflix.hystrix.HystrixCommandMetrics
Get or create the HystrixCommandMetrics instance for a given HystrixCommandKey.
getInstance(HystrixCommandKey, HystrixConcurrencyStrategy) - Static method in class com.netflix.hystrix.HystrixRequestCache
 
getInstance(HystrixThreadPoolKey) - Static method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Get the HystrixThreadPoolMetrics instance for a given HystrixThreadPoolKey or null if one does not exist.
getInstance(HystrixThreadPoolKey, ThreadPoolExecutor, HystrixThreadPoolProperties) - Static method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Get or create the HystrixThreadPoolMetrics instance for a given HystrixThreadPoolKey.
getInstances() - Static method in class com.netflix.hystrix.HystrixCollapserMetrics
All registered instances of HystrixCollapserMetrics
getInstances() - Static method in class com.netflix.hystrix.HystrixCommandMetrics
All registered instances of HystrixCommandMetrics
getInstances() - Static method in class com.netflix.hystrix.HystrixThreadPoolMetrics
All registered instances of HystrixThreadPoolMetrics
getInteger(String, Integer) - Method in interface com.netflix.hystrix.strategy.properties.HystrixDynamicProperties
Requests a property that may or may not actually exist.
getInteger(String, Integer) - Method in class com.netflix.hystrix.strategy.properties.HystrixDynamicPropertiesSystemProperties
 
getKeepAliveTimeMinutes() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
getLong(String, Long) - Method in interface com.netflix.hystrix.strategy.properties.HystrixDynamicProperties
Requests a property that may or may not actually exist.
getLong(String, Long) - Method in class com.netflix.hystrix.strategy.properties.HystrixDynamicPropertiesSystemProperties
 
getMaxQueueSize() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
getMaxRequestsInBatch() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetrics() - Method in class com.netflix.hystrix.HystrixCollapser
Return the HystrixCollapserMetrics for this collapser
getMetrics() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getMetrics() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Return the HystrixCollapserMetrics for this collapser
getMetricsHealthSnapshotIntervalInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsPublisher() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Retrieve instance of HystrixMetricsPublisher to use based on order of precedence as defined in HystrixPlugins class header.
getMetricsPublisherForCollapser(HystrixCollapserKey, HystrixCollapserMetrics, HystrixCollapserProperties) - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
Construct an implementation of HystrixMetricsPublisherCollapser for HystrixCollapser instances having key HystrixCollapserKey.
getMetricsPublisherForCommand(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandMetrics, HystrixCircuitBreaker, HystrixCommandProperties) - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
Construct an implementation of HystrixMetricsPublisherCommand for HystrixCommand instances having key HystrixCommandKey.
getMetricsPublisherForThreadPool(HystrixThreadPoolKey, HystrixThreadPoolMetrics, HystrixThreadPoolProperties) - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
Construct an implementation of HystrixMetricsPublisherThreadPool for HystrixThreadPool instances having key HystrixThreadPoolKey.
getMetricsRollingPercentileBucketSize() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetricsRollingPercentileBucketSize() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsRollingPercentileEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetricsRollingPercentileEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsRollingPercentileWindowBuckets() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetricsRollingPercentileWindowBuckets() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsRollingPercentileWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetricsRollingPercentileWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsRollingStatisticalWindowBuckets() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetricsRollingStatisticalWindowBuckets() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsRollingStatisticalWindowBuckets() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
getMetricsRollingStatisticalWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getMetricsRollingStatisticalWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getMetricsRollingStatisticalWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
getName() - Method in interface com.netflix.hystrix.strategy.properties.HystrixDynamicProperty
 
getName() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
getName() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
getName() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
getName() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 
getNumberCollapsed() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getNumberEmissions() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getNumberFallbackEmissions() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getOrderedList() - Method in class com.netflix.hystrix.ExecutionResult
 
getOriginatingCollapserKey() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getProperties() - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getProperties() - Method in class com.netflix.hystrix.HystrixCommandMetrics
HystrixCommandProperties of the HystrixCommand these metrics represent.
getProperties() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getProperties() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
HystrixThreadPoolProperties of the HystrixThreadPool these metrics represent.
getPropertiesStrategy() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Retrieve instance of HystrixPropertiesStrategy to use based on order of precedence as defined in HystrixPlugins class header.
getProperty(HystrixDynamicProperties, String, T, Class<T>) - Static method in class com.netflix.hystrix.strategy.properties.HystrixDynamicProperties.Util
A convenience method to get a property by type (Class).
getPublicCacheKey() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getQueueSizeRejectionThreshold() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
getRequestArgument() - Method in class com.netflix.hystrix.HystrixCollapser
The request arguments to be passed to the HystrixCommand.
getRequestArgument() - Method in class com.netflix.hystrix.HystrixObservableCollapser
The request arguments to be passed to the HystrixCommand.
getRequestArgumentKeySelector() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Function that returns the key used for matching request arguments against returned objects.
getRequestCacheEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getRequestCacheEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getRequestLogEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
getRequestVariable(HystrixRequestVariableLifecycle<T>) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixConcurrencyStrategy
Factory method to return an implementation of HystrixRequestVariable that behaves like a ThreadLocal except that it is scoped to a request instead of a thread.
getRollingCount(HystrixEventType) - Method in class com.netflix.hystrix.HystrixCommandMetrics
 
getRollingCount(HystrixEventType.Collapser) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getRollingCount(HystrixEventType.ThreadPool) - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
getRollingCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getRollingCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixCommandMetrics
 
getRollingCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixMetrics
Get the rolling count for the given HystrixRollingNumberEvent.
getRollingCount(HystrixRollingNumberEvent) - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
 
getRollingCountThreadsExecuted() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Rolling count of number of threads executed during rolling statistical window.
getRollingCountThreadsRejected() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Rolling count of number of threads rejected during rolling statistical window.
getRollingMaxActiveThreads() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Rolling max number of active threads during rolling statistical window.
getRollingMaxConcurrentExecutions() - Method in class com.netflix.hystrix.HystrixCommandMetrics
 
getScheduler() - Method in interface com.netflix.hystrix.HystrixThreadPool
 
getScheduler() - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
getScheduler(Func0<Boolean>) - Method in interface com.netflix.hystrix.HystrixThreadPool
 
getScheduler(Func0<Boolean>) - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
getScope() - Method in class com.netflix.hystrix.HystrixCollapser
Scope of collapsing.
getScope() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Scope of collapsing.
getShardSizeMean() - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
getShardSizePercentile(double) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
Retrieve the shard size for the HystrixCollapser being invoked at a given percentile.
getStartTimestamp() - Method in class com.netflix.hystrix.ExecutionResult
 
getString(String, String) - Method in interface com.netflix.hystrix.strategy.properties.HystrixDynamicProperties
Requests a property that may or may not actually exist.
getString(String, String) - Method in class com.netflix.hystrix.strategy.properties.HystrixDynamicPropertiesSystemProperties
 
getThreadPool() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
ThreadPoolExecutor this executor represents.
getThreadPool(HystrixThreadPoolKey, HystrixProperty<Integer>, HystrixProperty<Integer>, HystrixProperty<Integer>, TimeUnit, BlockingQueue<Runnable>) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixConcurrencyStrategy
Factory method to provide ThreadPoolExecutor instances as desired.
getThreadPoolCount() - Static method in class com.netflix.hystrix.HystrixCounters
Return the number of unique HystrixThreadPools that have been registered
getThreadPoolKey() - Method in class com.netflix.hystrix.HystrixCommandMetrics
HystrixThreadPoolKey used by HystrixCommand these metrics represent.
getThreadPoolKey() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
getThreadPoolKey() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
HystrixThreadPoolKey these metrics represent.
getThreadPoolProperties(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
Get an instance of HystrixThreadPoolProperties with the given factory HystrixPropertiesStrategy implementation for each HystrixThreadPool instance.
getThreadPoolProperties(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Construct an implementation of HystrixThreadPoolProperties for HystrixThreadPool instances with HystrixThreadPoolKey.
getThreadPoolPropertiesCacheKey(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Cache key used for caching the retrieval of HystrixThreadPoolProperties implementations.
getTimerDelayInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
getTimerThreadPoolProperties() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
Construct an implementation of HystrixTimerThreadPoolProperties for configuration of the timer thread pool that handles timeouts and collapser logic.
getTotalRequests() - Method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
 
getTotalTimeMean() - Method in class com.netflix.hystrix.HystrixCommandMetrics
The mean (average) execution time (in milliseconds) for HystrixCommand.execute() or HystrixCommand.queue().
getTotalTimePercentile(double) - Method in class com.netflix.hystrix.HystrixCommandMetrics
Retrieve the total end-to-end execution time (in milliseconds) for HystrixCommand.execute() or HystrixCommand.queue() at a given percentile.
getType() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty.ChainBuilder
 
getUserThreadLatency() - Method in class com.netflix.hystrix.ExecutionResult
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicLongProperty
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
getValue() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 
groupKey - Variable in class com.netflix.hystrix.HystrixCommand.Setter
 
groupKey - Variable in class com.netflix.hystrix.HystrixObservableCommand.Setter
 

H

hashCode() - Method in class com.netflix.hystrix.ExecutionResult.EventCounts
 
Hystrix - Class in com.netflix.hystrix
Lifecycle management of Hystrix.
Hystrix() - Constructor for class com.netflix.hystrix.Hystrix
 
HystrixBadRequestException - Exception in com.netflix.hystrix.exception
An exception representing an error with provided arguments or state rather than an execution failure.
HystrixBadRequestException(String) - Constructor for exception com.netflix.hystrix.exception.HystrixBadRequestException
 
HystrixBadRequestException(String, Throwable) - Constructor for exception com.netflix.hystrix.exception.HystrixBadRequestException
 
HystrixCachedObservable<R> - Class in com.netflix.hystrix
 
HystrixCachedObservable(Observable<R>) - Constructor for class com.netflix.hystrix.HystrixCachedObservable
 
HystrixCircuitBreaker - Interface in com.netflix.hystrix
Circuit-breaker logic that is hooked into HystrixCommand execution and will stop allowing executions if failures have gone past the defined threshold.
HystrixCircuitBreaker.Factory - Class in com.netflix.hystrix
 
HystrixCircuitBreaker.HystrixCircuitBreakerImpl - Class in com.netflix.hystrix
The default production implementation of HystrixCircuitBreaker.
HystrixCircuitBreaker.NoOpCircuitBreaker - Class in com.netflix.hystrix
An implementation of the circuit breaker that does nothing.
HystrixCircuitBreakerImpl(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandProperties, HystrixCommandMetrics) - Constructor for class com.netflix.hystrix.HystrixCircuitBreaker.HystrixCircuitBreakerImpl
 
HystrixCollapser<BatchReturnType,ResponseType,RequestArgumentType> - Class in com.netflix.hystrix
Collapse multiple requests into a single HystrixCommand execution based on a time window and optionally a max batch size.
HystrixCollapser() - Constructor for class com.netflix.hystrix.HystrixCollapser
Collapser with default HystrixCollapserKey derived from the implementing class name and scoped to HystrixCollapser.Scope.REQUEST and default configuration.
HystrixCollapser(HystrixCollapser.Setter) - Constructor for class com.netflix.hystrix.HystrixCollapser
Construct a HystrixCollapser with defined HystrixCollapser.Setter that allows injecting property and strategy overrides and other optional arguments.
HystrixCollapser(HystrixCollapserKey) - Constructor for class com.netflix.hystrix.HystrixCollapser
Collapser scoped to HystrixCollapser.Scope.REQUEST and default configuration.
HystrixCollapser.CollapsedRequest<ResponseType,RequestArgumentType> - Interface in com.netflix.hystrix
A request argument RequestArgumentType that was collapsed for batch processing and needs a response ResponseType set on it by the executeBatch implementation.
HystrixCollapser.Scope - Enum in com.netflix.hystrix
The scope of request collapsing.
HystrixCollapser.Setter - Class in com.netflix.hystrix
Fluent interface for arguments to the HystrixCollapser constructor.
HystrixCollapserKey - Interface in com.netflix.hystrix
A key to represent a HystrixCollapser for monitoring, circuit-breakers, metrics publishing, caching and other such uses.
HystrixCollapserKey.Factory - Class in com.netflix.hystrix
 
HystrixCollapserMetrics - Class in com.netflix.hystrix
Used by HystrixCollapser to record metrics.
HystrixCollapserProperties - Class in com.netflix.hystrix
Properties for instances of HystrixCollapser.
HystrixCollapserProperties(HystrixCollapserKey) - Constructor for class com.netflix.hystrix.HystrixCollapserProperties
 
HystrixCollapserProperties(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Constructor for class com.netflix.hystrix.HystrixCollapserProperties
 
HystrixCollapserProperties(HystrixCollapserKey, HystrixCollapserProperties.Setter, String) - Constructor for class com.netflix.hystrix.HystrixCollapserProperties
 
HystrixCollapserProperties.Setter - Class in com.netflix.hystrix
Fluent interface that allows chained setting of properties that can be passed into a HystrixCollapser constructor to inject instance specific property overrides.
HystrixCommand<R> - Class in com.netflix.hystrix
Used to wrap code that will execute potentially risky functionality (typically meaning a service call over the network) with fault and latency tolerance, statistics and performance metrics capture, circuit breaker and bulkhead functionality.
HystrixCommand(HystrixCommand.Setter) - Constructor for class com.netflix.hystrix.HystrixCommand
Construct a HystrixCommand with defined HystrixCommand.Setter that allows injecting property and strategy overrides and other optional arguments.
HystrixCommand(HystrixCommandGroupKey) - Constructor for class com.netflix.hystrix.HystrixCommand
Construct a HystrixCommand with defined HystrixCommandGroupKey.
HystrixCommand(HystrixCommandGroupKey, int) - Constructor for class com.netflix.hystrix.HystrixCommand
Construct a HystrixCommand with defined HystrixCommandGroupKey and thread timeout
HystrixCommand(HystrixCommandGroupKey, HystrixThreadPoolKey) - Constructor for class com.netflix.hystrix.HystrixCommand
HystrixCommand(HystrixCommandGroupKey, HystrixThreadPoolKey, int) - Constructor for class com.netflix.hystrix.HystrixCommand
Construct a HystrixCommand with defined HystrixCommandGroupKey, HystrixThreadPoolKey, and thread timeout.
HystrixCommand.Setter - Class in com.netflix.hystrix
Fluent interface for arguments to the HystrixCommand constructor.
HystrixCommandExecutionHook - Class in com.netflix.hystrix.strategy.executionhook
Abstract ExecutionHook with invocations at different lifecycle points of HystrixCommand and HystrixObservableCommand execution with default no-op implementations.
HystrixCommandExecutionHook() - Constructor for class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
 
HystrixCommandExecutionHookDefault - Class in com.netflix.hystrix.strategy.executionhook
Default implementations of HystrixCommandExecutionHook that does nothing.
HystrixCommandGroupKey - Interface in com.netflix.hystrix
A group name for a HystrixCommand.
HystrixCommandGroupKey.Factory - Class in com.netflix.hystrix
 
HystrixCommandKey - Interface in com.netflix.hystrix
A key to represent a HystrixCommand for monitoring, circuit-breakers, metrics publishing, caching and other such uses.
HystrixCommandKey.Factory - Class in com.netflix.hystrix
 
HystrixCommandMetrics - Class in com.netflix.hystrix
Used by HystrixCommand to record metrics.
HystrixCommandMetrics.HealthCounts - Class in com.netflix.hystrix
Number of requests during rolling window.
HystrixCommandProperties - Class in com.netflix.hystrix
Properties for instances of HystrixCommand.
HystrixCommandProperties(HystrixCommandKey) - Constructor for class com.netflix.hystrix.HystrixCommandProperties
 
HystrixCommandProperties(HystrixCommandKey, HystrixCommandProperties.Setter) - Constructor for class com.netflix.hystrix.HystrixCommandProperties
 
HystrixCommandProperties(HystrixCommandKey, HystrixCommandProperties.Setter, String) - Constructor for class com.netflix.hystrix.HystrixCommandProperties
 
HystrixCommandProperties.ExecutionIsolationStrategy - Enum in com.netflix.hystrix
Isolation strategy to use when executing a HystrixCommand.
HystrixCommandProperties.Setter - Class in com.netflix.hystrix
Fluent interface that allows chained setting of properties that can be passed into a HystrixCommand constructor to inject instance specific property overrides.
HystrixCommandResponseFromCache<R> - Class in com.netflix.hystrix
 
HystrixConcurrencyStrategy - Class in com.netflix.hystrix.strategy.concurrency
Abstract class for defining different behavior or implementations for concurrency related aspects of the system with default implementations.
HystrixConcurrencyStrategy() - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixConcurrencyStrategy
 
HystrixConcurrencyStrategyDefault - Class in com.netflix.hystrix.strategy.concurrency
Default implementation of HystrixConcurrencyStrategy using standard java.util.concurrent.* implementations.
HystrixContexSchedulerAction - Class in com.netflix.hystrix.strategy.concurrency
Wrapper around Func2 that manages the HystrixRequestContext initialization and cleanup for the execution of the Func2
HystrixContexSchedulerAction(HystrixConcurrencyStrategy, Action0) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContexSchedulerAction
 
HystrixContexSchedulerAction(Action0) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContexSchedulerAction
 
HystrixContextCallable<K> - Class in com.netflix.hystrix.strategy.concurrency
Wrapper around Callable that manages the HystrixRequestContext initialization and cleanup for the execution of the Callable
HystrixContextCallable(HystrixConcurrencyStrategy, Callable<K>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextCallable
 
HystrixContextCallable(Callable<K>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextCallable
 
HystrixContextRunnable - Class in com.netflix.hystrix.strategy.concurrency
Wrapper around Runnable that manages the HystrixRequestContext initialization and cleanup for the execution of the Runnable
HystrixContextRunnable(HystrixConcurrencyStrategy, Runnable) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextRunnable
 
HystrixContextRunnable(Runnable) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextRunnable
 
HystrixContextScheduler - Class in com.netflix.hystrix.strategy.concurrency
Wrap a Scheduler so that scheduled actions are wrapped with HystrixContexSchedulerAction so that the HystrixRequestContext is properly copied across threads (if they are used by the Scheduler).
HystrixContextScheduler(HystrixConcurrencyStrategy, HystrixThreadPool) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextScheduler
 
HystrixContextScheduler(HystrixConcurrencyStrategy, HystrixThreadPool, Func0<Boolean>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextScheduler
 
HystrixContextScheduler(HystrixConcurrencyStrategy, Scheduler) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextScheduler
 
HystrixContextScheduler(Scheduler) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixContextScheduler
 
HystrixCounters - Class in com.netflix.hystrix
Class with global statistics on Hystrix runtime behavior.
HystrixCounters() - Constructor for class com.netflix.hystrix.HystrixCounters
 
HystrixDynamicProperties - Interface in com.netflix.hystrix.strategy.properties
A hystrix plugin (SPI) for resolving dynamic configuration properties.
HystrixDynamicProperties.Util - Class in com.netflix.hystrix.strategy.properties
 
HystrixDynamicPropertiesSystemProperties - Class in com.netflix.hystrix.strategy.properties
 
HystrixDynamicPropertiesSystemProperties() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixDynamicPropertiesSystemProperties
Only public for unit test purposes.
HystrixDynamicProperty<T> - Interface in com.netflix.hystrix.strategy.properties
Generic interface to represent a dynamic property value so Hystrix can consume properties without being tied to any particular backing implementation.
HystrixEventNotifier - Class in com.netflix.hystrix.strategy.eventnotifier
Abstract EventNotifier that allows receiving notifications for different events with default implementations.
HystrixEventNotifier() - Constructor for class com.netflix.hystrix.strategy.eventnotifier.HystrixEventNotifier
 
HystrixEventNotifierDefault - Class in com.netflix.hystrix.strategy.eventnotifier
Default implementations of HystrixEventNotifier that does nothing.
HystrixEventType - Enum in com.netflix.hystrix
Various states/events that execution can result in or have tracked.
HystrixEventType.Collapser - Enum in com.netflix.hystrix
 
HystrixEventType.ThreadPool - Enum in com.netflix.hystrix
 
HystrixExecutable<R> - Interface in com.netflix.hystrix
Common interface for executables (HystrixCommand and HystrixCollapser) so client code can treat them the same and combine in typed collections if desired.
HystrixInvokable<R> - Interface in com.netflix.hystrix
Marker interface for Hystrix commands that can be invoked.
HystrixInvokableInfo<R> - Interface in com.netflix.hystrix
 
HystrixLifecycleForwardingRequestVariable<T> - Class in com.netflix.hystrix.strategy.concurrency
Implementation of HystrixRequestVariable which forwards to the wrapped HystrixRequestVariableLifecycle.
HystrixLifecycleForwardingRequestVariable(HystrixRequestVariableLifecycle<T>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
Creates a HystrixRequestVariable which will return data as provided by the HystrixRequestVariableLifecycle
HystrixMetrics - Class in com.netflix.hystrix
Abstract base class for Hystrix metrics
HystrixMetrics(HystrixRollingNumber) - Constructor for class com.netflix.hystrix.HystrixMetrics
 
HystrixMetricsPublisher - Class in com.netflix.hystrix.strategy.metrics
Abstract class with default implementations of Factory methods for creating "Metrics Publisher" instances for getting metrics and other related data exposed, published or otherwise retrievable by external systems such as Servo (https://github.com/Netflix/servo) for monitoring and statistical purposes.
HystrixMetricsPublisher() - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
 
HystrixMetricsPublisherCollapser - Interface in com.netflix.hystrix.strategy.metrics
Metrics publisher for a HystrixCollapser that will be constructed by an implementation of HystrixMetricsPublisher.
HystrixMetricsPublisherCollapserDefault - Class in com.netflix.hystrix.strategy.metrics
Default implementation of HystrixMetricsPublisherCollapser that does nothing.
HystrixMetricsPublisherCollapserDefault(HystrixCollapserKey, HystrixCollapserMetrics, HystrixCollapserProperties) - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCollapserDefault
 
HystrixMetricsPublisherCommand - Interface in com.netflix.hystrix.strategy.metrics
Metrics publisher for a HystrixCommand that will be constructed by an implementation of HystrixMetricsPublisher.
HystrixMetricsPublisherCommandDefault - Class in com.netflix.hystrix.strategy.metrics
Default implementation of HystrixMetricsPublisherCommand that does nothing.
HystrixMetricsPublisherCommandDefault(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandMetrics, HystrixCircuitBreaker, HystrixCommandProperties) - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCommandDefault
 
HystrixMetricsPublisherDefault - Class in com.netflix.hystrix.strategy.metrics
Default implementation of HystrixMetricsPublisher.
HystrixMetricsPublisherFactory - Class in com.netflix.hystrix.strategy.metrics
Factory for retrieving metrics publisher implementations.
HystrixMetricsPublisherThreadPool - Interface in com.netflix.hystrix.strategy.metrics
Metrics publisher for a HystrixThreadPool that will be constructed by an implementation of HystrixMetricsPublisher.
HystrixMetricsPublisherThreadPoolDefault - Class in com.netflix.hystrix.strategy.metrics
Default implementation of HystrixMetricsPublisherThreadPool that does nothing.
HystrixMetricsPublisherThreadPoolDefault(HystrixThreadPoolKey, HystrixThreadPoolMetrics, HystrixThreadPoolProperties) - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherThreadPoolDefault
 
HystrixObservable<R> - Interface in com.netflix.hystrix
Common interface for executables that implement the Observable methods HystrixObservable.observe() and HystrixObservable.toObservable() so client code can treat them the same and combine in typed collections if desired.
HystrixObservableCollapser<K,BatchReturnType,ResponseType,RequestArgumentType> - Class in com.netflix.hystrix
Collapse multiple requests into a single HystrixCommand execution based on a time window and optionally a max batch size.
HystrixObservableCollapser() - Constructor for class com.netflix.hystrix.HystrixObservableCollapser
Collapser with default HystrixCollapserKey derived from the implementing class name and scoped to HystrixObservableCollapser.Scope.REQUEST and default configuration.
HystrixObservableCollapser(HystrixCollapserKey) - Constructor for class com.netflix.hystrix.HystrixObservableCollapser
Collapser scoped to HystrixObservableCollapser.Scope.REQUEST and default configuration.
HystrixObservableCollapser(HystrixObservableCollapser.Setter) - Constructor for class com.netflix.hystrix.HystrixObservableCollapser
Construct a HystrixObservableCollapser with defined HystrixObservableCollapser.Setter that allows injecting property and strategy overrides and other optional arguments.
HystrixObservableCollapser.Scope - Enum in com.netflix.hystrix
The scope of request collapsing.
HystrixObservableCollapser.Setter - Class in com.netflix.hystrix
Fluent interface for arguments to the HystrixObservableCollapser constructor.
HystrixObservableCommand<R> - Class in com.netflix.hystrix
Used to wrap code that will execute potentially risky functionality (typically meaning a service call over the network) with fault and latency tolerance, statistics and performance metrics capture, circuit breaker and bulkhead functionality.
HystrixObservableCommand(HystrixCommandGroupKey) - Constructor for class com.netflix.hystrix.HystrixObservableCommand
HystrixObservableCommand(HystrixObservableCommand.Setter) - Constructor for class com.netflix.hystrix.HystrixObservableCommand
Construct a HystrixObservableCommand with defined HystrixObservableCommand.Setter that allows injecting property and strategy overrides and other optional arguments.
HystrixObservableCommand.Setter - Class in com.netflix.hystrix
Fluent interface for arguments to the HystrixObservableCommand constructor.
HystrixPlugins - Class in com.netflix.hystrix.strategy
Registry for plugin implementations that allows global override and handles the retrieval of correct implementation based on order of precedence: plugin registered globally via register methods in this class plugin registered and retrieved using the resolved HystrixDynamicProperties (usually Archaius, see get methods for property names) plugin registered and retrieved using the JDK ServiceLoader default implementation The exception to the above order is the HystrixDynamicProperties implementation which is only loaded through System.properties or the ServiceLoader (see the getter for more details).
HystrixPropertiesChainedArchaiusProperty - Class in com.netflix.hystrix.strategy.properties
Chained property allowing a chain of defaults using Archaius (https://github.com/Netflix/archaius) properties which is used by the default properties implementations.
HystrixPropertiesChainedArchaiusProperty() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty
 
HystrixPropertiesChainedArchaiusProperty.BooleanProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.ChainLink<T> - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.DynamicBooleanProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.DynamicLongProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.IntegerProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedArchaiusProperty.StringProperty - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesChainedProperty - Class in com.netflix.hystrix.strategy.properties
Chained property allowing a chain of defaults properties which is uses the properties plugin.
HystrixPropertiesChainedProperty() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedProperty
 
HystrixPropertiesChainedProperty.ChainBuilder<T> - Class in com.netflix.hystrix.strategy.properties
 
HystrixPropertiesCollapserDefault - Class in com.netflix.hystrix.strategy.properties
Default implementation of HystrixCollapserProperties using Archaius (https://github.com/Netflix/archaius)
HystrixPropertiesCollapserDefault(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesCollapserDefault
 
HystrixPropertiesCommandDefault - Class in com.netflix.hystrix.strategy.properties
Default implementation of HystrixCommandProperties using Archaius (https://github.com/Netflix/archaius)
HystrixPropertiesCommandDefault(HystrixCommandKey, HystrixCommandProperties.Setter) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesCommandDefault
 
HystrixPropertiesFactory - Class in com.netflix.hystrix.strategy.properties
Factory for retrieving properties implementations.
HystrixPropertiesFactory() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
 
HystrixPropertiesStrategy - Class in com.netflix.hystrix.strategy.properties
Abstract class with default implementations of factory methods for properties used by various components of Hystrix.
HystrixPropertiesStrategy() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
 
HystrixPropertiesStrategyDefault - Class in com.netflix.hystrix.strategy.properties
Default implementation of HystrixPropertiesStrategy.
HystrixPropertiesThreadPoolDefault - Class in com.netflix.hystrix.strategy.properties
Default implementation of HystrixThreadPoolProperties using Archaius (https://github.com/Netflix/archaius)
HystrixPropertiesThreadPoolDefault(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesThreadPoolDefault
 
HystrixPropertiesTimerThreadPoolDefault - Class in com.netflix.hystrix.strategy.properties
Default implementation of HystrixTimerThreadPoolProperties using Archaius (https://github.com/Netflix/archaius)
HystrixPropertiesTimerThreadPoolDefault() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesTimerThreadPoolDefault
 
HystrixProperty<T> - Interface in com.netflix.hystrix.strategy.properties
Generic interface to represent a property value so Hystrix can consume properties without being tied to any particular backing implementation.
HystrixProperty.Factory - Class in com.netflix.hystrix.strategy.properties
Helper methods for wrapping static values and dynamic Archaius (https://github.com/Netflix/archaius) properties in the HystrixProperty interface.
HystrixRequestCache - Class in com.netflix.hystrix
Cache that is scoped to the current request as managed by HystrixRequestVariableDefault.
HystrixRequestContext - Class in com.netflix.hystrix.strategy.concurrency
Contains the state and manages the lifecycle of HystrixRequestVariableDefault objects that provide request scoped (rather than only thread scoped) variables so that multiple threads within a single request can share state: request scoped caching as in HystrixRequestCache for de-duping HystrixCommand executions request scoped log of all events as in HystrixRequestLog automated batching of HystrixCommand executions within the scope of a request as in HystrixCollapser
HystrixRequestLog - Class in com.netflix.hystrix
Log of HystrixCommand executions and events during the current request.
HystrixRequestVariable<T> - Interface in com.netflix.hystrix.strategy.concurrency
Interface for a variable similar to ThreadLocal but scoped at the user request level.
HystrixRequestVariableDefault<T> - Class in com.netflix.hystrix.strategy.concurrency
Default implementation of HystrixRequestVariable.
HystrixRequestVariableDefault() - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
Creates a new HystrixRequestVariable that will exist across all threads within a HystrixRequestContext
HystrixRequestVariableHolder<T> - Class in com.netflix.hystrix.strategy.concurrency
Factory that encompasses functionality of HystrixRequestVariable for internal Hystrix code.
HystrixRequestVariableHolder(HystrixRequestVariableLifecycle<T>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableHolder
 
HystrixRequestVariableLifecycle<T> - Interface in com.netflix.hystrix.strategy.concurrency
Interface for lifecycle methods that are then executed by an implementation of HystrixRequestVariable.
HystrixRuntimeException - Exception in com.netflix.hystrix.exception
RuntimeException that is thrown when a HystrixCommand fails and does not have a fallback.
HystrixRuntimeException(HystrixRuntimeException.FailureType, Class<? extends HystrixInvokable>, String, Exception, Throwable) - Constructor for exception com.netflix.hystrix.exception.HystrixRuntimeException
 
HystrixRuntimeException(HystrixRuntimeException.FailureType, Class<? extends HystrixInvokable>, String, Throwable, Throwable) - Constructor for exception com.netflix.hystrix.exception.HystrixRuntimeException
 
HystrixRuntimeException.FailureType - Enum in com.netflix.hystrix.exception
 
HystrixThreadPool - Interface in com.netflix.hystrix
ThreadPool used to executed HystrixCommand.run() on separate threads when configured to do so with HystrixCommandProperties.executionIsolationStrategy().
HystrixThreadPool.Factory - Class in com.netflix.hystrix
 
HystrixThreadPool.HystrixThreadPoolDefault - Class in com.netflix.hystrix
 
HystrixThreadPoolDefault(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Constructor for class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
HystrixThreadPoolKey - Interface in com.netflix.hystrix
A key to represent a HystrixThreadPool for monitoring, metrics publishing, caching and other such uses.
HystrixThreadPoolKey.Factory - Class in com.netflix.hystrix
 
HystrixThreadPoolMetrics - Class in com.netflix.hystrix
Used by HystrixThreadPool to record metrics.
HystrixThreadPoolProperties - Class in com.netflix.hystrix
Properties for instances of HystrixThreadPool.
HystrixThreadPoolProperties(HystrixThreadPoolKey) - Constructor for class com.netflix.hystrix.HystrixThreadPoolProperties
 
HystrixThreadPoolProperties(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Constructor for class com.netflix.hystrix.HystrixThreadPoolProperties
 
HystrixThreadPoolProperties(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter, String) - Constructor for class com.netflix.hystrix.HystrixThreadPoolProperties
 
HystrixThreadPoolProperties.Setter - Class in com.netflix.hystrix
Fluent interface that allows chained setting of properties that can be passed into a HystrixThreadPool via a HystrixCommand constructor to inject instance specific property overrides.
HystrixTimeoutException - Exception in com.netflix.hystrix.exception
An exception representing an error where the provided execution method took longer than the Hystrix timeout.
HystrixTimeoutException() - Constructor for exception com.netflix.hystrix.exception.HystrixTimeoutException
 
HystrixTimerThreadPoolProperties - Class in com.netflix.hystrix
Properties for Hystrix timer thread pool.
HystrixTimerThreadPoolProperties() - Constructor for class com.netflix.hystrix.HystrixTimerThreadPoolProperties
 
HystrixTimerThreadPoolProperties(HystrixTimerThreadPoolProperties.Setter) - Constructor for class com.netflix.hystrix.HystrixTimerThreadPoolProperties
 
HystrixTimerThreadPoolProperties.Setter - Class in com.netflix.hystrix
Fluent interface that allows chained setting of properties.

I

initialize() - Method in interface com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCollapser
 
initialize() - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCollapserDefault
 
initialize() - Method in interface com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCommand
 
initialize() - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCommandDefault
 
initialize() - Method in interface com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherThreadPool
 
initialize() - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherThreadPoolDefault
 
initializeContext() - Static method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestContext
Call this at the beginning of each request (from parent thread) to initialize the underlying context so that HystrixRequestVariableDefault can be used on any children threads and be accessible from the parent thread.
initialValue() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
Delegates to the wrapped HystrixRequestVariableLifecycle
initialValue() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
Computes the initial value of the HystrixRequestVariable in a request.
initialValue() - Method in interface com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableLifecycle
Invoked when HystrixRequestVariable.get() is first called.
IntegerProperty(HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
IntegerProperty(HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty, HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
IntegerProperty(HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty, HystrixPropertiesChainedArchaiusProperty.IntegerProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
IntegerProperty(String, HystrixPropertiesChainedArchaiusProperty.DynamicIntegerProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
IntegerProperty(String, HystrixPropertiesChainedArchaiusProperty.IntegerProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
isCircuitBreakerOpen() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isCurrentThreadInitialized() - Static method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestContext
 
isExecutedInThread() - Method in class com.netflix.hystrix.ExecutionResult
 
isExecutedInThread() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isExecutionComplete() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isFailedExecution() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isOpen() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.HystrixCircuitBreakerImpl
 
isOpen() - Method in interface com.netflix.hystrix.HystrixCircuitBreaker
Whether the circuit is currently open (tripped).
isOpen() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.NoOpCircuitBreaker
 
isQueueSpaceAvailable() - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
Whether the threadpool queue has space available according to the queueSizeRejectionThreshold settings.
isQueueSpaceAvailable() - Method in interface com.netflix.hystrix.HystrixThreadPool
Whether the queue will allow adding an item to it.
isResponseFromCache() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isResponseFromFallback() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isResponseRejected() - Method in class com.netflix.hystrix.ExecutionResult
 
isResponseRejected() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isResponseSemaphoreRejected() - Method in class com.netflix.hystrix.ExecutionResult
 
isResponseSemaphoreRejected() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isResponseShortCircuited() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isResponseThreadPoolRejected() - Method in class com.netflix.hystrix.ExecutionResult
 
isResponseThreadPoolRejected() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isResponseTimedOut() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isSuccessfulExecution() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
 
isTerminal() - Method in enum com.netflix.hystrix.HystrixEventType
 
isValueAcceptable() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.BooleanProperty
 
isValueAcceptable() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 
isValueAcceptable() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.IntegerProperty
 
isValueAcceptable() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 

K

keepAliveTimeMinutes() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties
Keep-alive time in minutes that gets passed to ThreadPoolExecutor.setKeepAliveTime(long, TimeUnit)

M

mapResponseToRequests(BatchReturnType, Collection<HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) - Method in class com.netflix.hystrix.HystrixCollapser
Executed after the HystrixCommand<BatchReturnType> command created by HystrixCollapser.createCommand(java.util.Collection<com.netflix.hystrix.HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) finishes processing (unless it fails) for mapping the <BatchReturnType> to the list of CollapsedRequest<ResponseType, RequestArgumentType> objects.
markBatch(int) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
markCollapsed(HystrixCollapserKey, int) - Method in class com.netflix.hystrix.ExecutionResult
 
markCommandExecution(HystrixCommandKey, HystrixCommandProperties.ExecutionIsolationStrategy, int, List<HystrixEventType>) - Method in class com.netflix.hystrix.strategy.eventnotifier.HystrixEventNotifier
Called after a command is executed using thread isolation.
markEvent(HystrixEventType, HystrixCommandKey) - Method in class com.netflix.hystrix.strategy.eventnotifier.HystrixEventNotifier
Called for every event fired.
markRequestBatched() - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
markResponseFromCache() - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
markShards(int) - Method in class com.netflix.hystrix.HystrixCollapserMetrics
 
markSuccess() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.HystrixCircuitBreakerImpl
 
markSuccess() - Method in interface com.netflix.hystrix.HystrixCircuitBreaker
Invoked on successful executions from HystrixCommand as part of feedback mechanism when in a half-open state.
markSuccess() - Method in class com.netflix.hystrix.HystrixCircuitBreaker.NoOpCircuitBreaker
 
markThreadCompletion() - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
markThreadCompletion() - Method in interface com.netflix.hystrix.HystrixThreadPool
Mark when a thread completes executing a command.
markThreadCompletion() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Invoked each time a thread completes.
markThreadExecution() - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
markThreadExecution() - Method in interface com.netflix.hystrix.HystrixThreadPool
Mark when a thread begins executing a command.
markThreadExecution() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Invoked each time a thread is executed.
markThreadRejection() - Method in class com.netflix.hystrix.HystrixThreadPool.HystrixThreadPoolDefault
 
markThreadRejection() - Method in interface com.netflix.hystrix.HystrixThreadPool
Mark when a command gets rejected from the threadpool
markThreadRejection() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
Invoked each time a command is rejected from the thread-pool
markUserThreadCompletion(long) - Method in class com.netflix.hystrix.ExecutionResult
 
maxQueueSize() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties
Max queue size that gets passed to BlockingQueue in HystrixConcurrencyStrategy.getBlockingQueue(int) This should only affect the instantiation of a threadpool - it is not eliglible to change a queue size on the fly.
maxRequestsInBatch() - Method in class com.netflix.hystrix.HystrixCollapserProperties
The maximum number of requests allowed in a batch before triggering a batch execution.
metricsHealthSnapshotIntervalInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties
Time in milliseconds to wait between allowing health snapshots to be taken that calculate success and error percentages and affect HystrixCircuitBreaker.isOpen() status.
metricsRollingPercentileBucketSize() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Maximum number of values stored in each bucket of the rolling percentile.
metricsRollingPercentileBucketSize() - Method in class com.netflix.hystrix.HystrixCommandProperties
Maximum number of values stored in each bucket of the rolling percentile.
metricsRollingPercentileEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Whether percentile metrics should be captured using HystrixRollingPercentile inside HystrixCollapserMetrics.
metricsRollingPercentileEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether percentile metrics should be captured using HystrixRollingPercentile inside HystrixCommandMetrics.
metricsRollingPercentileWindow() - Method in class com.netflix.hystrix.HystrixCommandProperties
metricsRollingPercentileWindowBuckets() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Number of buckets the rolling percentile window is broken into.
metricsRollingPercentileWindowBuckets() - Method in class com.netflix.hystrix.HystrixCommandProperties
Number of buckets the rolling percentile window is broken into.
metricsRollingPercentileWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Duration of percentile rolling window in milliseconds.
metricsRollingPercentileWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties
Duration of percentile rolling window in milliseconds.
metricsRollingStatisticalWindowBuckets() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Number of buckets the rolling statistical window is broken into.
metricsRollingStatisticalWindowBuckets() - Method in class com.netflix.hystrix.HystrixCommandProperties
Number of buckets the rolling statistical window is broken into.
metricsRollingStatisticalWindowBuckets() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties
Number of buckets the rolling statistical window is broken into.
metricsRollingStatisticalWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Duration of statistical rolling window in milliseconds.
metricsRollingStatisticalWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties
Duration of statistical rolling window in milliseconds.
metricsRollingStatisticalWindowInMilliseconds() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties
Duration of statistical rolling window in milliseconds.

N

name() - Method in interface com.netflix.hystrix.HystrixCollapserKey
The word 'name' is used instead of 'key' so that Enums can implement this interface and it work natively.
name() - Method in interface com.netflix.hystrix.HystrixCommandGroupKey
The word 'name' is used instead of 'key' so that Enums can implement this interface and it work natively.
name() - Method in interface com.netflix.hystrix.HystrixCommandKey
The word 'name' is used instead of 'key' so that Enums can implement this interface and it work natively.
name() - Method in interface com.netflix.hystrix.HystrixThreadPoolKey
The 'key' used as the name for a thread-pool.
NoOpCircuitBreaker() - Constructor for class com.netflix.hystrix.HystrixCircuitBreaker.NoOpCircuitBreaker
 
nullProperty() - Static method in class com.netflix.hystrix.strategy.properties.HystrixProperty.Factory
 

O

observe() - Method in class com.netflix.hystrix.HystrixCollapser
Used for asynchronous execution with a callback by subscribing to the Observable.
observe() - Method in interface com.netflix.hystrix.HystrixExecutable
Used for asynchronous execution of command with a callback by subscribing to the Observable.
observe() - Method in interface com.netflix.hystrix.HystrixObservable
Used for asynchronous execution of command with a callback by subscribing to the Observable.
observe() - Method in class com.netflix.hystrix.HystrixObservableCollapser
Used for asynchronous execution with a callback by subscribing to the Observable.
onCacheHit(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the command response is found in the HystrixRequestCache.
onComplete(HystrixCommand<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onComplete(HystrixInvokable<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onEmit(HystrixInvokable<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when HystrixInvokable emits a value.
onError(HystrixCommand<T>, HystrixRuntimeException.FailureType, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onError(HystrixInvokable<T>, HystrixRuntimeException.FailureType, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when HystrixInvokable fails with an Exception.
onExecutionEmit(HystrixInvokable<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the user-defined execution method in HystrixInvokable emits a value.
onExecutionError(HystrixInvokable<T>, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the user-defined execution method in HystrixInvokable fails with an Exception.
onExecutionStart(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the user-defined execution method in HystrixInvokable starts.
onExecutionSuccess(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the user-defined execution method in HystrixInvokable completes successfully.
onFallbackEmit(HystrixInvokable<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the fallback method in HystrixInvokable emits a value.
onFallbackError(HystrixCommand<T>, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onFallbackError(HystrixInvokable<T>, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the fallback method in HystrixInvokable fails with an Exception.
onFallbackStart(HystrixCommand<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onFallbackStart(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the fallback method in HystrixInvokable starts.
onFallbackSuccess(HystrixCommand<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onFallbackSuccess(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when the user-defined execution method in HystrixInvokable completes successfully.
onFallbackSuccess(HystrixInvokable<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onMissingResponse(HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>) - Method in class com.netflix.hystrix.HystrixObservableCollapser
Invoked if a HystrixCollapser.CollapsedRequest in the batch does not have a response set on it.
onRunError(HystrixCommand<T>, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onRunError(HystrixInvokable<T>, Exception) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onRunStart(HystrixCommand<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onRunStart(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onRunSuccess(HystrixCommand<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onRunSuccess(HystrixInvokable<T>, T) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onStart(HystrixCommand<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onStart(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked before HystrixInvokable begins executing.
onSuccess(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked when HystrixInvokable finishes a successful execution.
onThreadComplete(HystrixCommand<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onThreadComplete(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked at completion of thread execution when HystrixCommand is executed using HystrixCommandProperties.ExecutionIsolationStrategy.THREAD.
onThreadStart(HystrixCommand<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Deprecated.
onThreadStart(HystrixInvokable<T>) - Method in class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
Invoked at start of thread execution when HystrixCommand is executed using HystrixCommandProperties.ExecutionIsolationStrategy.THREAD.
originalSubscription - Variable in class com.netflix.hystrix.HystrixCachedObservable
 

P

plus(long[]) - Method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
 

Q

queue() - Method in class com.netflix.hystrix.HystrixCollapser
Used for asynchronous execution.
queue() - Method in class com.netflix.hystrix.HystrixCommand
Used for asynchronous execution of command.
queue() - Method in interface com.netflix.hystrix.HystrixExecutable
Used for asynchronous execution of command.
queueSizeRejectionThreshold() - Method in class com.netflix.hystrix.HystrixThreadPoolProperties
Queue size rejection threshold is an artificial "max" size at which rejections will occur even if HystrixThreadPoolProperties.maxQueueSize has not been reached.

R

registerCommandExecutionHook(HystrixCommandExecutionHook) - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Register a HystrixCommandExecutionHook implementation as a global override of any injected or default implementations.
registerConcurrencyStrategy(HystrixConcurrencyStrategy) - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Register a HystrixConcurrencyStrategy implementation as a global override of any injected or default implementations.
registerEventNotifier(HystrixEventNotifier) - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Register a HystrixEventNotifier implementation as a global override of any injected or default implementations.
registerMetricsPublisher(HystrixMetricsPublisher) - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Register a HystrixMetricsPublisher implementation as a global override of any injected or default implementations.
registerPropertiesStrategy(HystrixPropertiesStrategy) - Method in class com.netflix.hystrix.strategy.HystrixPlugins
Register a HystrixPropertiesStrategy implementation as a global override of any injected or default implementations.
remove() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
Removes the value of the HystrixRequestVariable from the current request.
requestCacheEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Whether request caching is enabled for HystrixCollapser.execute() and HystrixCollapser.queue() invocations.
requestCacheEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether AbstractCommand.getCacheKey() should be used with HystrixRequestCache to provide de-duplication functionality via request-scoped caching.
requestCachingEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties
Deprecated.
requestLogEnabled() - Method in class com.netflix.hystrix.HystrixCommandProperties
Whether HystrixCommand execution and events should be logged to HystrixRequestLog.
reset() - Static method in class com.netflix.hystrix.Hystrix
Reset state and release resources in use (such as thread-pools).
reset() - Static method in class com.netflix.hystrix.strategy.HystrixPlugins
Reset all of the HystrixPlugins to null.
reset() - Static method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherFactory
Resets the SINGLETON object.
reset() - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
Clears all the defaults in the static property cache.
reset(long, TimeUnit) - Static method in class com.netflix.hystrix.Hystrix
Reset state and release resources in use (such as threadpools) and wait for completion.
resumeWithFallback() - Method in class com.netflix.hystrix.HystrixObservableCommand
If AbstractCommand.observe() or AbstractCommand.toObservable() fails in any way then this method will be invoked to provide an opportunity to return a fallback response.
run() - Method in class com.netflix.hystrix.HystrixCommand
Implement this method with code to be executed when HystrixCommand.execute() or HystrixCommand.queue() are invoked.
run() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixContextRunnable
 

S

set(T) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
Sets the value of the HystrixRequestVariable for the current request context.
setComplete() - Method in interface com.netflix.hystrix.HystrixCollapser.CollapsedRequest
When set, any Observer will have an OnCompleted emitted.
setContextOnCurrentThread(HystrixRequestContext) - Static method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestContext
 
setException(Exception) - Method in class com.netflix.hystrix.ExecutionResult
 
setException(Exception) - Method in interface com.netflix.hystrix.HystrixCollapser.CollapsedRequest
When set, any Observer will be OnErrored this exception
setExecutedInThread() - Method in class com.netflix.hystrix.ExecutionResult
 
setExecutionException(Exception) - Method in class com.netflix.hystrix.ExecutionResult
 
setExecutionLatency(int) - Method in class com.netflix.hystrix.ExecutionResult
 
setExecutionOccurred() - Method in class com.netflix.hystrix.ExecutionResult
 
setInvocationStartTime(long) - Method in class com.netflix.hystrix.ExecutionResult
 
setNotExecutedInThread() - Method in class com.netflix.hystrix.ExecutionResult
 
setResponse(ResponseType) - Method in interface com.netflix.hystrix.HystrixCollapser.CollapsedRequest
This corresponds in a OnNext(Response); OnCompleted pair of emissions.
Setter(HystrixCommandGroupKey) - Constructor for class com.netflix.hystrix.HystrixCommand.Setter
Setter factory method containing required values.
Setter(HystrixCommandGroupKey) - Constructor for class com.netflix.hystrix.HystrixObservableCommand.Setter
Setter factory method containing required values.
Setter() - Static method in class com.netflix.hystrix.HystrixCollapserProperties
Factory method to retrieve the default Setter.
Setter() - Static method in class com.netflix.hystrix.HystrixCommandProperties
Factory method to retrieve the default Setter.
Setter() - Static method in class com.netflix.hystrix.HystrixThreadPoolProperties
Factory method to retrieve the default Setter.
Setter() - Static method in class com.netflix.hystrix.HystrixTimerThreadPoolProperties
Factory method to retrieve the default Setter.
shardRequests(Collection<HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) - Method in class com.netflix.hystrix.HystrixCollapser
Override to split (shard) a batch of requests into multiple batches that will each call createCommand separately.
shardRequests(Collection<HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) - Method in class com.netflix.hystrix.HystrixObservableCollapser
Override to split (shard) a batch of requests into multiple batches that will each call createCommand separately.
shouldOutputOnNextEvents() - Method in class com.netflix.hystrix.HystrixObservableCommand
Overridden to true so that all onNext emissions are captured
shutdown() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestContext
Shutdown HystrixRequestVariableDefault objects in this context.
shutdown(T) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
Delegates to the wrapped HystrixRequestVariableLifecycle
shutdown(T) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
Provide life-cycle hook for a HystrixRequestVariable implementation to perform cleanup before the HystrixRequestVariable is removed from the current thread.
shutdown(T) - Method in interface com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableLifecycle
Invoked when request scope is shutdown to allow for cleanup.
StringProperty(HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 
StringProperty(HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty, HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 
StringProperty(HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty, HystrixPropertiesChainedArchaiusProperty.StringProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 
StringProperty(String, HystrixPropertiesChainedArchaiusProperty.DynamicStringProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 
StringProperty(String, HystrixPropertiesChainedArchaiusProperty.StringProperty) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.StringProperty
 

T

threadPoolKey - Variable in class com.netflix.hystrix.HystrixCommand.Setter
 
threadPoolKey - Variable in class com.netflix.hystrix.HystrixObservableCommand.Setter
 
threadPoolPropertiesDefaults - Variable in class com.netflix.hystrix.HystrixCommand.Setter
 
threadPoolPropertiesDefaults - Variable in class com.netflix.hystrix.HystrixObservableCommand.Setter
 
timerDelayInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties
The number of milliseconds between batch executions (unless HystrixCollapserProperties.maxRequestsInBatch is hit which will cause a batch to execute early.
toObservable() - Method in class com.netflix.hystrix.HystrixCachedObservable
 
toObservable() - Method in class com.netflix.hystrix.HystrixCollapser
A lazy Observable that will execute when subscribed to.
toObservable() - Method in interface com.netflix.hystrix.HystrixObservable
Used for asynchronous execution of command with a callback by subscribing to the Observable.
toObservable() - Method in class com.netflix.hystrix.HystrixObservableCollapser
A lazy Observable that will execute when subscribed to.
toObservable(Scheduler) - Method in class com.netflix.hystrix.HystrixCollapser
A lazy Observable that will execute when subscribed to.
toObservable(Scheduler) - Method in class com.netflix.hystrix.HystrixObservableCollapser
A lazy Observable that will execute when subscribed to.
toObservableWithStateCopiedInto(AbstractCommand<R>) - Method in class com.netflix.hystrix.HystrixCommandResponseFromCache
 
toString() - Method in class com.netflix.hystrix.ExecutionResult.EventCounts
 
toString() - Method in class com.netflix.hystrix.ExecutionResult
 
toString() - Method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
 
toString() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesChainedArchaiusProperty.ChainLink
 

U

unsubscribe() - Method in class com.netflix.hystrix.HystrixCachedObservable
 
Util() - Constructor for class com.netflix.hystrix.strategy.properties.HystrixDynamicProperties.Util
 

V

valueOf(String) - Static method in enum com.netflix.hystrix.exception.HystrixRuntimeException.FailureType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.hystrix.HystrixCollapser.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.hystrix.HystrixCommandProperties.ExecutionIsolationStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.hystrix.HystrixEventType.Collapser
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.hystrix.HystrixEventType.ThreadPool
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.hystrix.HystrixEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.hystrix.HystrixObservableCollapser.Scope
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.netflix.hystrix.exception.HystrixRuntimeException.FailureType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.hystrix.HystrixCollapser.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.hystrix.HystrixCommandProperties.ExecutionIsolationStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.hystrix.HystrixEventType.Collapser
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.hystrix.HystrixEventType.ThreadPool
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.hystrix.HystrixEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.hystrix.HystrixObservableCollapser.Scope
Returns an array containing the constants of this enum type, in the order they are declared.

W

withCircuitBreakerEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withCircuitBreakerErrorThresholdPercentage(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withCircuitBreakerForceClosed(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withCircuitBreakerForceOpen(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withCircuitBreakerRequestVolumeThreshold(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withCircuitBreakerSleepWindowInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withCollapserKey(HystrixCollapserKey) - Static method in class com.netflix.hystrix.HystrixCollapser.Setter
Setter factory method containing required values.
withCollapserKey(HystrixCollapserKey) - Static method in class com.netflix.hystrix.HystrixObservableCollapser.Setter
Setter factory method containing required values.
withCollapsingEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
Deprecated.
withCoreSize(int) - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
withCoreSize(int) - Method in class com.netflix.hystrix.HystrixTimerThreadPoolProperties.Setter
 
withExecutionIsolationSemaphoreMaxConcurrentRequests(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withExecutionIsolationStrategy(HystrixCommandProperties.ExecutionIsolationStrategy) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withExecutionIsolationThreadInterruptOnTimeout(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withExecutionIsolationThreadTimeoutInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
Deprecated.
As of 1.4.0, replaced with HystrixCommandProperties.Setter.withExecutionTimeoutInMilliseconds(int). Timeouts are no longer applied only to thread-isolated commands, so a thread-specific name is misleading
withExecutionTimeoutEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withExecutionTimeoutInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withFallbackEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withFallbackIsolationSemaphoreMaxConcurrentRequests(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withGroupKey(HystrixCommandGroupKey) - Static method in class com.netflix.hystrix.HystrixCommand.Setter
Setter factory method with required values.
withGroupKey(HystrixCommandGroupKey) - Static method in class com.netflix.hystrix.HystrixObservableCommand.Setter
Setter factory method with required values.
withKeepAliveTimeMinutes(int) - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
withMaxQueueSize(int) - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
withMaxRequestsInBatch(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsHealthSnapshotIntervalInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingPercentileBucketSize(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsRollingPercentileBucketSize(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingPercentileEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsRollingPercentileEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingPercentileWindowBuckets(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsRollingPercentileWindowBuckets(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingPercentileWindowInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsRollingPercentileWindowInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingStatisticalWindowBuckets(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsRollingStatisticalWindowBuckets(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingStatisticalWindowBuckets(int) - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
withMetricsRollingStatisticalWindowInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withMetricsRollingStatisticalWindowInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withMetricsRollingStatisticalWindowInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
withQueueSizeRejectionThreshold(int) - Method in class com.netflix.hystrix.HystrixThreadPoolProperties.Setter
 
withRequestCacheEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
withRequestCacheEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withRequestLogEnabled(boolean) - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
 
withTimerDelayInMilliseconds(int) - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
 
wrapCallable(Callable<T>) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixConcurrencyStrategy
Provides an opportunity to wrap/decorate a Callable<T> before execution.
A B C D E F G H I K M N O P Q R S T U V W 
Skip navigation links