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

A

abandon() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
apply(Context) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveContextWrappingFunction
 
AWS - org.springframework.cloud.sleuth.brave.propagation.PropagationType
AWS propagation type.

B

B3 - org.springframework.cloud.sleuth.brave.propagation.PropagationType
B3 propagation type.
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
BraveBaggageManager - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a BaggageManager.
BraveBaggageManager() - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
BraveContextWrappingFunction - Class in org.springframework.cloud.sleuth.brave.bridge
A function that wraps Context with Brave versions.
BraveContextWrappingFunction() - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveContextWrappingFunction
 
BraveCurrentTraceContext - Class in org.springframework.cloud.sleuth.brave.bridge
 
BraveCurrentTraceContext(CurrentTraceContext) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
BraveFinishedSpan - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a FinishedSpan.
BraveFinishedSpan(MutableSpan) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
BraveHttpClientHandler - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a HttpClientHandler.
BraveHttpClientHandler(HttpClientHandler<HttpClientRequest, HttpClientResponse>) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveHttpClientHandler
 
BraveHttpRequestParser - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a HttpRequestParser.
BraveHttpRequestParser(HttpRequestParser) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveHttpRequestParser
 
BraveHttpResponseParser - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a HttpResponseParser.
BraveHttpResponseParser(HttpResponseParser) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveHttpResponseParser
 
BraveHttpServerHandler - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a HttpServerHandler.
BraveHttpServerHandler(HttpServerHandler<HttpServerRequest, HttpServerResponse>) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveHttpServerHandler
 
BravePropagator - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a Propagator.
BravePropagator(Tracing) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BravePropagator
 
BraveSamplerFunction<T> - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a SamplerFunction.
BraveSamplerFunction(SamplerFunction<T>) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveSamplerFunction
 
BraveSpan - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a Span.
BraveSpan(Span) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
BraveSpanCustomizer - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a SpanCustomizer.
BraveSpanCustomizer(SpanCustomizer) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveSpanCustomizer
 
BraveSpanFromContextRetriever - Class in org.springframework.cloud.sleuth.brave.instrument.web
Retrieves Brave specific classes from Reactor context.
BraveSpanFromContextRetriever(CurrentTraceContext, Tracer) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.web.BraveSpanFromContextRetriever
 
BraveTraceContext - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a TraceContext.
BraveTraceContext(TraceContext) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
BraveTracer - Class in org.springframework.cloud.sleuth.brave.bridge
Brave implementation of a Tracer.
BraveTracer(Tracer, BraveBaggageManager) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
Deprecated.
BraveTracer(Tracer, CurrentTraceContext, BraveBaggageManager) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 

C

channelActive(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
channelRegistered(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
ClientResourcesBuilderCustomizer - Interface in org.springframework.cloud.sleuth.brave.instrument.redis
Customizer for ClientResources.Builder.
close() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
close(ChannelHandlerContext, ChannelPromise) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
CompositeHttpSampler - Class in org.springframework.cloud.sleuth.brave.instrument.web
Composite Http Sampler.
CompositeHttpSampler(SamplerFunction<HttpRequest>, SamplerFunction<HttpRequest>) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.web.CompositeHttpSampler
 
CompositePropagationFactorySupplier - Class in org.springframework.cloud.sleuth.brave.bridge
Merges various propagation factories into a composite.
CompositePropagationFactorySupplier(BeanFactory, List<String>, List<PropagationType>) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.CompositePropagationFactorySupplier
 
CompositeSpanHandler - Class in org.springframework.cloud.sleuth.brave.bridge
Merges SpanFilters and SpanReporters into a SpanHandler.
CompositeSpanHandler(List<SpanFilter>, List<SpanReporter>) - Constructor for class org.springframework.cloud.sleuth.brave.bridge.CompositeSpanHandler
 
ConditionalOnMessagingEnabled - Annotation Type in org.springframework.cloud.sleuth.brave.instrument.messaging
Verifies if messaging property was enabled.
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
ConsumerSampler - Annotation Type in org.springframework.cloud.sleuth.brave.instrument.messaging
Annotate a consumer SamplerFunction that should be injected to MessagingTracing.Builder.consumerSampler(SamplerFunction).
context() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
context() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
createBaggage(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
createBaggage(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
createBaggage(String, String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
createBaggage(String, String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
createListenerContainer(JmsListenerEndpoint, JmsListenerContainerFactory<?>) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
currentSpan() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
currentSpanCustomizer() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
currentTraceContext() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
CUSTOM - org.springframework.cloud.sleuth.brave.propagation.PropagationType
Custom propagation type.
customize(MongoClientSettings.Builder) - Method in class org.springframework.cloud.sleuth.brave.instrument.mongodb.TraceMongoClientSettingsBuilderCustomizer
 
customize(ManagedChannelBuilder<?>) - Method in interface org.springframework.cloud.sleuth.brave.instrument.grpc.GrpcManagedChannelBuilderCustomizer
Customizes the channel builder.
customize(ManagedChannelBuilder<?>) - Method in class org.springframework.cloud.sleuth.brave.instrument.grpc.TracingManagedChannelBuilderCustomizer
Add brave's client interceptor to the builder.
customize(ClientResources.Builder) - Method in interface org.springframework.cloud.sleuth.brave.instrument.redis.ClientResourcesBuilderCustomizer
Customizes the builder.
customize(ClientResources.Builder) - Method in class org.springframework.cloud.sleuth.brave.instrument.redis.TraceLettuceClientResourcesBuilderCustomizer
 

D

deregister(ChannelHandlerContext, ChannelPromise) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
destroy() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 

E

end() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
end(TraceContext, MutableSpan, SpanHandler.Cause) - Method in class org.springframework.cloud.sleuth.brave.bridge.CompositeSpanHandler
 
equals(Object) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
equals(Object) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
error(Throwable) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
event(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
event(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpanCustomizer
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
extract(C, Propagator.Getter<C>) - Method in class org.springframework.cloud.sleuth.brave.bridge.BravePropagator
 

F

fields() - Method in class org.springframework.cloud.sleuth.brave.bridge.BravePropagator
 
findSpan(Context) - Method in class org.springframework.cloud.sleuth.brave.instrument.web.BraveSpanFromContextRetriever
 
flush(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
forAddress(String, int) - Method in class org.springframework.cloud.sleuth.brave.instrument.grpc.SpringAwareManagedChannelBuilder
 
forTarget(String) - Method in class org.springframework.cloud.sleuth.brave.instrument.grpc.SpringAwareManagedChannelBuilder
 
fromBrave(MutableSpan) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
fromBrave(TraceContext) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
fromBrave(Span) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 

G

get() - Method in class org.springframework.cloud.sleuth.brave.bridge.CompositePropagationFactorySupplier
 
get() - Method in interface org.springframework.cloud.sleuth.brave.propagation.PropagationFactorySupplier
 
getAllBaggage() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
getAllBaggage() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
getBaggage(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
getBaggage(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
getBaggage(TraceContext, String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveBaggageManager
 
getBaggage(TraceContext, String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
getEndTimestamp() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getError() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getEvents() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getKind() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getListenerContainer(String) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
getListenerContainerIds() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
getListenerContainers() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
getLocalIp() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getName() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getParentId() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getPhase() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
getRemoteIp() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getRemotePort() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getRemoteServiceName() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getSpanId() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getStartTimestamp() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getTags() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
getTraceId() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
GrpcManagedChannelBuilderCustomizer - Interface in org.springframework.cloud.sleuth.brave.instrument.grpc
Callback interface that can be implemented by beans wishing to further customize the ManagedChannelBuilder via the SpringAwareManagedChannelBuilder.

H

handlerAdded(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
handlerAdded(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
handleReceive(HttpClientResponse, Span) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpClientHandler
 
handleReceive(HttpServerRequest) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpServerHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
handleSend(HttpClientRequest) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpClientHandler
 
handleSend(HttpClientRequest, TraceContext) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpClientHandler
 
handleSend(HttpServerResponse, Span) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpServerHandler
 
hashCode() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
hashCode() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 

I

inject(TraceContext, C, Propagator.Setter<C>) - Method in class org.springframework.cloud.sleuth.brave.bridge.BravePropagator
 
inProcessChannelBuilder(String) - Method in class org.springframework.cloud.sleuth.brave.instrument.grpc.SpringAwareManagedChannelBuilder
 
invoke(MethodInvocation) - Method in class org.springframework.cloud.sleuth.brave.instrument.messaging.MessageListenerMethodInterceptor
 
isAutoStartup() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
isNoop() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
isRunning() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
isSampled(long) - Method in class org.springframework.cloud.sleuth.brave.sampler.ProbabilityBasedSampler
 
isSampled(long) - Method in class org.springframework.cloud.sleuth.brave.sampler.RateLimitingSampler
 
isSharable() - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 
isSharable() - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 

K

KafkaFactoryBeanPostProcessor - Class in org.springframework.cloud.sleuth.brave.instrument.messaging
Bean post processor that wraps Kafka factories.
KafkaFactoryBeanPostProcessor(BeanFactory) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.messaging.KafkaFactoryBeanPostProcessor
 

L

LocalServiceName - Annotation Type in org.springframework.cloud.sleuth.brave
Injects the service name for this application.

M

maybeScope(TraceContext) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
MessageListenerMethodInterceptor<T extends org.springframework.kafka.listener.MessageListener> - Class in org.springframework.cloud.sleuth.brave.instrument.messaging
 
MessageListenerMethodInterceptor(KafkaTracing, Tracer) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.messaging.MessageListenerMethodInterceptor
 

N

name(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
name(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpanCustomizer
 
NAME - Static variable in annotation type org.springframework.cloud.sleuth.brave.instrument.messaging.ConsumerSampler
Default name for message consumer sampler.
NAME - Static variable in annotation type org.springframework.cloud.sleuth.brave.instrument.messaging.ProducerSampler
Default name for messaging producer sampler.
NAME - Static variable in annotation type org.springframework.cloud.sleuth.brave.instrument.rpc.RpcClientSampler
Default name for RPC client sampler.
NAME - Static variable in annotation type org.springframework.cloud.sleuth.brave.instrument.rpc.RpcServerSampler
Default name for RPC server sampler.
newScope(TraceContext) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
nextSpan() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
nextSpan(Span) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 

O

onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
org.springframework.cloud.sleuth.brave - package org.springframework.cloud.sleuth.brave
 
org.springframework.cloud.sleuth.brave.bridge - package org.springframework.cloud.sleuth.brave.bridge
 
org.springframework.cloud.sleuth.brave.instrument.grpc - package org.springframework.cloud.sleuth.brave.instrument.grpc
 
org.springframework.cloud.sleuth.brave.instrument.messaging - package org.springframework.cloud.sleuth.brave.instrument.messaging
 
org.springframework.cloud.sleuth.brave.instrument.mongodb - package org.springframework.cloud.sleuth.brave.instrument.mongodb
 
org.springframework.cloud.sleuth.brave.instrument.reactor.netty - package org.springframework.cloud.sleuth.brave.instrument.reactor.netty
 
org.springframework.cloud.sleuth.brave.instrument.redis - package org.springframework.cloud.sleuth.brave.instrument.redis
 
org.springframework.cloud.sleuth.brave.instrument.rpc - package org.springframework.cloud.sleuth.brave.instrument.rpc
 
org.springframework.cloud.sleuth.brave.instrument.web - package org.springframework.cloud.sleuth.brave.instrument.web
 
org.springframework.cloud.sleuth.brave.propagation - package org.springframework.cloud.sleuth.brave.propagation
 
org.springframework.cloud.sleuth.brave.sampler - package org.springframework.cloud.sleuth.brave.sampler
 
org.springframework.jms.config - package org.springframework.jms.config
 

P

parentId() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
parse(HttpRequest, TraceContext, SpanCustomizer) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpRequestParser
 
parse(HttpResponse, TraceContext, SpanCustomizer) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpResponseParser
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.cloud.sleuth.brave.instrument.messaging.KafkaFactoryBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.cloud.sleuth.brave.instrument.messaging.TracingConnectionFactoryBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.cloud.sleuth.brave.instrument.messaging.TracingJmsBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.cloud.sleuth.brave.instrument.messaging.SleuthRabbitBeanPostProcessor
 
ProbabilityBasedSampler - Class in org.springframework.cloud.sleuth.brave.sampler
This sampler is appropriate for low-traffic instrumentation (ex servers that each receive less than 100K requests), or those who do not provision random trace ids.
ProbabilityBasedSampler(Supplier<Float>) - Constructor for class org.springframework.cloud.sleuth.brave.sampler.ProbabilityBasedSampler
 
ProducerSampler - Annotation Type in org.springframework.cloud.sleuth.brave.instrument.messaging
Annotate a producer SamplerFunction that should be injected to MessagingTracing.Builder.producerSampler(SamplerFunction).
PropagationFactorySupplier - Interface in org.springframework.cloud.sleuth.brave.propagation
Provides logic for supplying of a Propagation.Factory.
PropagationType - Enum in org.springframework.cloud.sleuth.brave.propagation
 

R

RateLimitingSampler - Class in org.springframework.cloud.sleuth.brave.sampler
The rate-limited sampler allows you to choose an amount of traces to accept on a per-second interval.
RateLimitingSampler(Supplier<Integer>) - Constructor for class org.springframework.cloud.sleuth.brave.sampler.RateLimitingSampler
 
read(ChannelHandlerContext) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
registerListenerContainer(JmsListenerEndpoint, JmsListenerContainerFactory<?>) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
registerListenerContainer(JmsListenerEndpoint, JmsListenerContainerFactory<?>, boolean) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
remoteIpAndPort(String, int) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
remoteServiceName(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
RpcClientSampler - Annotation Type in org.springframework.cloud.sleuth.brave.instrument.rpc
Annotate a client SamplerFunction that should be injected to RpcTracing.Builder.clientSampler(SamplerFunction).
RpcServerSampler - Annotation Type in org.springframework.cloud.sleuth.brave.instrument.rpc
Annotate a server SamplerFunction that should be injected to RpcTracing.Builder.serverSampler(SamplerFunction).

S

sampled() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
SkipPatternHttpClientSampler - Class in org.springframework.cloud.sleuth.brave.instrument.web
 
SkipPatternHttpClientSampler(Pattern) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.web.SkipPatternHttpClientSampler
 
SkipPatternHttpServerSampler - Class in org.springframework.cloud.sleuth.brave.instrument.web
Http Sampler that looks at paths.
SkipPatternHttpServerSampler(SkipPatternProvider) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.web.SkipPatternHttpServerSampler
 
SleuthKafkaAspect - Class in org.springframework.cloud.sleuth.brave.instrument.messaging
Instruments Kafka related components.
SleuthKafkaAspect(KafkaTracing, Tracer) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.messaging.SleuthKafkaAspect
 
SleuthRabbitBeanPostProcessor - Class in org.springframework.cloud.sleuth.brave.instrument.messaging
Instruments spring-rabbit related components.
SleuthRabbitBeanPostProcessor(BeanFactory) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.messaging.SleuthRabbitBeanPostProcessor
 
spanBuilder() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
spanId() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
SpringAwareManagedChannelBuilder - Class in org.springframework.cloud.sleuth.brave.instrument.grpc
This is a Spring-aware managed channel builder that wraps the static entry points of gRPC's ManagedChannelBuilder to allow the configuration of the builder to be influenced by the Spring Context.
SpringAwareManagedChannelBuilder(Optional<List<GrpcManagedChannelBuilderCustomizer>>) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.grpc.SpringAwareManagedChannelBuilder
 
start() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
start() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
startScopedSpan(String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
stop() - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
stop(Runnable) - Method in class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 

T

tag(String, String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
tag(String, String) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpanCustomizer
 
toBrave(FinishedSpan) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
toBrave(HttpRequestParser) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpRequestParser
 
toBrave(HttpResponseParser) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveHttpResponseParser
 
toBrave(Span) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
toBrave(TraceContext) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
toHttpBrave(SamplerFunction<HttpRequest>) - Static method in class org.springframework.cloud.sleuth.brave.bridge.BraveSamplerFunction
 
toString() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveFinishedSpan
 
toString() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSpan
 
toString() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
traceContextBuilder() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
traceId() - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTraceContext
 
TraceLettuceClientResourcesBuilderCustomizer - Class in org.springframework.cloud.sleuth.brave.instrument.redis
ClientResourcesBuilderCustomizer for wrapping Lettuce components in a tracing representation.
TraceLettuceClientResourcesBuilderCustomizer(Tracing, String) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.redis.TraceLettuceClientResourcesBuilderCustomizer
 
TraceMongoClientSettingsBuilderCustomizer - Class in org.springframework.cloud.sleuth.brave.instrument.mongodb
Trace representation of a MongoClientSettingsBuilderCustomizer.
TraceMongoClientSettingsBuilderCustomizer(Tracing) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.mongodb.TraceMongoClientSettingsBuilderCustomizer
 
TracingChannelInboundHandler - Class in org.springframework.cloud.sleuth.brave.instrument.reactor.netty
ChannelInboundHandlerAdapter that wraps all events in scope.
TracingChannelInboundHandler(CurrentTraceContext) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
Creates a new instance of TracingChannelInboundHandler.
TracingChannelOutboundHandler - Class in org.springframework.cloud.sleuth.brave.instrument.reactor.netty
ChannelOutboundHandlerAdapter that wraps all events in scope.
TracingChannelOutboundHandler(CurrentTraceContext) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
Creates a new instance of TracingChannelOutboundHandler.
TracingConnectionFactoryBeanPostProcessor - Class in org.springframework.cloud.sleuth.brave.instrument.messaging
BeanPostProcessor wrapping around JMS ConnectionFactory.
TracingConnectionFactoryBeanPostProcessor(BeanFactory) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.messaging.TracingConnectionFactoryBeanPostProcessor
 
TracingJmsBeanPostProcessor - Class in org.springframework.cloud.sleuth.brave.instrument.messaging
A BeanPostProcessor for JMS endpoint registry.
TracingJmsBeanPostProcessor(BeanFactory) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.messaging.TracingJmsBeanPostProcessor
 
TracingJmsListenerEndpointRegistry - Class in org.springframework.jms.config
This ensures listeners end up continuing the trace from MessageConsumer.receive().
TracingJmsListenerEndpointRegistry(JmsListenerEndpointRegistry, BeanFactory) - Constructor for class org.springframework.jms.config.TracingJmsListenerEndpointRegistry
 
TracingManagedChannelBuilderCustomizer - Class in org.springframework.cloud.sleuth.brave.instrument.grpc
Brave interceptor based customizer.
TracingManagedChannelBuilderCustomizer(GrpcTracing) - Constructor for class org.springframework.cloud.sleuth.brave.instrument.grpc.TracingManagedChannelBuilderCustomizer
 
trySample(HttpRequest) - Method in class org.springframework.cloud.sleuth.brave.instrument.web.CompositeHttpSampler
 
trySample(T) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveSamplerFunction
 

U

userEventTriggered(ChannelHandlerContext, Object) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelInboundHandler
 

V

valueOf(String) - Static method in enum org.springframework.cloud.sleuth.brave.propagation.PropagationType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.cloud.sleuth.brave.propagation.PropagationType
Returns an array containing the constants of this enum type, in the order they are declared.

W

W3C - org.springframework.cloud.sleuth.brave.propagation.PropagationType
W3C propagation type.
withSpan(Span) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveTracer
 
wrap(Runnable) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
wrap(Callable<C>) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
wrap(Executor) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
wrap(ExecutorService) - Method in class org.springframework.cloud.sleuth.brave.bridge.BraveCurrentTraceContext
 
wrapListenerContainerCreation(ProceedingJoinPoint) - Method in class org.springframework.cloud.sleuth.brave.instrument.messaging.SleuthKafkaAspect
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.springframework.cloud.sleuth.brave.instrument.reactor.netty.TracingChannelOutboundHandler
 
A B C D E F G H I K L M N O P R S T U V W 
All Classes All Packages