- get() - Method in class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
-
- 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
-
- 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
-
- getCollapserKey() - Method in class com.netflix.hystrix.HystrixObservableCollapser
-
- getCollapserProperties(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
-
- getCollapserProperties(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- getCollapserPropertiesCacheKey(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- getCollapsingEnabled() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
-
Deprecated.
- getCommandCount() - Static method in class com.netflix.hystrix.HystrixCounters
-
- getCommandExecutionHook() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
-
- getCommandGroup() - Method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getCommandGroup() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
-
- getCommandKey() - Method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getCommandKey() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
-
- getCommandProperties(HystrixCommandKey, HystrixCommandProperties.Setter) - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
-
- getCommandProperties(HystrixCommandKey, HystrixCommandProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- getCommandPropertiesCacheKey(HystrixCommandKey, HystrixCommandProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- 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
-
- 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
-
- 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
-
- getCurrentRequest(HystrixConcurrencyStrategy) - Static method in class com.netflix.hystrix.HystrixRequestLog
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- getInstance(HystrixCollapserKey, HystrixConcurrencyStrategy) - Static method in class com.netflix.hystrix.HystrixRequestCache
-
- getInstance(HystrixCommandKey) - Static method in class com.netflix.hystrix.HystrixCircuitBreaker.Factory
-
- getInstance(HystrixCommandKey) - Static method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getInstance(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandProperties) - Static method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getInstance(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandProperties, HystrixCommandMetrics) - Static method in class com.netflix.hystrix.HystrixCircuitBreaker.Factory
-
- getInstance(HystrixCommandKey, HystrixCommandGroupKey, HystrixThreadPoolKey, HystrixCommandProperties) - Static method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getInstance(HystrixCommandKey, HystrixConcurrencyStrategy) - Static method in class com.netflix.hystrix.HystrixRequestCache
-
- getInstance(HystrixThreadPoolKey) - Static method in class com.netflix.hystrix.HystrixThreadPoolMetrics
-
- getInstance(HystrixThreadPoolKey, ThreadPoolExecutor, HystrixThreadPoolProperties) - Static method in class com.netflix.hystrix.HystrixThreadPoolMetrics
-
- getInstances() - Static method in class com.netflix.hystrix.HystrixCollapserMetrics
-
- getInstances() - Static method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getInstances() - Static method in class com.netflix.hystrix.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
-
- getMetrics() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
-
- getMetrics() - Method in class com.netflix.hystrix.HystrixObservableCollapser
-
- getMetricsHealthSnapshotIntervalInMilliseconds() - Method in class com.netflix.hystrix.HystrixCommandProperties.Setter
-
- getMetricsPublisher() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
-
- getMetricsPublisherForCollapser(HystrixCollapserKey, HystrixCollapserMetrics, HystrixCollapserProperties) - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
-
- getMetricsPublisherForCommand(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandMetrics, HystrixCircuitBreaker, HystrixCommandProperties) - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
-
- getMetricsPublisherForThreadPool(HystrixThreadPoolKey, HystrixThreadPoolMetrics, HystrixThreadPoolProperties) - Method in class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisher
-
- 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
-
- getProperties() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
-
- getProperties() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
-
- getPropertiesStrategy() - Method in class com.netflix.hystrix.strategy.HystrixPlugins
-
- 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
-
- getRequestArgument() - Method in class com.netflix.hystrix.HystrixObservableCollapser
-
- 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
-
- getThreadPoolKey() - Method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getThreadPoolKey() - Method in interface com.netflix.hystrix.HystrixInvokableInfo
-
- getThreadPoolKey() - Method in class com.netflix.hystrix.HystrixThreadPoolMetrics
-
- getThreadPoolProperties(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Static method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesFactory
-
- getThreadPoolProperties(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- getThreadPoolPropertiesCacheKey(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- getTimerDelayInMilliseconds() - Method in class com.netflix.hystrix.HystrixCollapserProperties.Setter
-
- getTimerThreadPoolProperties() - Method in class com.netflix.hystrix.strategy.properties.HystrixPropertiesStrategy
-
- getTotalRequests() - Method in class com.netflix.hystrix.HystrixCommandMetrics.HealthCounts
-
- getTotalTimeMean() - Method in class com.netflix.hystrix.HystrixCommandMetrics
-
- getTotalTimePercentile(double) - Method in class com.netflix.hystrix.HystrixCommandMetrics
-
- 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
-
- 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
-
- 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
-
- HystrixCollapser(HystrixCollapser.Setter) - Constructor for class com.netflix.hystrix.HystrixCollapser
-
- HystrixCollapser(HystrixCollapserKey) - Constructor for class com.netflix.hystrix.HystrixCollapser
-
- 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
-
- 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
-
- HystrixCollapserProperties - Class in com.netflix.hystrix
-
- 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
-
- HystrixCommand(HystrixCommandGroupKey) - Constructor for class com.netflix.hystrix.HystrixCommand
-
- HystrixCommand(HystrixCommandGroupKey, int) - Constructor for class com.netflix.hystrix.HystrixCommand
-
- HystrixCommand(HystrixCommandGroupKey, HystrixThreadPoolKey) - Constructor for class com.netflix.hystrix.HystrixCommand
-
- HystrixCommand(HystrixCommandGroupKey, HystrixThreadPoolKey, int) - Constructor for class com.netflix.hystrix.HystrixCommand
-
- HystrixCommand.Setter - Class in com.netflix.hystrix
-
- HystrixCommandExecutionHook - Class in com.netflix.hystrix.strategy.executionhook
-
- HystrixCommandExecutionHook() - Constructor for class com.netflix.hystrix.strategy.executionhook.HystrixCommandExecutionHook
-
- HystrixCommandExecutionHookDefault - Class in com.netflix.hystrix.strategy.executionhook
-
- HystrixCommandGroupKey - Interface in com.netflix.hystrix
-
- 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
-
- HystrixCommandMetrics.HealthCounts - Class in com.netflix.hystrix
-
Number of requests during rolling window.
- HystrixCommandProperties - Class in com.netflix.hystrix
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- HystrixLifecycleForwardingRequestVariable(HystrixRequestVariableLifecycle<T>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
-
- 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
-
- HystrixMetricsPublisherCollapserDefault - Class in com.netflix.hystrix.strategy.metrics
-
- HystrixMetricsPublisherCollapserDefault(HystrixCollapserKey, HystrixCollapserMetrics, HystrixCollapserProperties) - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCollapserDefault
-
- HystrixMetricsPublisherCommand - Interface in com.netflix.hystrix.strategy.metrics
-
- HystrixMetricsPublisherCommandDefault - Class in com.netflix.hystrix.strategy.metrics
-
- HystrixMetricsPublisherCommandDefault(HystrixCommandKey, HystrixCommandGroupKey, HystrixCommandMetrics, HystrixCircuitBreaker, HystrixCommandProperties) - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherCommandDefault
-
- HystrixMetricsPublisherDefault - Class in com.netflix.hystrix.strategy.metrics
-
- HystrixMetricsPublisherFactory - Class in com.netflix.hystrix.strategy.metrics
-
Factory for retrieving metrics publisher implementations.
- HystrixMetricsPublisherThreadPool - Interface in com.netflix.hystrix.strategy.metrics
-
- HystrixMetricsPublisherThreadPoolDefault - Class in com.netflix.hystrix.strategy.metrics
-
- HystrixMetricsPublisherThreadPoolDefault(HystrixThreadPoolKey, HystrixThreadPoolMetrics, HystrixThreadPoolProperties) - Constructor for class com.netflix.hystrix.strategy.metrics.HystrixMetricsPublisherThreadPoolDefault
-
- HystrixObservable<R> - Interface in com.netflix.hystrix
-
- 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
-
- HystrixObservableCollapser(HystrixCollapserKey) - Constructor for class com.netflix.hystrix.HystrixObservableCollapser
-
- HystrixObservableCollapser(HystrixObservableCollapser.Setter) - Constructor for class com.netflix.hystrix.HystrixObservableCollapser
-
- HystrixObservableCollapser.Scope - Enum in com.netflix.hystrix
-
The scope of request collapsing.
- HystrixObservableCollapser.Setter - Class in com.netflix.hystrix
-
- 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
-
- HystrixObservableCommand.Setter - Class in com.netflix.hystrix
-
- 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
-
- HystrixPropertiesCollapserDefault(HystrixCollapserKey, HystrixCollapserProperties.Setter) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesCollapserDefault
-
- HystrixPropertiesCommandDefault - Class in com.netflix.hystrix.strategy.properties
-
- 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
-
- HystrixPropertiesThreadPoolDefault - Class in com.netflix.hystrix.strategy.properties
-
- HystrixPropertiesThreadPoolDefault(HystrixThreadPoolKey, HystrixThreadPoolProperties.Setter) - Constructor for class com.netflix.hystrix.strategy.properties.HystrixPropertiesThreadPoolDefault
-
- HystrixPropertiesTimerThreadPoolDefault - Class in com.netflix.hystrix.strategy.properties
-
- 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
-
- HystrixRequestContext - Class in com.netflix.hystrix.strategy.concurrency
-
- 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
-
- HystrixRequestVariableDefault() - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableDefault
-
- HystrixRequestVariableHolder<T> - Class in com.netflix.hystrix.strategy.concurrency
-
- HystrixRequestVariableHolder(HystrixRequestVariableLifecycle<T>) - Constructor for class com.netflix.hystrix.strategy.concurrency.HystrixRequestVariableHolder
-
- HystrixRequestVariableLifecycle<T> - Interface in com.netflix.hystrix.strategy.concurrency
-
- 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
-
- 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
-
- HystrixThreadPoolProperties - Class in com.netflix.hystrix
-
- 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.
- mapResponseToRequests(BatchReturnType, Collection<HystrixCollapser.CollapsedRequest<ResponseType, RequestArgumentType>>) - Method in class com.netflix.hystrix.HystrixCollapser
-
- 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
-
- 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
-
- 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.
- 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(T) - Method in class com.netflix.hystrix.strategy.concurrency.HystrixLifecycleForwardingRequestVariable
-
- 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
-
- 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.