A B C D E F G H I J L M N O P Q R S T U V W X Y Z 

A

AbstractNamedChannelHandler - Class in org.ros.internal.transport.tcp
 
AbstractNamedChannelHandler() - Constructor for class org.ros.internal.transport.tcp.AbstractNamedChannelHandler
 
AbstractNodeMain - Class in org.ros.node
A NodeMain which provides empty defaults for all signals.
AbstractNodeMain() - Constructor for class org.ros.node.AbstractNodeMain
 
add(T, int) - Method in class org.ros.concurrent.ListenerGroup
Adds a listener to the ListenerGroup.
add(T) - Method in class org.ros.concurrent.ListenerGroup
Adds the specified listener to the ListenerGroup with the queue limit set to ListenerGroup.DEFAULT_QUEUE_CAPACITY.
add(T) - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
 
add(Vector3) - Method in class org.ros.rosjava_geometry.Vector3
 
addAll(Collection<T>, int) - Method in class org.ros.concurrent.ListenerGroup
Adds all the specified listeners to the ListenerGroup.
addAll(Collection<T>) - Method in class org.ros.concurrent.ListenerGroup
Adds all the specified listeners to the ListenerGroup with the queue capacity for each set to Integer.MAX_VALUE.
addAllNamedChannelHandlers(List<NamedChannelHandler>) - Method in class org.ros.internal.transport.tcp.TcpClient
 
addAllNamedChannelHandlers(List<NamedChannelHandler>) - Method in class org.ros.internal.transport.tcp.TcpClientManager
 
addChannel(Channel) - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
 
addClient(DefaultServiceClient<?, ?>) - Method in class org.ros.internal.node.service.ServiceManager
 
addField(String, String) - Method in class org.ros.internal.transport.ConnectionHeader
 
addFirst(T) - Method in class org.ros.concurrent.CircularBlockingDeque
Adds the specified entry to the tail of the queue, overwriting older entries if necessary.
addLast(T) - Method in class org.ros.concurrent.CircularBlockingDeque
Adds the specified entry to the tail of the queue, overwriting older entries if necessary.
addListener(NodeListener) - Method in class org.ros.internal.node.DefaultNode
 
addListener(GraphName, ParameterListener) - Method in class org.ros.internal.node.parameter.ParameterManager
 
addListener(ServiceServerListener<T, S>) - Method in class org.ros.internal.node.service.DefaultServiceServer
 
addListener(PublisherListener<T>) - Method in class org.ros.internal.node.topic.DefaultPublisher
 
addListener(ClientHandshakeListener) - Method in class org.ros.internal.transport.BaseClientHandshakeHandler
 
addListener(MessageListener<T>, int) - Method in class org.ros.internal.transport.queue.IncomingMessageQueue
 
addListener(MessageListener<T>, int) - Method in class org.ros.internal.transport.queue.MessageDispatcher
Adds the specified MessageListener to the internal ListenerGroup.
addListener(NodeListener) - Method in interface org.ros.node.Node
Add a new NodeListener to the Node.
addListener(ServiceServerListener<T, S>) - Method in interface org.ros.node.service.ServiceServer
addListener(PublisherListener<T>) - Method in interface org.ros.node.topic.Publisher
Add a new lifecycle listener to the Publisher.
addMessageListener(MessageListener<T>, int) - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
addMessageListener(MessageListener<T>) - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
addMessageListener(MessageListener<T>, int) - Method in interface org.ros.node.topic.Subscriber
Adds a MessageListener to be called when new messages are received.
addMessageListener(MessageListener<T>) - Method in interface org.ros.node.topic.Subscriber
Adds a MessageListener with a limit of 1.
addNamedChannelHandler(NamedChannelHandler) - Method in class org.ros.internal.transport.tcp.TcpClient
 
addNamedChannelHandler(NamedChannelHandler) - Method in class org.ros.internal.transport.tcp.TcpClientManager
 
addParameterListener(GraphName, ParameterListener) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
addParameterListener(String, ParameterListener) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
addParameterListener(GraphName, ParameterListener) - Method in class org.ros.node.AnonymousParmeterTree
 
addParameterListener(String, ParameterListener) - Method in class org.ros.node.AnonymousParmeterTree
 
addParameterListener(GraphName, ParameterListener) - Method in interface org.ros.node.parameter.ParameterTree
Subscribes to changes to the specified parameter.
addParameterListener(String, ParameterListener) - Method in interface org.ros.node.parameter.ParameterTree
 
addPublisher(TopicRegistrationInfo) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Add a new publisher to the node.
addPublisher(NodeRegistrationInfo, String) - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Add a new publisher to the topic.
addPublisher(PublisherIdentifier, InetSocketAddress) - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
addPublisher(DefaultPublisher<?>) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
addPublisherConnection(DefaultPublisher<?>, SubscriberIdentifier) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
Address - Interface in org.ros.address
 
addServer(DefaultServiceServer<?, ?>) - Method in class org.ros.internal.node.service.ServiceManager
 
addService(ServiceRegistrationInfo) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Add a new service to the node.
addSubscriber(TopicRegistrationInfo) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Add a new subscriber to the node.
addSubscriber(NodeRegistrationInfo, String) - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Add a new subscriber to the topic.
addSubscriber(SubscriberIdentifier, Channel) - Method in class org.ros.internal.node.topic.DefaultPublisher
Add a Subscriber connection to this Publisher.
addSubscriber(DefaultSubscriber<?>) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
addSubscriberConnection(DefaultSubscriber<?>, PublisherIdentifier) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
addSubscriberListener(SubscriberListener<T>) - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
addSubscriberListener(SubscriberListener<T>) - Method in interface org.ros.node.topic.Subscriber
Add a new lifecycle listener to the subscriber.
AdvertiseAddress - Class in org.ros.address
A wrapper for InetSocketAddress that emphasizes the difference between an address that should be used for binding a server port and one that should be advertised to external entities.
AdvertiseAddress(String) - Constructor for class org.ros.address.AdvertiseAddress
 
AdvertiseAddressFactory - Interface in org.ros.address
 
almostEquals(Quaternion, double) - Method in class org.ros.rosjava_geometry.Quaternion
 
almostEquals(Transform, double) - Method in class org.ros.rosjava_geometry.Transform
 
almostEquals(Vector3, double) - Method in class org.ros.rosjava_geometry.Vector3
 
AnonymousParmeterTree - Class in org.ros.node
 
AnonymousParmeterTree(URI) - Constructor for class org.ros.node.AnonymousParmeterTree
 
apply(Vector3) - Method in class org.ros.rosjava_geometry.Transform
 
apply(Quaternion) - Method in class org.ros.rosjava_geometry.Transform
 
await() - Method in class org.ros.concurrent.Holder
 
await(long, TimeUnit) - Method in class org.ros.concurrent.Holder
 
awaitMasterRegistrationFailure() - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of failed registrations.
awaitMasterRegistrationFailure(long, TimeUnit) - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of failed registrations within the given time period.
awaitMasterRegistrationSuccess() - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of successful registrations.
awaitMasterRegistrationSuccess(long, TimeUnit) - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of successful registrations within the given time period.
awaitMasterUnregistrationFailure() - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of failed unregistrations.
awaitMasterUnregistrationFailure(long, TimeUnit) - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of failed unregistrations within the given time period.
awaitMasterUnregistrationSuccess() - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of successful unregistrations.
awaitMasterUnregistrationSuccess(long, TimeUnit) - Method in class org.ros.internal.node.CountDownRegistrantListener
Wait for the requested number of successful unregistrations within the given time period.
awaitNewPublisher() - Method in class org.ros.node.topic.CountDownSubscriberListener
Wait for the requested number of new publishers.
awaitNewPublisher(long, TimeUnit) - Method in class org.ros.node.topic.CountDownSubscriberListener
Wait for the requested number of new publishers within the given time period.
awaitNewSubscriber() - Method in class org.ros.node.topic.CountDownPublisherListener
Wait for the requested number of shutdowns.
awaitNewSubscriber(long, TimeUnit) - Method in class org.ros.node.topic.CountDownPublisherListener
Wait for the requested number of new subscribers within the given time period.
awaitShutdown() - Method in class org.ros.node.service.CountDownServiceServerListener
Wait for shutdown.
awaitShutdown(long, TimeUnit) - Method in class org.ros.node.service.CountDownServiceServerListener
Wait for shutdown within the given time period.
awaitShutdown() - Method in class org.ros.node.topic.CountDownPublisherListener
Wait for for shutdown.
awaitShutdown(long, TimeUnit) - Method in class org.ros.node.topic.CountDownPublisherListener
Wait for shutdown within the given time period.
awaitShutdown() - Method in class org.ros.node.topic.CountDownSubscriberListener
Wait for shutdown.
awaitShutdown(long, TimeUnit) - Method in class org.ros.node.topic.CountDownSubscriberListener
Wait for shutdown within the given time period.
awaitStart() - Method in class org.ros.internal.node.server.XmlRpcServer
 
awaitStart(long, TimeUnit) - Method in class org.ros.internal.node.server.XmlRpcServer
 
awaitStart() - Method in class org.ros.RosCore
 
awaitStart(long, TimeUnit) - Method in class org.ros.RosCore
 
awaitTermination(long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
First calls DefaultScheduledExecutorService.awaitTermination(long, TimeUnit) on the wrapped ExecutorService and then DefaultScheduledExecutorService.awaitTermination(long, TimeUnit) on the wrapped ScheduledExecutorService.
awaitTermination(long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 

B

BaseClientHandshake - Class in org.ros.internal.node
An abstract ClientHandshake implementation for convenience.
BaseClientHandshake(ConnectionHeader) - Constructor for class org.ros.internal.node.BaseClientHandshake
 
BaseClientHandshakeHandler - Class in org.ros.internal.transport
Common functionality for ClientHandshake handlers.
BaseClientHandshakeHandler(ClientHandshake, ExecutorService) - Constructor for class org.ros.internal.transport.BaseClientHandshakeHandler
 
BindAddress - Class in org.ros.address
A wrapper for InetSocketAddress that emphasizes the difference between an address that should be used for binding a server port and one that should be advertised to external entities.
BooleanResultFactory - Class in org.ros.internal.node.response
 
BooleanResultFactory() - Constructor for class org.ros.internal.node.response.BooleanResultFactory
 
build() - Method in class org.ros.internal.loader.CommandLineLoader
Create NodeConfiguration according to ROS command-line and environment specification.
build(T, S) - Method in interface org.ros.node.service.ServiceResponseBuilder
Builds a service response given a service request.
byteToShort(byte) - Static method in class org.ros.math.Unsigned
 

C

calibrate(int, double) - Method in class org.ros.time.RemoteUptimeClock
Good calibration settings will depend on the remote uptime provider.
call(T, ServiceResponseListener<S>) - Method in class org.ros.internal.node.service.DefaultServiceClient
 
call(T, ServiceResponseListener<S>) - Method in interface org.ros.node.service.ServiceClient
Calls a method on the ServiceServer.
CALLER_ID - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
cancel() - Method in class org.ros.concurrent.CancellableLoop
Interrupts the loop.
cancel() - Method in class org.ros.concurrent.WatchdogTimer
 
cancel() - Method in class org.ros.internal.node.topic.RepeatingPublisher
 
CancellableLoop - Class in org.ros.concurrent
An interruptable loop that can be run by an ExecutorService.
CancellableLoop() - Constructor for class org.ros.concurrent.CancellableLoop
 
channelClosed(ChannelHandlerContext, ChannelStateEvent) - Method in class org.ros.internal.transport.ConnectionTrackingHandler
 
channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in class org.ros.internal.transport.BaseClientHandshakeHandler
 
channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in class org.ros.internal.transport.ConnectionTrackingHandler
 
CircularBlockingDeque<T> - Class in org.ros.concurrent
A deque that removes head or tail elements when the number of elements exceeds the limit and blocks on CircularBlockingDeque.takeFirst() and CircularBlockingDeque.takeLast() when there are no elements available.
CircularBlockingDeque(int) - Constructor for class org.ros.concurrent.CircularBlockingDeque
 
clamp(double, double, double) - Static method in class org.ros.math.RosMath
 
clamp(float, float, float) - Static method in class org.ros.math.RosMath
 
clamp(int, int, int) - Static method in class org.ros.math.RosMath
 
clamp(long, long, long) - Static method in class org.ros.math.RosMath
 
Client - Class in org.ros.rosjava_tutorial_services
Client() - Constructor for class org.ros.rosjava_tutorial_services.Client
 
ClientHandshake - Interface in org.ros.internal.transport
Encapsulates client-side transport handshake logic.
ClientHandshakeListener - Interface in org.ros.internal.transport
A listener for handshake events.
CLOCK - Static variable in interface org.ros.Topics
 
ClockTopicTimeProvider - Class in org.ros.time
A TimeProvider for use when the ROS graph is configured for simulation.
ClockTopicTimeProvider(DefaultNode) - Constructor for class org.ros.time.ClockTopicTimeProvider
 
CollectionMath - Class in org.ros.math
 
CommandLineLoader - Class in org.ros.internal.loader
Create NodeConfiguration instances using a ROS command-line and environment specification.
CommandLineLoader(List<String>) - Constructor for class org.ros.internal.loader.CommandLineLoader
Create new CommandLineLoader with specified command-line arguments.
CommandLineLoader(List<String>, Map<String, String>) - Constructor for class org.ros.internal.loader.CommandLineLoader
Create new CommandLineLoader with specified command-line arguments and environment variables.
CommandLineVariables - Interface in org.ros
Remapping keys used to override ROS environment and other configuration settings from a command-line-based executation of a node.
conjugate() - Method in class org.ros.rosjava_geometry.Quaternion
 
connect(URI) - Method in class org.ros.internal.node.service.DefaultServiceClient
 
connect(String, SocketAddress) - Method in class org.ros.internal.transport.tcp.TcpClient
 
connect(String, SocketAddress) - Method in class org.ros.internal.transport.tcp.TcpClientManager
Connects to a server.
connect(URI) - Method in interface org.ros.node.service.ServiceClient
Connects to a ServiceServer.
ConnectedNode - Interface in org.ros.node
A node in the ROS graph that has successfully contacted the master.
CONNECTION_TRACKING_HANDLER - Static variable in class org.ros.internal.transport.tcp.ConnectionTrackingChannelPipelineFactory
 
ConnectionHeader - Class in org.ros.internal.transport
 
ConnectionHeader() - Constructor for class org.ros.internal.transport.ConnectionHeader
 
ConnectionHeaderFields - Interface in org.ros.internal.transport
Fields found inside the header for node to node communication.
ConnectionTrackingChannelPipelineFactory - Class in org.ros.internal.transport.tcp
 
ConnectionTrackingChannelPipelineFactory(ChannelGroup) - Constructor for class org.ros.internal.transport.tcp.ConnectionTrackingChannelPipelineFactory
 
ConnectionTrackingHandler - Class in org.ros.internal.transport
Adds new Channels to the provided ChannelGroup.
ConnectionTrackingHandler(ChannelGroup) - Constructor for class org.ros.internal.transport.ConnectionTrackingHandler
 
contactSubscriberForPublisherUpdate(URI, GraphName, List<URI>) - Method in class org.ros.internal.node.server.master.MasterServer
Contact a subscriber and send it a publisher update.
copyOf(NodeConfiguration) - Static method in class org.ros.node.NodeConfiguration
 
CountDownPublisherListener<T> - Class in org.ros.node.topic
A PublisherListener which uses separate CountDownLatch instances for all signals.
CountDownRegistrantListener<T> - Class in org.ros.internal.node
 
CountDownRegistrantListener() - Constructor for class org.ros.internal.node.CountDownRegistrantListener
Construct a CountDownPublisherListener with all counts set to 1.
CountDownRegistrantListener(int, int, int, int) - Constructor for class org.ros.internal.node.CountDownRegistrantListener
 
CountDownRegistrantListener(CountDownLatch, CountDownLatch, CountDownLatch, CountDownLatch) - Constructor for class org.ros.internal.node.CountDownRegistrantListener
 
CountDownServiceServerListener<T,S> - Class in org.ros.node.service
A ServiceServerListener which uses CountDownLatch to track message invocations.
CountDownSubscriberListener<T> - Class in org.ros.node.topic
A SubscriberListener which uses separate CountDownLatch instances for all messages.

D

decode(ChannelBuffer) - Static method in class org.ros.internal.transport.ConnectionHeader
Decodes a header that came over the wire into a Map of fields and values.
DEFAULT_MASTER_URI - Static variable in class org.ros.node.NodeConfiguration
The default master URI.
DefaultNode - Class in org.ros.internal.node
The default implementation of a Node.
DefaultNode(NodeConfiguration, Collection<NodeListener>, ScheduledExecutorService) - Constructor for class org.ros.internal.node.DefaultNode
DefaultNodes should only be constructed using the DefaultNodeFactory.
DefaultNodeFactory - Class in org.ros.node
Constructs DefaultNodes.
DefaultNodeFactory(ScheduledExecutorService) - Constructor for class org.ros.node.DefaultNodeFactory
 
DefaultNodeListener - Class in org.ros.node
A NodeListener which provides empty defaults for all signals.
DefaultNodeListener() - Constructor for class org.ros.node.DefaultNodeListener
 
DefaultNodeMainExecutor - Class in org.ros.node
Executes NodeMains in separate threads.
DefaultParameterTree - Class in org.ros.internal.node.parameter
Provides access to the ROS ParameterServer.
DefaultPublisher<T> - Class in org.ros.internal.node.topic
Default implementation of a Publisher.
DefaultPublisher(NodeIdentifier, TopicDeclaration, MessageSerializer<T>, MessageFactory, ScheduledExecutorService) - Constructor for class org.ros.internal.node.topic.DefaultPublisher
 
DefaultPublisherListener<T> - Class in org.ros.node.topic
A PublisherListener which provides empty defaults for all signals.
DefaultPublisherListener() - Constructor for class org.ros.node.topic.DefaultPublisherListener
 
DefaultScheduledExecutorService - Class in org.ros.concurrent
This wraps a Executors.newCachedThreadPool() and a Executors.newScheduledThreadPool(int) to provide the functionality of both in a single ScheduledExecutorService.
DefaultScheduledExecutorService() - Constructor for class org.ros.concurrent.DefaultScheduledExecutorService
 
DefaultScheduledExecutorService(ExecutorService) - Constructor for class org.ros.concurrent.DefaultScheduledExecutorService
This instance will take over the lifecycle of the services.
DefaultScheduledExecutorService(ExecutorService, ScheduledExecutorService) - Constructor for class org.ros.concurrent.DefaultScheduledExecutorService
This instance will take over the lifecycle of the services.
DefaultServiceClient<T,S> - Class in org.ros.internal.node.service
Default implementation of a ServiceClient.
DefaultServiceServer<T,S> - Class in org.ros.internal.node.service
Default implementation of a ServiceServer.
DefaultServiceServer(ServiceDeclaration, ServiceResponseBuilder<T, S>, AdvertiseAddress, MessageDeserializer<T>, MessageSerializer<S>, MessageFactory, ScheduledExecutorService) - Constructor for class org.ros.internal.node.service.DefaultServiceServer
 
DefaultServiceServerListener<T,S> - Class in org.ros.node.service
 
DefaultServiceServerListener() - Constructor for class org.ros.node.service.DefaultServiceServerListener
 
DefaultSubscriber<T> - Class in org.ros.internal.node.topic
Default implementation of a Subscriber.
DefaultSubscriberListener<T> - Class in org.ros.node.topic
A SubscriberListener which provides empty defaults for all signals.
DefaultSubscriberListener() - Constructor for class org.ros.node.topic.DefaultSubscriberListener
 
DefaultTopicParticipant - Class in org.ros.internal.node.topic
Base definition of a TopicSystemState.
DefaultTopicParticipant(TopicDeclaration) - Constructor for class org.ros.internal.node.topic.DefaultTopicParticipant
 
delete(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
delete(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
delete(GraphName) - Method in class org.ros.internal.node.server.ParameterServer
 
delete(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
delete(String) - Method in class org.ros.node.AnonymousParmeterTree
 
delete(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
Deletes a specified parameter.
delete(String) - Method in interface org.ros.node.parameter.ParameterTree
 
deleteParam(GraphName) - Method in class org.ros.internal.node.client.ParameterClient
 
deleteParam(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
deleteParam(String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Deletes a parameter.
dotProduct(Vector3) - Method in class org.ros.rosjava_geometry.Vector3
 
DroppedEntryException - Exception in org.ros.concurrent
 
DroppedEntryException() - Constructor for exception org.ros.concurrent.DroppedEntryException
 
DuplicateServiceException - Exception in org.ros.exception
 
DuplicateServiceException(String) - Constructor for exception org.ros.exception.DuplicateServiceException
 

E

empty() - Static method in class org.ros.namespace.GraphName
 
encode(ChannelHandlerContext, Channel, Object) - Method in class org.ros.internal.node.service.ServiceResponseEncoder
 
encode() - Method in class org.ros.internal.transport.ConnectionHeader
Encodes this ConnectionHeader for transmission over the wire.
EnvironmentVariables - Interface in org.ros
ROS environment variables.
equals(Object) - Method in class org.ros.address.AdvertiseAddress
 
equals(Object) - Method in class org.ros.address.BindAddress
 
equals(Object) - Method in class org.ros.concurrent.Holder
 
equals(Object) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
 
equals(Object) - Method in class org.ros.internal.node.server.master.ServiceRegistrationInfo
 
equals(Object) - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
 
equals(Object) - Method in class org.ros.internal.node.server.NodeIdentifier
 
equals(Object) - Method in class org.ros.internal.node.service.ServiceDeclaration
 
equals(Object) - Method in class org.ros.internal.node.service.ServiceIdentifier
 
equals(Object) - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
equals(Object) - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
equals(Object) - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
equals(Object) - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
equals(Object) - Method in class org.ros.internal.node.topic.TopicDeclaration
 
equals(Object) - Method in class org.ros.internal.node.topic.TopicIdentifier
 
equals(Object) - Method in class org.ros.internal.transport.ConnectionHeader
 
equals(Object) - Method in class org.ros.internal.transport.ProtocolDescription
 
equals(Object) - Method in class org.ros.namespace.GraphName
 
equals(Object) - Method in class org.ros.rosjava_geometry.FrameName
 
equals(Object) - Method in class org.ros.rosjava_geometry.FrameTransform
 
equals(Object) - Method in class org.ros.rosjava_geometry.Quaternion
 
equals(Object) - Method in class org.ros.rosjava_geometry.Transform
 
equals(Object) - Method in class org.ros.rosjava_geometry.Vector3
 
ERROR - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
EventDispatcher<T> - Class in org.ros.concurrent
 
EventDispatcher(T, int) - Constructor for class org.ros.concurrent.EventDispatcher
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.ros.internal.transport.ConnectionTrackingHandler
 
execute(Runnable) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
execute(Runnable) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
execute(NodeMain, NodeConfiguration, Collection<NodeListener>) - Method in class org.ros.node.DefaultNodeMainExecutor
 
execute(NodeMain, NodeConfiguration) - Method in class org.ros.node.DefaultNodeMainExecutor
 
execute(NodeMain, NodeConfiguration, Collection<NodeListener>) - Method in interface org.ros.node.NodeMainExecutor
Executes the supplied NodeMain using the supplied NodeConfiguration.
execute(NodeMain, NodeConfiguration) - Method in interface org.ros.node.NodeMainExecutor
Executes the supplied NodeMain using the supplied NodeConfiguration.
executeCancellableLoop(CancellableLoop) - Method in class org.ros.internal.node.DefaultNode
 
executeCancellableLoop(CancellableLoop) - Method in interface org.ros.node.Node
Executes a CancellableLoop using the Node's ScheduledExecutorService.

F

finishHandshake(ConnectionHeader) - Method in class org.ros.internal.node.service.DefaultServiceServer
 
finishHandshake(ConnectionHeader) - Method in class org.ros.internal.node.topic.DefaultPublisher
Complete connection handshake on buffer.
forName(String) - Static method in class org.ros.internal.node.server.NodeIdentifier
 
forName(String) - Static method in class org.ros.internal.node.topic.TopicIdentifier
 
forNameAndUri(String, String) - Static method in class org.ros.internal.node.server.NodeIdentifier
 
forUri(String) - Static method in class org.ros.internal.node.server.NodeIdentifier
 
FrameName - Class in org.ros.rosjava_geometry
Provides a simple wrapper around strings to represent frame names with backwards compatibility (pre ros hydro) catered for by ignoring graph name style leading slashes.
FrameTransform - Class in org.ros.rosjava_geometry
Describes a Transform from data in the source frame to data in the target frame at a specified Time.
FrameTransform(Transform, FrameName, FrameName, Time) - Constructor for class org.ros.rosjava_geometry.FrameTransform
Allocates a new FrameTransform.
FrameTransformTree - Class in org.ros.rosjava_geometry
A tree of FrameTransforms.
FrameTransformTree() - Constructor for class org.ros.rosjava_geometry.FrameTransformTree
 
fromAxisAngle(Vector3, double) - Static method in class org.ros.rosjava_geometry.Quaternion
 
fromInt(int) - Static method in enum org.ros.internal.node.response.StatusCode
 
fromListChecked(List<Object>, ResultFactory<T>) - Static method in class org.ros.internal.node.response.Response
Creates a Response from the List of Objects returned from an XML-RPC call.
fromListCheckedFailure(List<Object>, ResultFactory<T>) - Static method in class org.ros.internal.node.response.Response
Creates a Response from the List of Objects returned from an XML-RPC call.
fromPointMessage(Point) - Static method in class org.ros.rosjava_geometry.Vector3
 
fromPoseMessage(Pose) - Static method in class org.ros.rosjava_geometry.Transform
 
fromQuaternionMessage(Quaternion) - Static method in class org.ros.rosjava_geometry.Quaternion
 
fromTransformMessage(Transform) - Static method in class org.ros.rosjava_geometry.Transform
 
fromTransformStampedMessage(TransformStamped) - Static method in class org.ros.rosjava_geometry.FrameTransform
 
fromVector3Message(Vector3) - Static method in class org.ros.rosjava_geometry.Vector3
 

G

get() - Method in class org.ros.concurrent.Holder
 
get(GraphName) - Method in class org.ros.internal.node.server.ParameterServer
 
get() - Method in class org.ros.internal.transport.queue.LazyMessage
 
get(String) - Method in class org.ros.rosjava_geometry.FrameTransformTree
 
get(String, Time) - Method in class org.ros.rosjava_geometry.FrameTransformTree
 
get() - Method in class org.ros.rosjava_geometry.LazyFrameTransform
 
getAddress() - Method in class org.ros.internal.node.server.XmlRpcServer
 
getAddress() - Method in class org.ros.internal.transport.ProtocolDescription
 
getAddress() - Method in class org.ros.internal.transport.tcp.TcpRosServer
 
getAdverstiseAddress() - Method in class org.ros.internal.transport.ProtocolDescription
 
getAdvertiseAddress() - Method in class org.ros.internal.node.server.XmlRpcServer
 
getAdvertiseAddress() - Method in class org.ros.internal.transport.tcp.TcpRosServer
 
getAllServices() - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Get all services registered.
getAllTopics() - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Get all topics registered.
getBasename() - Method in class org.ros.namespace.GraphName
 
getBoolean(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getBoolean(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getBoolean(GraphName, boolean) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getBoolean(String, boolean) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getBoolean(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
getBoolean(String) - Method in class org.ros.node.AnonymousParmeterTree
 
getBoolean(GraphName, boolean) - Method in class org.ros.node.AnonymousParmeterTree
 
getBoolean(String, boolean) - Method in class org.ros.node.AnonymousParmeterTree
 
getBoolean(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
getBoolean(String) - Method in interface org.ros.node.parameter.ParameterTree
 
getBoolean(GraphName, boolean) - Method in interface org.ros.node.parameter.ParameterTree
 
getBoolean(String, boolean) - Method in interface org.ros.node.parameter.ParameterTree
 
getBusInfo() - Method in class org.ros.internal.node.client.SlaveClient
 
getBusInfo(String) - Method in class org.ros.internal.node.server.SlaveServer
 
getBusInfo(String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
Retrieve transport/topic connection information.
getBusInfo(String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
getBusStats() - Method in class org.ros.internal.node.client.SlaveClient
 
getBusStats(String) - Method in class org.ros.internal.node.server.SlaveServer
 
getBusStats(String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
Retrieve transport/topic statistics.
getBusStats(String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
getChannelGroup() - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
 
getClient(GraphName) - Method in class org.ros.internal.node.service.ServiceManager
 
getClient() - Method in class org.ros.internal.node.xmlrpc.XmlRpcClientFactory
Returns the factories client.
getClients() - Method in class org.ros.internal.node.service.ServiceManager
 
getCurrentTime() - Method in class org.ros.internal.node.DefaultNode
 
getCurrentTime() - Method in interface org.ros.node.ConnectedNode
In ROS, time can be wallclock (actual) or simulated, so it is important to use ConnectedNode.getCurrentTime() instead of using the standard Java routines for determining the current time.
getCurrentTime() - Method in class org.ros.time.ClockTopicTimeProvider
 
getCurrentTime() - Method in class org.ros.time.NtpTimeProvider
 
getCurrentTime() - Method in interface org.ros.time.TimeProvider
 
getCurrentTime() - Method in class org.ros.time.WallTimeProvider
 
getDefaultNodeName() - Method in class org.ros.MessageSerializationTestNode
 
getDefaultNodeName() - Method in interface org.ros.node.NodeMain
 
getDefaultNodeName() - Method in class org.ros.ParameterServerTestNode
 
getDefaultNodeName() - Method in class org.ros.PassthroughTestNode
 
getDefaultNodeName() - Method in class org.ros.rosjava_benchmarks.MessagesBenchmark
 
getDefaultNodeName() - Method in class org.ros.rosjava_benchmarks.PubsubBenchmark
 
getDefaultNodeName() - Method in class org.ros.rosjava_benchmarks.TransformBenchmark
 
getDefaultNodeName() - Method in class org.ros.rosjava_tutorial_pubsub.Listener
 
getDefaultNodeName() - Method in class org.ros.rosjava_tutorial_pubsub.Talker
 
getDefaultNodeName() - Method in class org.ros.rosjava_tutorial_right_hand_rule.RightHandRule
 
getDefaultNodeName() - Method in class org.ros.rosjava_tutorial_services.Client
 
getDefaultNodeName() - Method in class org.ros.rosjava_tutorial_services.Server
 
getDefaultNodeName() - Method in class org.ros.SlaveApiTestNode
 
getDefinition() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
getDouble(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getDouble(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getDouble(GraphName, double) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getDouble(String, double) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getDouble(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
getDouble(String) - Method in class org.ros.node.AnonymousParmeterTree
 
getDouble(GraphName, double) - Method in class org.ros.node.AnonymousParmeterTree
 
getDouble(String, double) - Method in class org.ros.node.AnonymousParmeterTree
 
getDouble(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
getDouble(String) - Method in interface org.ros.node.parameter.ParameterTree
 
getDouble(GraphName, double) - Method in interface org.ros.node.parameter.ParameterTree
 
getDouble(String, double) - Method in interface org.ros.node.parameter.ParameterTree
 
getErrorMessage() - Method in class org.ros.internal.node.BaseClientHandshake
 
getErrorMessage() - Method in interface org.ros.internal.transport.ClientHandshake
 
getField(String) - Method in class org.ros.internal.transport.ConnectionHeader
 
getFields() - Method in class org.ros.internal.transport.ConnectionHeader
 
getHost() - Method in class org.ros.address.AdvertiseAddress
 
getIdentifier() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
getIdentifier() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
getInteger(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getInteger(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getInteger(GraphName, int) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getInteger(String, int) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getInteger(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
getInteger(String) - Method in class org.ros.node.AnonymousParmeterTree
 
getInteger(GraphName, int) - Method in class org.ros.node.AnonymousParmeterTree
 
getInteger(String, int) - Method in class org.ros.node.AnonymousParmeterTree
 
getInteger(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
getInteger(String) - Method in interface org.ros.node.parameter.ParameterTree
 
getInteger(GraphName, int) - Method in interface org.ros.node.parameter.ParameterTree
 
getInteger(String, int) - Method in interface org.ros.node.parameter.ParameterTree
 
getLatchMode() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
getLatchMode() - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
getLatchMode() - Method in class org.ros.internal.transport.queue.IncomingMessageQueue
 
getLatchMode() - Method in class org.ros.internal.transport.queue.MessageDispatcher
 
getLatchMode() - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
 
getLatchMode() - Method in interface org.ros.node.topic.Publisher
 
getLatchMode() - Method in interface org.ros.node.topic.Subscriber
 
getList(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getList(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getList(GraphName, List<?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getList(String, List<?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getList(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
getList(String) - Method in class org.ros.node.AnonymousParmeterTree
 
getList(GraphName, List<?>) - Method in class org.ros.node.AnonymousParmeterTree
 
getList(String, List<?>) - Method in class org.ros.node.AnonymousParmeterTree
 
getList(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
getList(String) - Method in interface org.ros.node.parameter.ParameterTree
 
getList(GraphName, List<?>) - Method in interface org.ros.node.parameter.ParameterTree
 
getList(String, List<?>) - Method in interface org.ros.node.parameter.ParameterTree
 
getLog() - Method in class org.ros.internal.node.DefaultNode
 
getLog() - Method in interface org.ros.node.Node
 
getMagnitude() - Method in class org.ros.rosjava_geometry.Quaternion
 
getMagnitude() - Method in class org.ros.rosjava_geometry.Vector3
 
getMagnitudeSquared() - Method in class org.ros.rosjava_geometry.Quaternion
 
getMagnitudeSquared() - Method in class org.ros.rosjava_geometry.Vector3
 
getMap(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getMap(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getMap(GraphName, Map<?, ?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getMap(String, Map<?, ?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getMap(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
getMap(String) - Method in class org.ros.node.AnonymousParmeterTree
 
getMap(GraphName, Map<?, ?>) - Method in class org.ros.node.AnonymousParmeterTree
 
getMap(String, Map<?, ?>) - Method in class org.ros.node.AnonymousParmeterTree
 
getMap(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
getMap(String) - Method in interface org.ros.node.parameter.ParameterTree
 
getMap(GraphName, Map<?, ?>) - Method in interface org.ros.node.parameter.ParameterTree
 
getMap(String, Map<?, ?>) - Method in interface org.ros.node.parameter.ParameterTree
 
getMasterServer() - Method in class org.ros.RosCore
 
getMasterUri() - Method in class org.ros.internal.node.client.SlaveClient
 
getMasterUri() - Method in class org.ros.internal.node.DefaultNode
 
getMasterUri() - Method in class org.ros.internal.node.server.SlaveServer
 
getMasterUri(String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
getMasterUri(String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
getMasterUri() - Method in interface org.ros.master.uri.MasterUriProvider
Get a master URI.
getMasterUri(long, TimeUnit) - Method in interface org.ros.master.uri.MasterUriProvider
Get a master URI within a given amount of time.
getMasterUri() - Method in class org.ros.master.uri.StaticMasterUriProvider
 
getMasterUri(long, TimeUnit) - Method in class org.ros.master.uri.StaticMasterUriProvider
 
getMasterUri() - Method in class org.ros.master.uri.SwitchableMasterUriProvider
 
getMasterUri(long, TimeUnit) - Method in class org.ros.master.uri.SwitchableMasterUriProvider
 
getMasterUri() - Method in interface org.ros.node.Node
 
getMasterUri() - Method in class org.ros.node.NodeConfiguration
 
getMd5Checksum() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
getMessageReceiver() - Method in class org.ros.internal.transport.queue.IncomingMessageQueue
 
getMessageSerializationFactory() - Method in class org.ros.internal.node.DefaultNode
 
getMessageSerializationFactory() - Method in interface org.ros.node.Node
 
getMessageSerializationFactory() - Method in class org.ros.node.NodeConfiguration
 
getMessageType() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Get the currently known message type of the topic.
getMessageType() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
getMessageType() - Method in class org.ros.master.client.TopicType
 
getName() - Method in class org.ros.internal.node.DefaultNode
 
getName() - Method in class org.ros.internal.node.server.NodeIdentifier
 
getName() - Method in class org.ros.internal.node.service.DefaultServiceClient
 
getName() - Method in class org.ros.internal.node.service.DefaultServiceServer
 
getName() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
getName() - Method in class org.ros.internal.node.service.ServiceIdentifier
 
getName() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
getName() - Method in class org.ros.internal.node.topic.TopicIdentifier
 
getName() - Method in class org.ros.internal.transport.ProtocolDescription
 
getName() - Method in class org.ros.internal.transport.queue.MessageReceiver
 
getName() - Method in interface org.ros.internal.transport.tcp.NamedChannelHandler
 
getName() - Method in class org.ros.master.client.TopicType
 
getName() - Method in interface org.ros.node.Node
 
getName() - Method in interface org.ros.node.service.ServiceClient
 
getName() - Method in interface org.ros.node.service.ServiceServer
 
getNames() - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getNames() - Method in class org.ros.internal.node.server.ParameterServer
 
getNames() - Method in class org.ros.node.AnonymousParmeterTree
 
getNames() - Method in interface org.ros.node.parameter.ParameterTree
 
getNamespace() - Method in class org.ros.namespace.NameResolver
 
getNode() - Method in class org.ros.internal.node.server.master.ServiceRegistrationInfo
Get the information about the node which contains the service.
getNodeArguments() - Method in class org.ros.internal.loader.CommandLineLoader
 
getNodeClassName() - Method in class org.ros.internal.loader.CommandLineLoader
 
getNodeIdentifier() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
getNodeIdentifier() - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
getNodeIdentifier() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
getNodeName() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
 
getNodeName() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
getNodeName() - Method in class org.ros.node.NodeConfiguration
 
getNodeRegistrationInfo(GraphName) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Get the information known about a node.
getNodeSlaveUri() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
 
getNodeUri() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
getNumberOfChannels() - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
 
getNumberOfSubscribers() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
getNumberOfSubscribers() - Method in interface org.ros.node.topic.Publisher
Get the number of Subscribers currently connected to the Publisher.
getOutgoingConnectionHeader() - Method in class org.ros.internal.node.BaseClientHandshake
 
getOutgoingConnectionHeader() - Method in interface org.ros.internal.transport.ClientHandshake
 
getParam(GraphName) - Method in class org.ros.internal.node.client.ParameterClient
 
getParam(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getParam(String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Retrieve parameter value from server.
getParameterTree() - Method in class org.ros.internal.node.DefaultNode
 
getParameterTree() - Method in interface org.ros.node.ConnectedNode
Create a ParameterTree to query and set parameters on the ROS parameter server.
getParamNames() - Method in class org.ros.internal.node.client.ParameterClient
 
getParamNames(String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getParamNames(String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Gets the list of all parameter names stored on this server.
getParent() - Method in class org.ros.namespace.GraphName
 
getParentResolver() - Method in class org.ros.node.NodeConfiguration
 
getPid() - Method in class org.ros.internal.node.client.SlaveClient
 
getPid() - Method in class org.ros.internal.node.server.SlaveServer
 
getPid() - Method in class org.ros.internal.node.server.XmlRpcServer
 
getPid(String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Get the PID for the master process.
getPid(String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getPid(String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
getPid(String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
getPid() - Static method in class org.ros.internal.system.Process
 
getPipeline() - Method in class org.ros.internal.transport.tcp.ConnectionTrackingChannelPipelineFactory
 
getPipeline() - Method in class org.ros.internal.transport.tcp.TcpClientPipelineFactory
 
getPipeline() - Method in class org.ros.internal.transport.tcp.TcpServerPipelineFactory
 
getPort() - Method in class org.ros.address.AdvertiseAddress
 
getPublications() - Method in class org.ros.internal.node.client.SlaveClient
 
getPublications() - Method in class org.ros.internal.node.server.SlaveServer
 
getPublications(String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
Retrieve a list of topics that this node publishes.
getPublications(String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
getPublishedTopics(GraphName, String) - Method in class org.ros.internal.node.client.MasterClient
 
getPublishedTopics(GraphName, GraphName) - Method in class org.ros.internal.node.server.master.MasterServer
Get a list of all topics published for the give subgraph.
getPublishedTopics(String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Get list of topics that can be subscribed to.
getPublishedTopics(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getPublishedTopics(String) - Method in class org.ros.master.client.MasterStateClient
 
getPublisher(GraphName) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
getPublisherConnections(DefaultPublisher<?>) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
getPublishers() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Get all known topics published by the node.
getPublishers() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Get a list of all known publishers for the topic.
getPublishers() - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
getPublishers() - Method in class org.ros.master.client.TopicSystemState
Get the set of all nodes that publish the topic.
getRemappings() - Method in class org.ros.namespace.NameResolver
 
getRequest() - Method in class org.ros.internal.node.service.Service
 
getResolver() - Method in class org.ros.internal.node.DefaultNode
 
getResolver() - Method in interface org.ros.node.Node
 
getResponse() - Method in class org.ros.internal.node.service.Service
 
getResult() - Method in class org.ros.internal.node.response.Response
 
getRosPackagePath() - Method in class org.ros.node.NodeConfiguration
These ordered paths tell the ROS system where to search for more ROS packages.
getRosRoot() - Method in class org.ros.node.NodeConfiguration
 
getScale() - Method in class org.ros.rosjava_geometry.Transform
 
getScheduledExecutorService() - Method in class org.ros.internal.node.DefaultNode
 
getScheduledExecutorService() - Method in class org.ros.node.DefaultNodeMainExecutor
 
getScheduledExecutorService() - Method in interface org.ros.node.Node
 
getScheduledExecutorService() - Method in interface org.ros.node.NodeMainExecutor
 
getServer(GraphName) - Method in class org.ros.internal.node.service.ServiceFactory
 
getServer(GraphName) - Method in class org.ros.internal.node.service.ServiceManager
 
getServers() - Method in class org.ros.internal.node.service.ServiceManager
 
getServiceDescriptionFactory() - Method in class org.ros.node.NodeConfiguration
 
getServiceName() - Method in class org.ros.internal.node.server.master.ServiceRegistrationInfo
Get the name of the service.
getServiceRegistrationInfo(GraphName) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Get the information known about a service.
getServiceRequestMessageFactory() - Method in class org.ros.internal.node.DefaultNode
 
getServiceRequestMessageFactory() - Method in interface org.ros.node.Node
 
getServiceRequestMessageFactory() - Method in class org.ros.node.NodeConfiguration
 
getServiceResponseMessageFactory() - Method in class org.ros.internal.node.DefaultNode
 
getServiceResponseMessageFactory() - Method in interface org.ros.node.Node
 
getServiceResponseMessageFactory() - Method in class org.ros.node.NodeConfiguration
 
getServices() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Get all known services provided by the node.
getServiceServer(GraphName) - Method in class org.ros.internal.node.DefaultNode
 
getServiceServer(String) - Method in class org.ros.internal.node.DefaultNode
 
getServiceServer(GraphName) - Method in interface org.ros.node.ConnectedNode
 
getServiceServer(String) - Method in interface org.ros.node.ConnectedNode
 
getServiceUri() - Method in class org.ros.internal.node.server.master.ServiceRegistrationInfo
Get the URI of the service server.
getSlaveIdentifier() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
getSlaveName() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
getSlaveUri() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
getSlaveUri() - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
getSourceFrame() - Method in class org.ros.rosjava_geometry.FrameTransform
 
getStatusCode() - Method in exception org.ros.exception.RemoteException
 
getStatusCode() - Method in class org.ros.internal.node.response.Response
 
getStatusMessage() - Method in class org.ros.internal.node.response.Response
 
getString(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getString(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getString(GraphName, String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getString(String, String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
getString(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
getString(String) - Method in class org.ros.node.AnonymousParmeterTree
 
getString(GraphName, String) - Method in class org.ros.node.AnonymousParmeterTree
 
getString(String, String) - Method in class org.ros.node.AnonymousParmeterTree
 
getString(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
getString(String) - Method in interface org.ros.node.parameter.ParameterTree
 
getString(GraphName, String) - Method in interface org.ros.node.parameter.ParameterTree
 
getString(String, String) - Method in interface org.ros.node.parameter.ParameterTree
 
getSubscriber(GraphName) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
getSubscriber() - Method in class org.ros.time.ClockTopicTimeProvider
 
getSubscriberConnections(DefaultSubscriber<?>) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
getSubscribers() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Get all known topics subscribed to by the node.
getSubscribers() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Get a list of all known subscribers for the topic.
getSubscribers() - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
getSubscribers() - Method in class org.ros.master.client.TopicSystemState
Get the set of all nodes that subscribe to the topic.
getSubscriptions() - Method in class org.ros.internal.node.client.SlaveClient
 
getSubscriptions() - Method in class org.ros.internal.node.server.SlaveServer
 
getSubscriptions(String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
getSubscriptions(String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
getSupportedProtocols() - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
getSystemState(GraphName) - Method in class org.ros.internal.node.client.MasterClient
 
getSystemState() - Method in class org.ros.internal.node.server.master.MasterServer
Get the state of the ROS graph.
getSystemState(String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Retrieve list representation of system state (i.e.
getSystemState(String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getSystemState() - Method in class org.ros.master.client.MasterStateClient
 
getTargetFrame() - Method in class org.ros.rosjava_geometry.FrameTransform
 
getTcpRosAdvertiseAddress() - Method in class org.ros.internal.node.server.SlaveServer
 
getTcpRosAdvertiseAddress() - Method in class org.ros.node.NodeConfiguration
 
getTcpRosAdvertiseAddressFactory() - Method in class org.ros.node.NodeConfiguration
 
getTcpRosBindAddress() - Method in class org.ros.node.NodeConfiguration
 
getTime() - Method in class org.ros.rosjava_geometry.FrameTransform
 
getTimeProvider() - Method in class org.ros.node.NodeConfiguration
 
getTopicDeclaration() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
 
getTopicDeclarationAsList() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
 
getTopicDeclarationHeader() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
 
getTopicDescriptionFactory() - Method in class org.ros.node.NodeConfiguration
 
getTopicIdentifier() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
getTopicIdentifier() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
getTopicMessageFactory() - Method in class org.ros.internal.node.DefaultNode
 
getTopicMessageFactory() - Method in interface org.ros.node.Node
 
getTopicMessageFactory() - Method in class org.ros.node.NodeConfiguration
 
getTopicMessageType() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
 
getTopicMessageType() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
getTopicMessageType() - Method in interface org.ros.internal.node.topic.TopicParticipant
 
getTopicName() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
 
getTopicName() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
 
getTopicName() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
getTopicName() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
getTopicName() - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
getTopicName() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
getTopicName() - Method in interface org.ros.internal.node.topic.TopicParticipant
 
getTopicName() - Method in class org.ros.master.client.TopicSystemState
 
getTopicRegistrationInfo(GraphName) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Get the information known about a topic.
getTopics() - Method in class org.ros.master.client.SystemState
Get all topics in the system state.
getTopicTypes(GraphName) - Method in class org.ros.internal.node.client.MasterClient
Get a List of all TopicSystemState message types.
getTopicTypes(GraphName) - Method in class org.ros.internal.node.server.master.MasterServer
Get a List of all TopicSystemState message types.
getTopicTypes(String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Get a list of all topic types.
getTopicTypes(String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getTopicTypes() - Method in class org.ros.master.client.MasterStateClient
 
getTransform() - Method in class org.ros.rosjava_geometry.FrameTransform
 
getType() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
getUri(GraphName) - Method in class org.ros.internal.node.client.MasterClient
 
getUri() - Method in class org.ros.internal.node.DefaultNode
 
getUri() - Method in class org.ros.internal.node.server.NodeIdentifier
 
getUri() - Method in class org.ros.internal.node.server.XmlRpcServer
 
getUri() - Method in class org.ros.internal.node.service.DefaultServiceServer
 
getUri() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
getUri() - Method in class org.ros.internal.node.service.ServiceIdentifier
 
getUri() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
getUri(String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Get the URI of the the master.
getUri(String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
getUri() - Method in class org.ros.master.client.MasterStateClient
 
getUri() - Method in interface org.ros.node.Node
 
getUri() - Method in interface org.ros.node.service.ServiceServer
 
getUri() - Method in class org.ros.RosCore
 
getW() - Method in class org.ros.rosjava_geometry.Quaternion
 
getX() - Method in class org.ros.rosjava_geometry.Quaternion
 
getX() - Method in class org.ros.rosjava_geometry.Vector3
 
getXmlRpcAdvertiseAddress() - Method in class org.ros.node.NodeConfiguration
 
getXmlRpcAdvertiseAddressFactory() - Method in class org.ros.node.NodeConfiguration
 
getXmlRpcBindAddress() - Method in class org.ros.node.NodeConfiguration
 
getY() - Method in class org.ros.rosjava_geometry.Quaternion
 
getY() - Method in class org.ros.rosjava_geometry.Vector3
 
getZ() - Method in class org.ros.rosjava_geometry.Quaternion
 
getZ() - Method in class org.ros.rosjava_geometry.Vector3
 
GraphName - Class in org.ros.namespace
ROS graph resource name.

H

handleInterruptedException(InterruptedException) - Method in class org.ros.concurrent.CancellableLoop
An InterruptedException was thrown.
handleInterruptedException(InterruptedException) - Method in class org.ros.internal.transport.queue.MessageDispatcher
 
handshake(ConnectionHeader) - Method in class org.ros.internal.node.service.ServiceClientHandshake
 
handshake(ConnectionHeader) - Method in class org.ros.internal.node.topic.SubscriberHandshake
 
handshake(ConnectionHeader) - Method in interface org.ros.internal.transport.ClientHandshake
 
HANDSHAKE_HANDLER - Static variable in class org.ros.internal.transport.tcp.TcpServerPipelineFactory
 
has(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
has(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
has(GraphName) - Method in class org.ros.internal.node.server.ParameterServer
 
has(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
has(String) - Method in class org.ros.node.AnonymousParmeterTree
 
has(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
 
has(String) - Method in interface org.ros.node.parameter.ParameterTree
 
hasClient(GraphName) - Method in class org.ros.internal.node.service.ServiceManager
 
hasField(String) - Method in class org.ros.internal.transport.ConnectionHeader
 
hashCode() - Method in class org.ros.address.AdvertiseAddress
 
hashCode() - Method in class org.ros.address.BindAddress
 
hashCode() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
 
hashCode() - Method in class org.ros.internal.node.server.master.ServiceRegistrationInfo
 
hashCode() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
 
hashCode() - Method in class org.ros.internal.node.server.NodeIdentifier
 
hashCode() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
hashCode() - Method in class org.ros.internal.node.service.ServiceIdentifier
 
hashCode() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
hashCode() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
hashCode() - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
hashCode() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
hashCode() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
hashCode() - Method in class org.ros.internal.node.topic.TopicIdentifier
 
hashCode() - Method in class org.ros.internal.transport.ConnectionHeader
 
hashCode() - Method in class org.ros.internal.transport.ProtocolDescription
 
hashCode() - Method in class org.ros.namespace.GraphName
 
hashCode() - Method in class org.ros.rosjava_geometry.FrameName
 
hashCode() - Method in class org.ros.rosjava_geometry.FrameTransform
 
hashCode() - Method in class org.ros.rosjava_geometry.Quaternion
 
hashCode() - Method in class org.ros.rosjava_geometry.Transform
 
hashCode() - Method in class org.ros.rosjava_geometry.Vector3
 
hasParam(GraphName) - Method in class org.ros.internal.node.client.ParameterClient
 
hasParam(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
hasParam(String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Check if parameter is stored on server.
hasPublisher(GraphName) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
hasPublishers() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Does the topic have any publishers?
hasRegistrations() - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Does the node have any registrations of any sort.
hasRegistrations() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Does the topic have any registrations?
hasServer(GraphName) - Method in class org.ros.internal.node.service.ServiceManager
 
hasSubscriber(GraphName) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
hasSubscribers() - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Does the topic have any subscribers?
hasSubscribers() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
hasSubscribers() - Method in interface org.ros.node.topic.Publisher
 
Holder<T> - Class in org.ros.concurrent
A mutable object that may contain a value to another object.

I

identity() - Static method in class org.ros.rosjava_geometry.Quaternion
 
identity() - Static method in class org.ros.rosjava_geometry.Transform
 
IncomingMessageQueue<T> - Class in org.ros.internal.transport.queue
 
IncomingMessageQueue(MessageDeserializer<T>, ExecutorService) - Constructor for class org.ros.internal.transport.queue.IncomingMessageQueue
 
InetAddressFactory - Class in org.ros.address
 
IntegerResultFactory - Class in org.ros.internal.node.response
 
IntegerResultFactory() - Constructor for class org.ros.internal.node.response.IntegerResultFactory
 
intToLong(int) - Static method in class org.ros.math.Unsigned
 
invert() - Method in class org.ros.rosjava_geometry.FrameTransform
 
invert() - Method in class org.ros.rosjava_geometry.Quaternion
 
invert() - Method in class org.ros.rosjava_geometry.Transform
 
invert() - Method in class org.ros.rosjava_geometry.Vector3
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
isAlmostNeutral(double) - Method in class org.ros.rosjava_geometry.Quaternion
 
isEmpty() - Method in class org.ros.concurrent.CircularBlockingDeque
 
isEmpty() - Method in class org.ros.namespace.GraphName
 
isGlobal() - Method in class org.ros.namespace.GraphName
Is this a /global/name? If node node1 in the global / namespace accesses the resource /bar, that will resolve to the name /bar. If node node2 in the /wg/ namespace accesses the resource /foo, that will resolve to the name /foo. If node node3 in the /wg/ namespace accesses the resource /foo/bar, that will resolve to the name /foo/bar.
isLoopbackAddress() - Method in class org.ros.address.AdvertiseAddress
 
isObjectMethodLocal() - Method in class org.ros.internal.node.xmlrpc.XmlRpcClientFactory
Returns, whether a method declared by the Object class is performed by the local object, rather than by the server.
isPrivate() - Method in class org.ros.namespace.GraphName
Is this a ~private/name? If node node1 in the global / namespace accesses the resource ~bar, that will resolve to the name /node1/bar.
isRelative() - Method in class org.ros.namespace.GraphName
Is this a relative/name? If node node1 in the global / namespace accesses the resource ~bar, that will resolve to the name /node1/bar.
isRoot() - Method in class org.ros.namespace.GraphName
 
isRunning() - Method in class org.ros.concurrent.CancellableLoop
 
isShutdown() - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
isShutdown() - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
isSuccess() - Method in class org.ros.internal.node.response.Response
 
isTerminated() - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
isTerminated() - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
iterator() - Method in class org.ros.concurrent.CircularBlockingDeque
Returns an iterator over the queue.

J

join(GraphName) - Method in class org.ros.namespace.GraphName
Join this GraphName with another.
join(String) - Method in class org.ros.namespace.GraphName
 

L

LATCHING - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
LazyFrameTransform - Class in org.ros.rosjava_geometry
Lazily converts a Transform message to a Transform on the first call to LazyFrameTransform.get() and caches the result.
LazyFrameTransform(TransformStamped) - Constructor for class org.ros.rosjava_geometry.LazyFrameTransform
 
LazyMessage<T> - Class in org.ros.internal.transport.queue
Lazily deserializes a message on the first call to LazyMessage.get() and caches the result.
LazyMessage(ChannelBuffer, MessageDeserializer<T>) - Constructor for class org.ros.internal.transport.queue.LazyMessage
 
LENGTH_FIELD_BASED_FRAME_DECODER - Static variable in class org.ros.internal.transport.tcp.TcpClientPipelineFactory
 
LENGTH_FIELD_BASED_FRAME_DECODER - Static variable in class org.ros.internal.transport.tcp.TcpServerPipelineFactory
 
LENGTH_FIELD_PREPENDER - Static variable in class org.ros.internal.transport.tcp.TcpClientPipelineFactory
 
LENGTH_FIELD_PREPENDER - Static variable in class org.ros.internal.transport.tcp.TcpServerPipelineFactory
 
Listener - Class in org.ros.rosjava_tutorial_pubsub
Listener() - Constructor for class org.ros.rosjava_tutorial_pubsub.Listener
 
ListenerGroup<T> - Class in org.ros.concurrent
A group of listeners.
ListenerGroup(ExecutorService) - Constructor for class org.ros.concurrent.ListenerGroup
 
loadClass(String) - Method in class org.ros.internal.loader.CommandLineLoader
 
LOCALHOST - Static variable in interface org.ros.address.Address
 
lookUp(FrameName) - Method in class org.ros.rosjava_geometry.FrameTransformTree
Returns the most recent FrameTransform for target source.
lookUp(FrameName, Time) - Method in class org.ros.rosjava_geometry.FrameTransformTree
Returns the FrameTransform for source closest to time.
lookupNode(GraphName, String) - Method in class org.ros.internal.node.client.MasterClient
 
lookupNode(GraphName) - Method in class org.ros.internal.node.server.master.MasterServer
Returns a NodeIdentifier for the Node with the given name.
lookupNode(String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Get the XML-RPC URI of the node with the associated name/caller_id.
lookupNode(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
lookupNode(String) - Method in class org.ros.master.client.MasterStateClient
 
lookUpRemapping(GraphName) - Method in class org.ros.namespace.NameResolver
 
lookupService(GraphName, String) - Method in class org.ros.internal.node.client.MasterClient
 
lookupService(GraphName) - Method in class org.ros.internal.node.server.master.MasterServer
Lookup the provider of a particular service.
lookupService(String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Lookup all provider of a particular service.
lookupService(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
lookupService(String) - Method in class org.ros.master.client.MasterStateClient
 
lookupServiceUri(GraphName) - Method in class org.ros.internal.node.DefaultNode
 
lookupServiceUri(String) - Method in class org.ros.internal.node.DefaultNode
 
lookupServiceUri(GraphName) - Method in interface org.ros.node.ConnectedNode
 
lookupServiceUri(String) - Method in interface org.ros.node.ConnectedNode
 
loop() - Method in class org.ros.concurrent.CancellableLoop
The body of the loop.
loop() - Method in class org.ros.concurrent.EventDispatcher
 
loop() - Method in class org.ros.internal.transport.queue.MessageDispatcher
 
LOOPBACK - Static variable in interface org.ros.address.Address
 

M

main(String[]) - Static method in class org.ros.RosRun
 
MasterClient - Class in org.ros.internal.node.client
Provides access to the XML-RPC API exposed by a MasterServer.
MasterClient(URI) - Constructor for class org.ros.internal.node.client.MasterClient
Create a new MasterClient connected to the specified MasterServer URI.
MasterRegistrationListener - Interface in org.ros.internal.node.server.master
Listen for master registration events from the MasterRegistrationManagerImpl.
MasterRegistrationManagerImpl - Class in org.ros.internal.node.server.master
Manages all registration logic for the MasterServer.
MasterRegistrationManagerImpl(MasterRegistrationListener) - Constructor for class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
 
MasterServer - Class in org.ros.internal.node.server.master
The MasterServer provides naming and registration services to the rest of the Nodes in the ROS system.
MasterServer(BindAddress, AdvertiseAddress) - Constructor for class org.ros.internal.node.server.master.MasterServer
 
MasterStateClient - Class in org.ros.master.client
A remote client for obtaining system information from a master.
MasterStateClient(Node, URI) - Constructor for class org.ros.master.client.MasterStateClient
 
MasterUriProvider - Interface in org.ros.master.uri
Provides URLs for a ROS master.
MasterXmlRpcEndpoint - Interface in org.ros.internal.node.xmlrpc
An XML-RPC endpoint description of a ROS master.
MasterXmlRpcEndpointImpl - Class in org.ros.internal.node.xmlrpc
A combined XML-RPC endpoint for the master and parameter servers.
MasterXmlRpcEndpointImpl(MasterServer) - Constructor for class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
MD5_CHECKSUM - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
median(Collection<T>) - Static method in class org.ros.math.CollectionMath
 
merge(ConnectionHeader) - Method in class org.ros.internal.transport.ConnectionHeader
 
mergeFields(Map<String, String>) - Method in class org.ros.internal.transport.ConnectionHeader
 
MESSAGE_DEFINITION - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
MessageDispatcher<T> - Class in org.ros.internal.transport.queue
 
MessageDispatcher(CircularBlockingDeque<LazyMessage<T>>, ExecutorService) - Constructor for class org.ros.internal.transport.queue.MessageDispatcher
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.ros.internal.transport.BaseClientHandshakeHandler
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.ros.internal.transport.queue.MessageReceiver
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.ros.internal.transport.tcp.TcpServerHandshakeHandler
 
MessageReceiver<T> - Class in org.ros.internal.transport.queue
 
MessageReceiver(CircularBlockingDeque<LazyMessage<T>>, MessageDeserializer<T>) - Constructor for class org.ros.internal.transport.queue.MessageReceiver
 
MessagesBenchmark - Class in org.ros.rosjava_benchmarks
 
MessagesBenchmark() - Constructor for class org.ros.rosjava_benchmarks.MessagesBenchmark
 
MessageSerializationTestNode - Class in org.ros
 
MessageSerializationTestNode() - Constructor for class org.ros.MessageSerializationTestNode
 
multiply(Quaternion) - Method in class org.ros.rosjava_geometry.Quaternion
 
multiply(Transform) - Method in class org.ros.rosjava_geometry.Transform
Apply another Transform to this Transform.

N

NamedChannelHandler - Interface in org.ros.internal.transport.tcp
 
NameResolver - Class in org.ros.namespace
 
NameResolver(GraphName, Map<GraphName, GraphName>) - Constructor for class org.ros.namespace.NameResolver
 
newAnonymous() - Static method in class org.ros.namespace.GraphName
Creates an anonymous GraphName.
newChild(GraphName) - Method in class org.ros.namespace.NameResolver
Construct a new child NameResolver with the same remappings as this NameResolver.
newChild(String) - Method in class org.ros.namespace.NameResolver
 
newClient(ServiceDeclaration, MessageSerializer<T>, MessageDeserializer<S>, MessageFactory) - Method in class org.ros.internal.node.service.ServiceFactory
Gets or creates a DefaultServiceClient instance.
newCollectionFromUris(Collection<URI>, TopicDeclaration) - Static method in class org.ros.internal.node.topic.PublisherIdentifier
 
newDefault() - Method in interface org.ros.address.AdvertiseAddressFactory
 
newDefault() - Method in class org.ros.address.PrivateAdvertiseAddressFactory
 
newDefault() - Method in class org.ros.address.PublicAdvertiseAddressFactory
 
newDefault(GraphName, ServiceDeclaration, MessageSerializer<S>, MessageDeserializer<T>, MessageFactory, ScheduledExecutorService) - Static method in class org.ros.internal.node.service.DefaultServiceClient
 
newDefault(NodeIdentifier, TopicDeclaration, ScheduledExecutorService, MessageDeserializer<S>) - Static method in class org.ros.internal.node.topic.DefaultSubscriber
 
newDefault() - Static method in class org.ros.node.DefaultNodeMainExecutor
 
newDefault(ScheduledExecutorService) - Static method in class org.ros.node.DefaultNodeMainExecutor
 
newDefault() - Static method in class org.ros.node.service.CountDownServiceServerListener
Construct a CountDownServiceServerListener with all counts set to 1.
newDefault() - Static method in class org.ros.node.topic.CountDownPublisherListener
 
newDefault() - Static method in class org.ros.node.topic.CountDownSubscriberListener
Construct a CountDownSubscriberListener with all counts set to 1.
newDefault(TimeProvider, Callable<Double>, double, double, int, double) - Static method in class org.ros.time.RemoteUptimeClock
The provided Callable should return the current measuredRemoteUptime of the remote clock with minimal overhead since the run time of this call will be used to further improve the estimation of measuredRemoteUptime.
newEmpty() - Static method in class org.ros.concurrent.Holder
 
newError(String, T) - Static method in class org.ros.internal.node.response.Response
 
newFailure(String, T) - Static method in class org.ros.internal.node.response.Response
 
newFromCounts(int, int, int, int) - Static method in class org.ros.node.service.CountDownServiceServerListener
 
newFromCounts(int, int, int, int, int) - Static method in class org.ros.node.topic.CountDownPublisherListener
 
newFromCounts(int, int, int, int, int) - Static method in class org.ros.node.topic.CountDownSubscriberListener
 
newFromHeader(Map<String, String>) - Static method in class org.ros.internal.node.topic.SubscriberDeclaration
Creates a subscriber definition from the headers in a connection header.
newFromHeader(Map<String, String>) - Static method in class org.ros.internal.node.topic.TopicDeclaration
 
newFromHostString(String) - Static method in class org.ros.address.InetAddressFactory
Creates an InetAddress with both an IP and a host set so that no further resolving will take place.
newFromNamespace(GraphName) - Static method in class org.ros.namespace.NameResolver
 
newFromNamespace(String) - Static method in class org.ros.namespace.NameResolver
 
newFromNamespaceAndRemappings(String, Map<GraphName, GraphName>) - Static method in class org.ros.namespace.NameResolver
 
newFromNodeIdentifier(NodeIdentifier, URI, NameResolver, ParameterManager) - Static method in class org.ros.internal.node.parameter.DefaultParameterTree
 
newFromNodeIdentifier(NodeIdentifier, TopicDeclaration) - Static method in class org.ros.internal.node.topic.PublisherDeclaration
 
newFromStrings(String, String, String) - Static method in class org.ros.internal.node.topic.PublisherIdentifier
 
newFromTopicName(GraphName, TopicDescription) - Static method in class org.ros.internal.node.topic.TopicDeclaration
 
newFromValue(Object) - Method in class org.ros.internal.node.response.BooleanResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.IntegerResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.ObjectResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.ProtocolDescriptionResultFactory
 
newFromValue(Object) - Method in interface org.ros.internal.node.response.ResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.StringListResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.StringResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.SystemStateResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.TopicListResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.TopicTypeListResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.UriListResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.UriResultFactory
 
newFromValue(Object) - Method in class org.ros.internal.node.response.VoidResultFactory
 
newInstance(ClassLoader, Class<T>, String, int) - Method in class org.ros.internal.node.xmlrpc.XmlRpcClientFactory
Creates an object, which is implementing the given interface.
newLoopback() - Static method in class org.ros.address.InetAddressFactory
 
newMessage() - Method in class org.ros.internal.node.service.DefaultServiceClient
 
newMessage() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
newMessage() - Method in interface org.ros.node.service.ServiceClient
 
newMessage() - Method in interface org.ros.node.topic.Publisher
Create a new message.
newNode(NodeConfiguration, Collection<NodeListener>) - Method in class org.ros.node.DefaultNodeFactory
 
newNode(NodeConfiguration) - Method in class org.ros.node.DefaultNodeFactory
 
newNode(NodeConfiguration) - Method in interface org.ros.node.NodeFactory
Build a new Node with the given NodeConfiguration.
newNode(NodeConfiguration, Collection<NodeListener>) - Method in interface org.ros.node.NodeFactory
Build a new Node with the given NodeConfiguration and NodeListeners.
newNonLoopback() - Static method in class org.ros.address.InetAddressFactory
 
newOrExisting(TopicDeclaration, MessageSerializer<T>) - Method in class org.ros.internal.node.topic.PublisherFactory
Gets or creates a Publisher instance.
newOrExisting(TopicDeclaration, MessageDeserializer<T>) - Method in class org.ros.internal.node.topic.SubscriberFactory
Gets or creates a Subscriber instance.
newPrivate() - Static method in class org.ros.address.AdvertiseAddress
 
newPrivate(int) - Static method in class org.ros.address.BindAddress
 
newPrivate() - Static method in class org.ros.address.BindAddress
 
newPrivate(URI) - Static method in class org.ros.node.NodeConfiguration
Creates a new NodeConfiguration for a Node that is only accessible on the local host.
newPrivate() - Static method in class org.ros.node.NodeConfiguration
Creates a new NodeConfiguration for a Node that is only accessible on the local host.
newPrivate(int) - Static method in class org.ros.RosCore
 
newPrivate() - Static method in class org.ros.RosCore
 
newPublic() - Static method in class org.ros.address.AdvertiseAddress
Best effort method, returns a new AdvertiseAddress where the host is determined automatically.
newPublic(int) - Static method in class org.ros.address.BindAddress
 
newPublic() - Static method in class org.ros.address.BindAddress
 
newPublic(String, URI) - Static method in class org.ros.node.NodeConfiguration
Creates a new NodeConfiguration for a publicly accessible Node.
newPublic(String) - Static method in class org.ros.node.NodeConfiguration
Creates a new NodeConfiguration for a publicly accessible Node.
newPublic(String, int) - Static method in class org.ros.RosCore
 
newPublic(int) - Static method in class org.ros.RosCore
 
newPublic() - Static method in class org.ros.RosCore
 
newPublisher(GraphName, String) - Method in class org.ros.internal.node.DefaultNode
 
newPublisher(String, String) - Method in class org.ros.internal.node.DefaultNode
 
newPublisher(GraphName, String) - Method in interface org.ros.node.ConnectedNode
 
newPublisher(String, String) - Method in interface org.ros.node.ConnectedNode
 
newRequestHandler() - Method in class org.ros.internal.node.service.DefaultServiceServer
 
newRoot() - Static method in class org.ros.namespace.NameResolver
 
newRootFromRemappings(Map<GraphName, GraphName>) - Static method in class org.ros.namespace.NameResolver
 
newServer(ServiceDeclaration, ServiceResponseBuilder<T, S>, MessageDeserializer<T>, MessageSerializer<S>, MessageFactory) - Method in class org.ros.internal.node.service.ServiceFactory
Creates a DefaultServiceServer instance and registers it with the master.
newServiceClient(GraphName, String) - Method in class org.ros.internal.node.DefaultNode
 
newServiceClient(String, String) - Method in class org.ros.internal.node.DefaultNode
 
newServiceClient(GraphName, String) - Method in interface org.ros.node.ConnectedNode
Create a ServiceClient.
newServiceClient(String, String) - Method in interface org.ros.node.ConnectedNode
 
newServiceServer(GraphName, String, ServiceResponseBuilder<T, S>) - Method in class org.ros.internal.node.DefaultNode
 
newServiceServer(String, String, ServiceResponseBuilder<T, S>) - Method in class org.ros.internal.node.DefaultNode
 
newServiceServer(GraphName, String, ServiceResponseBuilder<T, S>) - Method in interface org.ros.node.ConnectedNode
Create a new ServiceServer.
newServiceServer(String, String, ServiceResponseBuilder<T, S>) - Method in interface org.ros.node.ConnectedNode
 
newSubscriber(GraphName, String) - Method in class org.ros.internal.node.DefaultNode
 
newSubscriber(String, String) - Method in class org.ros.internal.node.DefaultNode
 
newSubscriber(GraphName, String) - Method in interface org.ros.node.ConnectedNode
 
newSubscriber(String, String) - Method in interface org.ros.node.ConnectedNode
 
newSuccess(String, T) - Static method in class org.ros.internal.node.response.Response
 
Node - Interface in org.ros.node
A node in the ROS graph.
NODE_NAME - Static variable in interface org.ros.CommandLineVariables
 
NodeConfiguration - Class in org.ros.node
Stores configuration information (e.g.
NodeFactory - Interface in org.ros.node
Builds new Nodes.
NodeIdentifier - Class in org.ros.internal.node.server
A node slave identifier which combines the node name of a node with the URI for contacting the node's XMLRPC server.
NodeIdentifier(GraphName, URI) - Constructor for class org.ros.internal.node.server.NodeIdentifier
Constructs a new NodeIdentifier.
NodeListener - Interface in org.ros.node
A listener for lifecycle events on a Node.
NodeMain - Interface in org.ros.node
Encapsulates a Node with its associated program logic.
NodeMainExecutor - Interface in org.ros.node
Executes NodeMains and allows shutting down individual NodeMains or all currently running NodeMains as a group.
NodeNameResolver - Class in org.ros.namespace
Resolver for Node names.
NodeNameResolver(GraphName, NameResolver) - Constructor for class org.ros.namespace.NodeNameResolver
 
NodeRegistrationInfo - Class in org.ros.internal.node.server.master
Information a master needs about a node.
NodeRegistrationInfo(GraphName, URI) - Constructor for class org.ros.internal.node.server.master.NodeRegistrationInfo
 
normalize() - Method in class org.ros.rosjava_geometry.Quaternion
 
normalize() - Method in class org.ros.rosjava_geometry.Vector3
 
NtpTimeProvider - Class in org.ros.time
Provides NTP synchronized wallclock (actual) time.
NtpTimeProvider(InetAddress, ScheduledExecutorService) - Constructor for class org.ros.time.NtpTimeProvider
 

O

ObjectResultFactory - Class in org.ros.internal.node.response
 
ObjectResultFactory() - Constructor for class org.ros.internal.node.response.ObjectResultFactory
 
of(String) - Static method in class org.ros.namespace.GraphName
Returns a new GraphName of the specified GraphName.name.
of(String) - Static method in class org.ros.rosjava_geometry.FrameName
 
onError(Node, Throwable) - Method in class org.ros.MessageSerializationTestNode
 
onError(Node, Throwable) - Method in class org.ros.node.AbstractNodeMain
 
onError(Node, Throwable) - Method in class org.ros.node.DefaultNodeListener
 
onError(Node, Throwable) - Method in interface org.ros.node.NodeListener
Called when the Node experiences an unrecoverable error.
onFailure(String, ChannelHandlerContext, MessageEvent) - Method in class org.ros.internal.transport.BaseClientHandshakeHandler
 
onFailure(ConnectionHeader, String) - Method in interface org.ros.internal.transport.ClientHandshakeListener
Called when the ClientHandshake fails.
onFailure(RemoteException) - Method in interface org.ros.node.service.ServiceResponseListener
Called when a service method fails to return successfully.
onMasterRegistrationFailure(T) - Method in class org.ros.internal.node.CountDownRegistrantListener
 
onMasterRegistrationFailure(T) - Method in interface org.ros.internal.node.RegistrantListener
The registrant has failed to register with the master.
onMasterRegistrationFailure(ServiceServer<T, S>) - Method in class org.ros.node.service.DefaultServiceServerListener
 
onMasterRegistrationFailure(Publisher<T>) - Method in class org.ros.node.topic.DefaultPublisherListener
 
onMasterRegistrationFailure(Subscriber<T>) - Method in class org.ros.node.topic.DefaultSubscriberListener
 
onMasterRegistrationSuccess(T) - Method in class org.ros.internal.node.CountDownRegistrantListener
 
onMasterRegistrationSuccess(T) - Method in interface org.ros.internal.node.RegistrantListener
The registrant has been registered with the master.
onMasterRegistrationSuccess(ServiceServer<T, S>) - Method in class org.ros.node.service.DefaultServiceServerListener
 
onMasterRegistrationSuccess(Publisher<T>) - Method in class org.ros.node.topic.DefaultPublisherListener
 
onMasterRegistrationSuccess(Subscriber<T>) - Method in class org.ros.node.topic.DefaultSubscriberListener
 
onMasterUnregistrationFailure(T) - Method in class org.ros.internal.node.CountDownRegistrantListener
 
onMasterUnregistrationFailure(T) - Method in interface org.ros.internal.node.RegistrantListener
The registrant has failed to unregister with the master.
onMasterUnregistrationFailure(ServiceServer<T, S>) - Method in class org.ros.node.service.DefaultServiceServerListener
 
onMasterUnregistrationFailure(Publisher<T>) - Method in class org.ros.node.topic.DefaultPublisherListener
 
onMasterUnregistrationFailure(Subscriber<T>) - Method in class org.ros.node.topic.DefaultSubscriberListener
 
onMasterUnregistrationSuccess(T) - Method in class org.ros.internal.node.CountDownRegistrantListener
 
onMasterUnregistrationSuccess(T) - Method in interface org.ros.internal.node.RegistrantListener
The registrant has been unregistered with the master.
onMasterUnregistrationSuccess(ServiceServer<T, S>) - Method in class org.ros.node.service.DefaultServiceServerListener
 
onMasterUnregistrationSuccess(Publisher<T>) - Method in class org.ros.node.topic.DefaultPublisherListener
 
onMasterUnregistrationSuccess(Subscriber<T>) - Method in class org.ros.node.topic.DefaultSubscriberListener
 
onNewPublisher(Subscriber<T>, PublisherIdentifier) - Method in class org.ros.node.topic.CountDownSubscriberListener
 
onNewPublisher(Subscriber<T>, PublisherIdentifier) - Method in class org.ros.node.topic.DefaultSubscriberListener
 
onNewPublisher(Subscriber<T>, PublisherIdentifier) - Method in interface org.ros.node.topic.SubscriberListener
A new Publisher has connected to the Subscriber.
onNewSubscriber(Publisher<T>, SubscriberIdentifier) - Method in class org.ros.node.topic.CountDownPublisherListener
 
onNewSubscriber(Publisher<T>, SubscriberIdentifier) - Method in class org.ros.node.topic.DefaultPublisherListener
 
onNewSubscriber(Publisher<T>, SubscriberIdentifier) - Method in interface org.ros.node.topic.PublisherListener
A Subscriber has connected to the Publisher.
onNewValue(Object) - Method in interface org.ros.node.parameter.ParameterListener
 
onNodeReplacement(NodeRegistrationInfo) - Method in interface org.ros.internal.node.server.master.MasterRegistrationListener
A node is being replaced.
onNodeReplacement(NodeRegistrationInfo) - Method in class org.ros.internal.node.server.master.MasterServer
 
onPublisherAdded(DefaultPublisher<?>) - Method in class org.ros.internal.node.client.Registrar
 
onPublisherAdded(DefaultPublisher<?>) - Method in interface org.ros.internal.node.topic.TopicParticipantManagerListener
Called when a new Publisher is added.
onPublisherRemoved(DefaultPublisher<?>) - Method in class org.ros.internal.node.client.Registrar
 
onPublisherRemoved(DefaultPublisher<?>) - Method in interface org.ros.internal.node.topic.TopicParticipantManagerListener
Called when a new Publisher is removed.
onServiceServerAdded(DefaultServiceServer<?, ?>) - Method in class org.ros.internal.node.client.Registrar
 
onServiceServerAdded(DefaultServiceServer<?, ?>) - Method in interface org.ros.internal.node.service.ServiceManagerListener
Called when a new ServiceServer is added.
onServiceServerRemoved(DefaultServiceServer<?, ?>) - Method in class org.ros.internal.node.client.Registrar
 
onServiceServerRemoved(DefaultServiceServer<?, ?>) - Method in interface org.ros.internal.node.service.ServiceManagerListener
Called when a new ServiceServer is added.
onShutdown(Node) - Method in class org.ros.MessageSerializationTestNode
 
onShutdown(Node) - Method in class org.ros.node.AbstractNodeMain
 
onShutdown(Node) - Method in class org.ros.node.DefaultNodeListener
 
onShutdown(Node) - Method in interface org.ros.node.NodeListener
Called when the ConnectedNode has started shutting down.
onShutdown(ServiceServer<T, S>) - Method in class org.ros.node.service.CountDownServiceServerListener
 
onShutdown(ServiceServer<T, S>) - Method in class org.ros.node.service.DefaultServiceServerListener
 
onShutdown(ServiceServer<T, S>) - Method in interface org.ros.node.service.ServiceServerListener
 
onShutdown(Publisher<T>) - Method in class org.ros.node.topic.CountDownPublisherListener
 
onShutdown(Subscriber<T>) - Method in class org.ros.node.topic.CountDownSubscriberListener
 
onShutdown(Publisher<T>) - Method in class org.ros.node.topic.DefaultPublisherListener
 
onShutdown(Subscriber<T>) - Method in class org.ros.node.topic.DefaultSubscriberListener
 
onShutdown(Publisher<T>) - Method in interface org.ros.node.topic.PublisherListener
The Publisher has been shut down.
onShutdown(Subscriber<T>) - Method in interface org.ros.node.topic.SubscriberListener
The Subscriber has been shut down.
onShutdownComplete(Node) - Method in class org.ros.MessageSerializationTestNode
 
onShutdownComplete(Node) - Method in class org.ros.node.AbstractNodeMain
 
onShutdownComplete(Node) - Method in class org.ros.node.DefaultNodeListener
 
onShutdownComplete(Node) - Method in interface org.ros.node.NodeListener
Called when the Node has shut down.
onStart(ConnectedNode) - Method in class org.ros.MessageSerializationTestNode
 
onStart(ConnectedNode) - Method in class org.ros.node.AbstractNodeMain
 
onStart(ConnectedNode) - Method in class org.ros.node.DefaultNodeListener
 
onStart(ConnectedNode) - Method in interface org.ros.node.NodeListener
Called when the Node has started and successfully connected to the master.
onStart(ConnectedNode) - Method in class org.ros.ParameterServerTestNode
 
onStart(ConnectedNode) - Method in class org.ros.PassthroughTestNode
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_benchmarks.MessagesBenchmark
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_benchmarks.PubsubBenchmark
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_benchmarks.TransformBenchmark
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_tutorial_pubsub.Listener
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_tutorial_pubsub.Talker
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_tutorial_right_hand_rule.RightHandRule
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_tutorial_services.Client
 
onStart(ConnectedNode) - Method in class org.ros.rosjava_tutorial_services.Server
 
onStart(ConnectedNode) - Method in class org.ros.SlaveApiTestNode
 
onSubscriberAdded(DefaultSubscriber<?>) - Method in class org.ros.internal.node.client.Registrar
 
onSubscriberAdded(DefaultSubscriber<?>) - Method in interface org.ros.internal.node.topic.TopicParticipantManagerListener
Called when a Subscriber is added.
onSubscriberRemoved(DefaultSubscriber<?>) - Method in class org.ros.internal.node.client.Registrar
 
onSubscriberRemoved(DefaultSubscriber<?>) - Method in interface org.ros.internal.node.topic.TopicParticipantManagerListener
Called when a Subscriber is removed.
onSuccess(ConnectionHeader, ChannelHandlerContext, MessageEvent) - Method in class org.ros.internal.transport.BaseClientHandshakeHandler
Called when the ClientHandshake succeeds and will block the network thread until it returns.
onSuccess(ConnectionHeader, ConnectionHeader) - Method in interface org.ros.internal.transport.ClientHandshakeListener
Called when the ClientHandshake completes successfully.
onSuccess(MessageType) - Method in interface org.ros.node.service.ServiceResponseListener
Called when a service method returns successfully.
org.ros - package org.ros
 
org.ros.address - package org.ros.address
Provides the classes for acquiring and representing network addresses.
org.ros.concurrent - package org.ros.concurrent
Provides utility classes for common concurrent programming operations.
org.ros.exception - package org.ros.exception
 
org.ros.internal.loader - package org.ros.internal.loader
Provides internal classes for loading node configurations.
org.ros.internal.node - package org.ros.internal.node
Provides internal classes for creating and communicating with nodes in the ROS graph.
org.ros.internal.node.client - package org.ros.internal.node.client
Provides internal classes for clients.
org.ros.internal.node.parameter - package org.ros.internal.node.parameter
Provides internal classes for working with the parameter server.
org.ros.internal.node.response - package org.ros.internal.node.response
Provides internal classes for representing RPC results.
org.ros.internal.node.server - package org.ros.internal.node.server
Provides internal classes for servers.
org.ros.internal.node.server.master - package org.ros.internal.node.server.master
Provides internal classes for the server side of the master.
org.ros.internal.node.service - package org.ros.internal.node.service
Provides internal classes for working with services.
org.ros.internal.node.topic - package org.ros.internal.node.topic
Provides internal classes for working with topics.
org.ros.internal.node.xmlrpc - package org.ros.internal.node.xmlrpc
Provides internal classes for working with the ROS XML-RPC layer.
org.ros.internal.system - package org.ros.internal.system
Provides internal utility classes for system operations.
org.ros.internal.transport - package org.ros.internal.transport
Provides internal classes that are core to the implementation of rosjava.
org.ros.internal.transport.queue - package org.ros.internal.transport.queue
 
org.ros.internal.transport.tcp - package org.ros.internal.transport.tcp
Provides internal classes for implementing TCPROS.
org.ros.master.client - package org.ros.master.client
Provides the classes for communicating with the master.
org.ros.master.uri - package org.ros.master.uri
Provides the classes for representing master URIs.
org.ros.math - package org.ros.math
Provides utility classes for common mathematical operations.
org.ros.namespace - package org.ros.namespace
Provides the classes for representing names in the ROS graph.
org.ros.node - package org.ros.node
Provides the classes for creating and communicating with nodes in the ROS graph.
org.ros.node.parameter - package org.ros.node.parameter
Provides the classes for accessing and modifying parameters.
org.ros.node.service - package org.ros.node.service
Provides the classes for communicating via services.
org.ros.node.topic - package org.ros.node.topic
Provides the classes for communicating via topics.
org.ros.rosjava_benchmarks - package org.ros.rosjava_benchmarks
 
org.ros.rosjava_geometry - package org.ros.rosjava_geometry
Provides the classes for common geometry operations and representations (e.g.
org.ros.rosjava_tutorial_pubsub - package org.ros.rosjava_tutorial_pubsub
 
org.ros.rosjava_tutorial_right_hand_rule - package org.ros.rosjava_tutorial_right_hand_rule
 
org.ros.rosjava_tutorial_services - package org.ros.rosjava_tutorial_services
 
org.ros.time - package org.ros.time
Provides the classes for dealing with time and clock synchronization.
outgoingConnectionHeader - Variable in class org.ros.internal.node.BaseClientHandshake
 
OutgoingMessageQueue<T> - Class in org.ros.internal.transport.queue
 
OutgoingMessageQueue(MessageSerializer<T>, ExecutorService) - Constructor for class org.ros.internal.transport.queue.OutgoingMessageQueue
 

P

ParameterClassCastException - Exception in org.ros.exception
Thrown when a requested parameter does not match the requested parameter type.
ParameterClassCastException(String) - Constructor for exception org.ros.exception.ParameterClassCastException
 
ParameterClassCastException(String, Throwable) - Constructor for exception org.ros.exception.ParameterClassCastException
 
ParameterClassCastException(Throwable) - Constructor for exception org.ros.exception.ParameterClassCastException
 
ParameterClient - Class in org.ros.internal.node.client
Provide access to the XML-RPC API for a ROS ParameterServer.
ParameterClient(NodeIdentifier, URI) - Constructor for class org.ros.internal.node.client.ParameterClient
Create a new ParameterClient connected to the specified ParameterServer URI.
ParameterListener - Interface in org.ros.node.parameter
Called when a subscribed parameter value changes.
ParameterManager - Class in org.ros.internal.node.parameter
 
ParameterManager(ExecutorService) - Constructor for class org.ros.internal.node.parameter.ParameterManager
 
ParameterNotFoundException - Exception in org.ros.exception
Thrown when a requested parameter is not found.
ParameterNotFoundException(String) - Constructor for exception org.ros.exception.ParameterNotFoundException
 
ParameterNotFoundException(String, Throwable) - Constructor for exception org.ros.exception.ParameterNotFoundException
 
ParameterNotFoundException(Throwable) - Constructor for exception org.ros.exception.ParameterNotFoundException
 
Parameters - Interface in org.ros
ROS parameters.
ParameterServer - Class in org.ros.internal.node.server
A ROS parameter server.
ParameterServer() - Constructor for class org.ros.internal.node.server.ParameterServer
 
ParameterServerTestNode - Class in org.ros
This node is used in rostest end-to-end integration tests with other client libraries.
ParameterServerTestNode() - Constructor for class org.ros.ParameterServerTestNode
 
ParameterServerXmlRpcEndpoint - Interface in org.ros.internal.node.xmlrpc
XML-RPC endpoint for a parameter server.
ParameterTree - Interface in org.ros.node.parameter
Provides access to a ParameterServer.
paramUpdate(GraphName, boolean) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, char) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, int) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, double) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, String) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, List<?>) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, Map<?, ?>) - Method in class org.ros.internal.node.client.SlaveClient
 
paramUpdate(GraphName, Object) - Method in class org.ros.internal.node.server.SlaveServer
 
paramUpdate(String, String, boolean) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
Callback from master with updated value of subscribed parameter.
paramUpdate(String, String, char) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, byte) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, short) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, int) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, double) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, List<?>) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, Vector<?>) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, Map<?, ?>) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
paramUpdate(String, String, boolean) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, char) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, byte) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, short) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, int) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, double) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, List<?>) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, Vector<?>) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
paramUpdate(String, String, Map<?, ?>) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
PassthroughTestNode - Class in org.ros
This node is used in rostest end-to-end integration tests with other client libraries.
PassthroughTestNode() - Constructor for class org.ros.PassthroughTestNode
 
peekFirst() - Method in class org.ros.concurrent.CircularBlockingDeque
Retrieves, but does not remove, the head of this queue, returning null if this queue is empty.
peekLast() - Method in class org.ros.concurrent.CircularBlockingDeque
Retrieves, but does not remove, the tail of this queue, returning null if this queue is empty.
PERSISTENT - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
printUsage() - Static method in class org.ros.RosRun
 
PrivateAdvertiseAddressFactory - Class in org.ros.address
 
PrivateAdvertiseAddressFactory() - Constructor for class org.ros.address.PrivateAdvertiseAddressFactory
 
PROBE - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
Process - Class in org.ros.internal.system
Process-related utility methods.
ProtocolDescription - Class in org.ros.internal.transport
 
ProtocolDescription(String, AdvertiseAddress) - Constructor for class org.ros.internal.transport.ProtocolDescription
 
ProtocolDescriptionResultFactory - Class in org.ros.internal.node.response
 
ProtocolDescriptionResultFactory() - Constructor for class org.ros.internal.node.response.ProtocolDescriptionResultFactory
 
ProtocolNames - Interface in org.ros.internal.transport
 
PublicAdvertiseAddressFactory - Class in org.ros.address
An AdvertiseAddressFactory which creates public (non-loopback) addresses.
PublicAdvertiseAddressFactory() - Constructor for class org.ros.address.PublicAdvertiseAddressFactory
 
PublicAdvertiseAddressFactory(String) - Constructor for class org.ros.address.PublicAdvertiseAddressFactory
 
publish(T) - Method in class org.ros.internal.node.topic.DefaultPublisher
 
publish(T) - Method in interface org.ros.node.topic.Publisher
Publishes a message.
Publisher<T> - Interface in org.ros.node.topic
Publishes messages of a given type on a given ROS topic.
PublisherDeclaration - Class in org.ros.internal.node.topic
 
PublisherDeclaration(PublisherIdentifier, TopicDeclaration) - Constructor for class org.ros.internal.node.topic.PublisherDeclaration
 
PublisherFactory - Class in org.ros.internal.node.topic
A factory for Publisher instances.
PublisherFactory(NodeIdentifier, TopicParticipantManager, MessageFactory, ScheduledExecutorService) - Constructor for class org.ros.internal.node.topic.PublisherFactory
 
PublisherIdentifier - Class in org.ros.internal.node.topic
All information needed to identify a publisher.
PublisherIdentifier(NodeIdentifier, TopicIdentifier) - Constructor for class org.ros.internal.node.topic.PublisherIdentifier
 
PublisherListener<T> - Interface in org.ros.node.topic
A lifecycle listener for Publisher instances.
publisherUpdate(GraphName, Collection<URI>) - Method in class org.ros.internal.node.client.SlaveClient
 
publisherUpdate(String, String, Collection<URI>) - Method in class org.ros.internal.node.server.SlaveServer
 
publisherUpdate(String, String, Object[]) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
publisherUpdate(String, String, Object[]) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
PubsubBenchmark - Class in org.ros.rosjava_benchmarks
 
PubsubBenchmark() - Constructor for class org.ros.rosjava_benchmarks.PubsubBenchmark
 
pulse() - Method in class org.ros.concurrent.WatchdogTimer
 

Q

Quaternion - Class in org.ros.rosjava_geometry
A quaternion.
Quaternion(double, double, double, double) - Constructor for class org.ros.rosjava_geometry.Quaternion
 

R

Rate - Interface in org.ros.concurrent
 
registerPublisher(PublisherDeclaration) - Method in class org.ros.internal.node.client.MasterClient
Registers the specified PublisherDeclaration.
registerPublisher(GraphName, URI, GraphName, String) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Register a publisher.
registerPublisher(GraphName, URI, GraphName, String) - Method in class org.ros.internal.node.server.master.MasterServer
Register the caller as a Publisher of the specified topic.
registerPublisher(String, String, String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Register the caller as a publisher the topic.
registerPublisher(String, String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
registerService(NodeIdentifier, ServiceServer<?, ?>) - Method in class org.ros.internal.node.client.MasterClient
Registers the given ServiceServer.
registerService(GraphName, URI, GraphName, URI) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Register a service.
registerService(GraphName, URI, GraphName, URI) - Method in class org.ros.internal.node.server.master.MasterServer
Register a service with the master.
registerService(String, String, String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Register the caller as a provider of the specified service.
registerService(String, String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
registerSubscriber(NodeIdentifier, Subscriber<?>) - Method in class org.ros.internal.node.client.MasterClient
Registers the given Subscriber.
registerSubscriber(GraphName, URI, GraphName, String) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Register a subscriber.
registerSubscriber(GraphName, URI, GraphName, String) - Method in class org.ros.internal.node.server.master.MasterServer
Subscribe the caller to the specified topic.
registerSubscriber(String, String, String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Subscribe the caller to the specified topic.
registerSubscriber(String, String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
RegistrantListener<T> - Interface in org.ros.internal.node
 
Registrar - Class in org.ros.internal.node.client
Manages topic, and service registrations of a SlaveServer with the MasterServer.
Registrar(MasterClient, ScheduledExecutorService) - Constructor for class org.ros.internal.node.client.Registrar
 
RemoteException - Exception in org.ros.exception
 
RemoteException(StatusCode, String) - Constructor for exception org.ros.exception.RemoteException
 
RemoteUptimeClock - Class in org.ros.time
 
removeClient(DefaultServiceClient<?, ?>) - Method in class org.ros.internal.node.service.ServiceManager
 
removePublisher(TopicRegistrationInfo) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Remove a publisher from the node.
removePublisher(NodeRegistrationInfo) - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Remove a publisher to the topic.
removePublisher(DefaultPublisher<?>) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
removePublisherConnection(DefaultPublisher<?>, SubscriberIdentifier) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
removeServer(DefaultServiceServer<?, ?>) - Method in class org.ros.internal.node.service.ServiceManager
 
removeService(ServiceRegistrationInfo) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Remove a service from the node.
removeSubscriber(TopicRegistrationInfo) - Method in class org.ros.internal.node.server.master.NodeRegistrationInfo
Remove a subscriber from the node.
removeSubscriber(NodeRegistrationInfo) - Method in class org.ros.internal.node.server.master.TopicRegistrationInfo
Remove a subscriber to the topic.
removeSubscriber(DefaultSubscriber<?>) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
removeSubscriberConnection(DefaultSubscriber<?>, PublisherIdentifier) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
RepeatingPublisher<MessageType> - Class in org.ros.internal.node.topic
Repeatedly send a message out on a given Publisher.
RepeatingPublisher(Publisher<MessageType>, MessageType, int, ScheduledExecutorService) - Constructor for class org.ros.internal.node.topic.RepeatingPublisher
 
requestTopic(GraphName, Collection<String>) - Method in class org.ros.internal.node.client.SlaveClient
 
requestTopic(String, Collection<String>) - Method in class org.ros.internal.node.server.SlaveServer
 
requestTopic(String, String, Object[]) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
Publisher node API method called by a subscriber node.
requestTopic(String, String, Object[]) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
resolve(GraphName, GraphName) - Method in class org.ros.namespace.NameResolver
Resolve name relative to namespace.
resolve(String, String) - Method in class org.ros.namespace.NameResolver
 
resolve(GraphName, String) - Method in class org.ros.namespace.NameResolver
 
resolve(String, GraphName) - Method in class org.ros.namespace.NameResolver
 
resolve(GraphName) - Method in class org.ros.namespace.NameResolver
 
resolve(String) - Method in class org.ros.namespace.NameResolver
 
resolve(GraphName) - Method in class org.ros.namespace.NodeNameResolver
 
resolve(String) - Method in class org.ros.namespace.NodeNameResolver
 
resolveName(GraphName) - Method in class org.ros.internal.node.DefaultNode
 
resolveName(String) - Method in class org.ros.internal.node.DefaultNode
 
resolveName(GraphName) - Method in interface org.ros.node.Node
Resolve the given name, using ROS conventions, into a full ROS namespace name.
resolveName(String) - Method in interface org.ros.node.Node
 
Response<T> - Class in org.ros.internal.node.response
The response from an XML-RPC call.
Response(int, String, T) - Constructor for class org.ros.internal.node.response.Response
 
Response(StatusCode, String, T) - Constructor for class org.ros.internal.node.response.Response
 
ResultFactory<T> - Interface in org.ros.internal.node.response
 
RetryingExecutorService - Class in org.ros.concurrent
Wraps an ScheduledExecutorService to execute Callables with retries.
RetryingExecutorService(ScheduledExecutorService) - Constructor for class org.ros.concurrent.RetryingExecutorService
 
RightHandRule - Class in org.ros.rosjava_tutorial_right_hand_rule
 
RightHandRule() - Constructor for class org.ros.rosjava_tutorial_right_hand_rule.RightHandRule
 
root() - Static method in class org.ros.namespace.GraphName
 
ROS_HOSTNAME - Static variable in interface org.ros.EnvironmentVariables
 
ROS_IP - Static variable in interface org.ros.CommandLineVariables
 
ROS_IP - Static variable in interface org.ros.EnvironmentVariables
 
ROS_MASTER_URI - Static variable in interface org.ros.CommandLineVariables
 
ROS_MASTER_URI - Static variable in interface org.ros.EnvironmentVariables
 
ROS_NAMESPACE - Static variable in interface org.ros.CommandLineVariables
 
ROS_NAMESPACE - Static variable in interface org.ros.EnvironmentVariables
 
ROS_PACKAGE_PATH - Static variable in interface org.ros.EnvironmentVariables
 
ROS_ROOT - Static variable in interface org.ros.EnvironmentVariables
 
RosCore - Class in org.ros
RosCore is a collection of nodes and programs that are pre-requisites of a ROS-based system.
RosException - Exception in org.ros.exception
 
RosException(Throwable) - Constructor for exception org.ros.exception.RosException
 
RosException(String, Throwable) - Constructor for exception org.ros.exception.RosException
 
RosException(String) - Constructor for exception org.ros.exception.RosException
 
RosMath - Class in org.ros.math
 
ROSOUT - Static variable in interface org.ros.Topics
 
RosRun - Class in org.ros
This is a main class entry point for executing NodeMains.
RosRun() - Constructor for class org.ros.RosRun
 
RosRuntimeException - Exception in org.ros.exception
 
RosRuntimeException(Throwable) - Constructor for exception org.ros.exception.RosRuntimeException
 
RosRuntimeException(String, Throwable) - Constructor for exception org.ros.exception.RosRuntimeException
 
RosRuntimeException(String) - Constructor for exception org.ros.exception.RosRuntimeException
 
rotateAndScaleVector(Vector3) - Method in class org.ros.rosjava_geometry.Quaternion
 
rotationBetweenVectors(Vector3, Vector3) - Static method in class org.ros.rosjava_geometry.Quaternion
 
run() - Method in class org.ros.concurrent.CancellableLoop
 
run(T) - Method in interface org.ros.concurrent.SignalRunnable
This method will be called when the listener should be signaled.

S

scale(double) - Method in class org.ros.rosjava_geometry.Quaternion
 
scale(double) - Method in class org.ros.rosjava_geometry.Transform
 
scale(double) - Method in class org.ros.rosjava_geometry.Vector3
 
schedule(Runnable, long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
schedule(Runnable, long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
search(GraphName) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
search(String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
search(GraphName) - Method in class org.ros.internal.node.server.ParameterServer
 
search(GraphName) - Method in class org.ros.node.AnonymousParmeterTree
 
search(String) - Method in class org.ros.node.AnonymousParmeterTree
 
search(GraphName) - Method in interface org.ros.node.parameter.ParameterTree
Search for parameter key on the Parameter Server.
search(String) - Method in interface org.ros.node.parameter.ParameterTree
 
searchParam(GraphName) - Method in class org.ros.internal.node.client.ParameterClient
 
searchParam(String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
searchParam(String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Searches for a parameter key on the ParameterServer.
Server - Class in org.ros.rosjava_tutorial_services
This is a simple ServiceServer NodeMain.
Server() - Constructor for class org.ros.rosjava_tutorial_services.Server
 
ServerException - Exception in org.ros.internal.node.server
 
ServerException(String) - Constructor for exception org.ros.internal.node.server.ServerException
 
ServerException(Exception) - Constructor for exception org.ros.internal.node.server.ServerException
 
Service - Class in org.ros.internal.node.service
 
Service(Service.Request, Service.Response) - Constructor for class org.ros.internal.node.service.Service
 
SERVICE - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
Service.Request - Interface in org.ros.internal.node.service
 
Service.Response - Interface in org.ros.internal.node.service
 
ServiceClient<T,S> - Interface in org.ros.node.service
Provides a connection to a ROS service.
ServiceClientHandshake - Class in org.ros.internal.node.service
Handshake logic from the client side of a service connection.
ServiceClientHandshake(ConnectionHeader) - Constructor for class org.ros.internal.node.service.ServiceClientHandshake
 
ServiceDeclaration - Class in org.ros.internal.node.service
 
ServiceDeclaration(ServiceIdentifier, ServiceDescription) - Constructor for class org.ros.internal.node.service.ServiceDeclaration
 
ServiceException - Exception in org.ros.exception
 
ServiceException(Throwable) - Constructor for exception org.ros.exception.ServiceException
 
ServiceException(String, Throwable) - Constructor for exception org.ros.exception.ServiceException
 
ServiceException(String) - Constructor for exception org.ros.exception.ServiceException
 
ServiceFactory - Class in org.ros.internal.node.service
A factory for ServiceServers and ServiceClients.
ServiceFactory(GraphName, SlaveServer, ServiceManager, ScheduledExecutorService) - Constructor for class org.ros.internal.node.service.ServiceFactory
 
ServiceIdentifier - Class in org.ros.internal.node.service
 
ServiceIdentifier(GraphName, URI) - Constructor for class org.ros.internal.node.service.ServiceIdentifier
 
ServiceManager - Class in org.ros.internal.node.service
Manages a collection of ServiceServers and ServiceClients.
ServiceManager() - Constructor for class org.ros.internal.node.service.ServiceManager
 
ServiceManagerListener - Interface in org.ros.internal.node.service
Listener ServiceManager events.
ServiceNotFoundException - Exception in org.ros.exception
 
ServiceNotFoundException(Throwable) - Constructor for exception org.ros.exception.ServiceNotFoundException
 
ServiceNotFoundException(String, Throwable) - Constructor for exception org.ros.exception.ServiceNotFoundException
 
ServiceNotFoundException(String) - Constructor for exception org.ros.exception.ServiceNotFoundException
 
ServiceRegistrationInfo - Class in org.ros.internal.node.server.master
Information a master needs about a service.
ServiceRegistrationInfo(GraphName, URI, NodeRegistrationInfo) - Constructor for class org.ros.internal.node.server.master.ServiceRegistrationInfo
 
ServiceResponseBuilder<T,S> - Interface in org.ros.node.service
Builds a service response given a service request.
ServiceResponseEncoder - Class in org.ros.internal.node.service
 
ServiceResponseEncoder() - Constructor for class org.ros.internal.node.service.ServiceResponseEncoder
 
ServiceResponseListener<MessageType> - Interface in org.ros.node.service
A listener for service responses.
ServiceServer<T,S> - Interface in org.ros.node.service
Provides a ROS service.
ServiceServerListener<T,S> - Interface in org.ros.node.service
A lifecycle listener for ServiceServer instances.
set(T) - Method in class org.ros.concurrent.Holder
 
set(GraphName, boolean) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(String, boolean) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(GraphName, int) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(String, int) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(GraphName, double) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(String, double) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(GraphName, String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(String, String) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(GraphName, List<?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(String, List<?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(GraphName, Map<?, ?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(String, Map<?, ?>) - Method in class org.ros.internal.node.parameter.DefaultParameterTree
 
set(GraphName, boolean) - Method in class org.ros.internal.node.server.ParameterServer
 
set(GraphName, int) - Method in class org.ros.internal.node.server.ParameterServer
 
set(GraphName, double) - Method in class org.ros.internal.node.server.ParameterServer
 
set(GraphName, String) - Method in class org.ros.internal.node.server.ParameterServer
 
set(GraphName, List<?>) - Method in class org.ros.internal.node.server.ParameterServer
 
set(GraphName, Map<?, ?>) - Method in class org.ros.internal.node.server.ParameterServer
 
set(GraphName, boolean) - Method in class org.ros.node.AnonymousParmeterTree
 
set(String, boolean) - Method in class org.ros.node.AnonymousParmeterTree
 
set(GraphName, int) - Method in class org.ros.node.AnonymousParmeterTree
 
set(String, int) - Method in class org.ros.node.AnonymousParmeterTree
 
set(GraphName, double) - Method in class org.ros.node.AnonymousParmeterTree
 
set(String, double) - Method in class org.ros.node.AnonymousParmeterTree
 
set(GraphName, String) - Method in class org.ros.node.AnonymousParmeterTree
 
set(String, String) - Method in class org.ros.node.AnonymousParmeterTree
 
set(GraphName, List<?>) - Method in class org.ros.node.AnonymousParmeterTree
 
set(String, List<?>) - Method in class org.ros.node.AnonymousParmeterTree
 
set(GraphName, Map<?, ?>) - Method in class org.ros.node.AnonymousParmeterTree
 
set(String, Map<?, ?>) - Method in class org.ros.node.AnonymousParmeterTree
 
set(GraphName, boolean) - Method in interface org.ros.node.parameter.ParameterTree
 
set(String, boolean) - Method in interface org.ros.node.parameter.ParameterTree
 
set(GraphName, int) - Method in interface org.ros.node.parameter.ParameterTree
 
set(String, int) - Method in interface org.ros.node.parameter.ParameterTree
 
set(GraphName, double) - Method in interface org.ros.node.parameter.ParameterTree
 
set(String, double) - Method in interface org.ros.node.parameter.ParameterTree
 
set(GraphName, String) - Method in interface org.ros.node.parameter.ParameterTree
 
set(String, String) - Method in interface org.ros.node.parameter.ParameterTree
 
set(GraphName, List<?>) - Method in interface org.ros.node.parameter.ParameterTree
 
set(String, List<?>) - Method in interface org.ros.node.parameter.ParameterTree
 
set(GraphName, Map<?, ?>) - Method in interface org.ros.node.parameter.ParameterTree
 
set(String, Map<?, ?>) - Method in interface org.ros.node.parameter.ParameterTree
 
setConnectionTimeout(long, TimeUnit) - Method in class org.ros.internal.transport.tcp.TcpClient
 
setDefaultNodeName(GraphName) - Method in class org.ros.node.NodeConfiguration
Sets the name of the Node if the name has not already been set.
setDefaultNodeName(String) - Method in class org.ros.node.NodeConfiguration
Sets the name of the Node if the name has not already been set.
setErrorMessage(String) - Method in class org.ros.internal.node.BaseClientHandshake
 
setKeepAlive(boolean) - Method in class org.ros.internal.transport.tcp.TcpClient
 
setLatchMode(boolean) - Method in class org.ros.internal.node.topic.DefaultPublisher
 
setLatchMode(boolean) - Method in class org.ros.internal.transport.queue.IncomingMessageQueue
 
setLatchMode(boolean) - Method in class org.ros.internal.transport.queue.MessageDispatcher
 
setLatchMode(boolean) - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
 
setLatchMode(boolean) - Method in interface org.ros.node.topic.Publisher
 
setListener(ServiceManagerListener) - Method in class org.ros.internal.node.service.ServiceManager
 
setListener(TopicParticipantManagerListener) - Method in class org.ros.internal.node.topic.TopicParticipantManager
 
setMasterUri(URI) - Method in class org.ros.node.NodeConfiguration
 
setMessageSerializationFactory(MessageSerializationFactory) - Method in class org.ros.node.NodeConfiguration
 
setNodeName(GraphName) - Method in class org.ros.node.NodeConfiguration
 
setNodeName(String) - Method in class org.ros.node.NodeConfiguration
 
setObjectMethodLocal(boolean) - Method in class org.ros.internal.node.xmlrpc.XmlRpcClientFactory
Sets, whether a method declared by the Object class is performed by the local object, rather than by the server.
setParam(GraphName, Boolean) - Method in class org.ros.internal.node.client.ParameterClient
 
setParam(GraphName, Integer) - Method in class org.ros.internal.node.client.ParameterClient
 
setParam(GraphName, Double) - Method in class org.ros.internal.node.client.ParameterClient
 
setParam(GraphName, String) - Method in class org.ros.internal.node.client.ParameterClient
 
setParam(GraphName, List<?>) - Method in class org.ros.internal.node.client.ParameterClient
 
setParam(GraphName, Map<?, ?>) - Method in class org.ros.internal.node.client.ParameterClient
 
setParam(String, String, Boolean) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
setParam(String, String, Integer) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
setParam(String, String, Double) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
setParam(String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
setParam(String, String, List<?>) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
setParam(String, String, Map<?, ?>) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
setParam(String, String, Boolean) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Sets a parameter.
setParam(String, String, Integer) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
 
setParam(String, String, Double) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
 
setParam(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
 
setParam(String, String, List<?>) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
 
setParam(String, String, Map<?, ?>) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
 
setParentResolver(NameResolver) - Method in class org.ros.node.NodeConfiguration
 
setPortCallable(Callable<Integer>) - Method in class org.ros.address.AdvertiseAddress
 
setRetryDelay(long, TimeUnit) - Method in class org.ros.concurrent.RetryingExecutorService
 
setRetryDelay(long, TimeUnit) - Method in class org.ros.internal.node.client.Registrar
Failed registration actions are retried periodically until they succeed.
setRosPackagePath(List<File>) - Method in class org.ros.node.NodeConfiguration
These ordered paths tell the ROS system where to search for more ROS packages.
setRosRoot(File) - Method in class org.ros.node.NodeConfiguration
 
setServiceDescriptionFactory(ServiceDescriptionFactory) - Method in class org.ros.node.NodeConfiguration
 
setServiceRequestMessageFactory(ServiceRequestMessageFactory) - Method in class org.ros.node.NodeConfiguration
 
setServiceResponseMessageFactory(ServiceResponseMessageFactory) - Method in class org.ros.node.NodeConfiguration
 
setStaticPort(int) - Method in class org.ros.address.AdvertiseAddress
 
setTcpRosAdvertiseAddressFactory(AdvertiseAddressFactory) - Method in class org.ros.node.NodeConfiguration
 
setTcpRosBindAddress(BindAddress) - Method in class org.ros.node.NodeConfiguration
 
setTimeProvider(TimeProvider) - Method in class org.ros.node.NodeConfiguration
Sets the TimeProvider that Nodes will use.
setTopicDescriptionFactory(TopicDescriptionFactory) - Method in class org.ros.node.NodeConfiguration
 
setTopicMessageFactory(MessageFactory) - Method in class org.ros.node.NodeConfiguration
 
setup() - Method in class org.ros.concurrent.CancellableLoop
The setup block for the loop.
setXmlRpcAdvertiseAddressFactory(AdvertiseAddressFactory) - Method in class org.ros.node.NodeConfiguration
 
setXmlRpcBindAddress(BindAddress) - Method in class org.ros.node.NodeConfiguration
 
SharedScheduledExecutorService - Class in org.ros.concurrent
A ScheduledExecutorService which cannot be shut down.
SharedScheduledExecutorService(ScheduledExecutorService) - Constructor for class org.ros.concurrent.SharedScheduledExecutorService
 
shortToInt(short) - Static method in class org.ros.math.Unsigned
 
shutdown() - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
shutdown() - Method in class org.ros.concurrent.ListenerGroup
 
shutdown(long, TimeUnit) - Method in class org.ros.concurrent.RetryingExecutorService
Stops accepting new Callables and waits for all submitted Callables to finish within the specified timeout.
shutdown() - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
shutdown() - Method in class org.ros.internal.node.client.Registrar
Shuts down the Registrar.
shutdown(String) - Method in class org.ros.internal.node.client.SlaveClient
 
shutdown() - Method in class org.ros.internal.node.DefaultNode
 
shutdown() - Method in class org.ros.internal.node.server.SlaveServer
 
shutdown() - Method in class org.ros.internal.node.server.XmlRpcServer
Shut the remote call server down.
shutdown() - Method in class org.ros.internal.node.service.DefaultServiceClient
 
shutdown() - Method in class org.ros.internal.node.service.DefaultServiceServer
 
shutdown(long, TimeUnit) - Method in class org.ros.internal.node.topic.DefaultPublisher
 
shutdown() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
shutdown(long, TimeUnit) - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
shutdown() - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
shutdown(String, String) - Method in interface org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpoint
 
shutdown(String, String) - Method in class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
shutdown() - Method in class org.ros.internal.transport.queue.IncomingMessageQueue
 
shutdown() - Method in class org.ros.internal.transport.queue.OutgoingMessageQueue
Stop writing messages and close all outgoing connections.
shutdown() - Method in class org.ros.internal.transport.tcp.TcpClientManager
Sets all TcpClientConnections as non-persistent and closes all open Channels.
shutdown() - Method in class org.ros.internal.transport.tcp.TcpRosServer
Close all incoming connections and the server socket.
shutdown() - Method in class org.ros.node.DefaultNodeMainExecutor
 
shutdown() - Method in interface org.ros.node.Node
Shut the node down.
shutdown() - Method in interface org.ros.node.NodeMainExecutor
Shutdown all started Nodes.
shutdown() - Method in interface org.ros.node.service.ServiceClient
Stops the client (e.g.
shutdown() - Method in interface org.ros.node.service.ServiceServer
Stops the service and unregisters it.
shutdown(long, TimeUnit) - Method in interface org.ros.node.topic.Publisher
Shuts down and unregisters the Publisher.
shutdown() - Method in interface org.ros.node.topic.Publisher
Shuts down and unregisters the Publisher using the default timeout for PublisherListener.onShutdown(Publisher) callbacks.
shutdown(long, TimeUnit) - Method in interface org.ros.node.topic.Subscriber
Shuts down and unregisters the Subscriber.
shutdown() - Method in interface org.ros.node.topic.Subscriber
Shuts down and unregisters the Subscriber using the default timeout for SubscriberListener.onShutdown(Subscriber) callbacks.
shutdown() - Method in class org.ros.RosCore
 
shutdownNodeMain(NodeMain) - Method in class org.ros.node.DefaultNodeMainExecutor
 
shutdownNodeMain(NodeMain) - Method in interface org.ros.node.NodeMainExecutor
Shuts down the supplied NodeMain (i.e.
shutdownNow() - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
shutdownNow() - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
signal(SignalRunnable<T>) - Method in class org.ros.concurrent.EventDispatcher
 
signal(SignalRunnable<T>) - Method in class org.ros.concurrent.ListenerGroup
Signals all listeners.
signal(SignalRunnable<T>, long, TimeUnit) - Method in class org.ros.concurrent.ListenerGroup
Signals all listeners and waits for the result.
signalOnMasterRegistrationFailure() - Method in class org.ros.internal.node.service.DefaultServiceServer
Signal all ServiceServerListeners that the ServiceServer has failed to register with the master.
signalOnMasterRegistrationFailure() - Method in class org.ros.internal.node.topic.DefaultPublisher
Signal all PublisherListeners that the Publisher has failed to register with the master.
signalOnMasterRegistrationFailure() - Method in class org.ros.internal.node.topic.DefaultSubscriber
Signal all SubscriberListeners that the Subscriber has failed to register with the master.
signalOnMasterRegistrationFailure() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
Signal that the TopicSystemState failed to register with the master.
signalOnMasterRegistrationSuccess() - Method in class org.ros.internal.node.service.DefaultServiceServer
Signal all ServiceServerListeners that the ServiceServer has been successfully registered with the master.
signalOnMasterRegistrationSuccess() - Method in class org.ros.internal.node.topic.DefaultPublisher
Signal all PublisherListeners that the Publisher has successfully registered with the master.
signalOnMasterRegistrationSuccess() - Method in class org.ros.internal.node.topic.DefaultSubscriber
Signal all SubscriberListeners that the Subscriber has successfully registered with the master.
signalOnMasterRegistrationSuccess() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
Signal that the TopicSystemState successfully registered with the master.
signalOnMasterUnregistrationFailure() - Method in class org.ros.internal.node.service.DefaultServiceServer
Signal all ServiceServerListeners that the ServiceServer has failed to unregister with the master.
signalOnMasterUnregistrationFailure() - Method in class org.ros.internal.node.topic.DefaultPublisher
Signal all PublisherListeners that the Publisher has failed to unregister with the master.
signalOnMasterUnregistrationFailure() - Method in class org.ros.internal.node.topic.DefaultSubscriber
Signal all SubscriberListeners that the Subscriber has failed to unregister with the master.
signalOnMasterUnregistrationFailure() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
Signal that the TopicSystemState failed to unregister with the master.
signalOnMasterUnregistrationSuccess() - Method in class org.ros.internal.node.service.DefaultServiceServer
Signal all ServiceServerListeners that the ServiceServer has been successfully unregistered with the master.
signalOnMasterUnregistrationSuccess() - Method in class org.ros.internal.node.topic.DefaultPublisher
Signal all PublisherListeners that the Publisher has successfully unregistered with the master.
signalOnMasterUnregistrationSuccess() - Method in class org.ros.internal.node.topic.DefaultSubscriber
Signal all SubscriberListeners that the Subscriber has successfully unregistered with the master.
signalOnMasterUnregistrationSuccess() - Method in class org.ros.internal.node.topic.DefaultTopicParticipant
Signal that the TopicSystemState successfully unregistered with the master.
signalOnNewPublisher(PublisherIdentifier) - Method in class org.ros.internal.node.topic.DefaultSubscriber
Signal all SubscriberListeners that a new Publisher has connected.
SignalRunnable<T> - Interface in org.ros.concurrent
Decouples specific listener interfaces from the signaling implementation.
size() - Method in class org.ros.concurrent.ListenerGroup
 
SlaveApiTestNode - Class in org.ros
This node is used to test the slave API externally using rostest.
SlaveApiTestNode() - Constructor for class org.ros.SlaveApiTestNode
 
SlaveClient - Class in org.ros.internal.node.client
 
SlaveClient(GraphName, URI) - Constructor for class org.ros.internal.node.client.SlaveClient
 
SlaveServer - Class in org.ros.internal.node.server
 
SlaveServer(GraphName, BindAddress, AdvertiseAddress, BindAddress, AdvertiseAddress, MasterClient, TopicParticipantManager, ServiceManager, ParameterManager, ScheduledExecutorService) - Constructor for class org.ros.internal.node.server.SlaveServer
 
SlaveXmlRpcEndpoint - Interface in org.ros.internal.node.xmlrpc
 
SlaveXmlRpcEndpointImpl - Class in org.ros.internal.node.xmlrpc
 
SlaveXmlRpcEndpointImpl(SlaveServer) - Constructor for class org.ros.internal.node.xmlrpc.SlaveXmlRpcEndpointImpl
 
sleep() - Method in interface org.ros.concurrent.Rate
Sleeps until the configured rate is achieved.
sleep() - Method in class org.ros.concurrent.WallTimeRate
 
start() - Method in class org.ros.concurrent.WatchdogTimer
 
start(NodeIdentifier) - Method in class org.ros.internal.node.client.Registrar
Starts the Registrar for the SlaveServer identified by the given NodeIdentifier.
start() - Method in class org.ros.internal.node.server.master.MasterServer
Start the MasterServer.
start() - Method in class org.ros.internal.node.server.SlaveServer
Start the XML-RPC server.
start(Class<T>, T) - Method in class org.ros.internal.node.server.XmlRpcServer
Start up the remote calling server.
start() - Method in class org.ros.internal.node.topic.RepeatingPublisher
 
start() - Method in class org.ros.internal.transport.tcp.TcpRosServer
 
start() - Method in class org.ros.RosCore
 
startPeriodicUpdates(long, TimeUnit) - Method in class org.ros.time.NtpTimeProvider
Starts periodically updating the current time offset periodically.
StaticMasterUriProvider - Class in org.ros.master.uri
A MasterUriProvider which will always return the same URI.
StaticMasterUriProvider(URI) - Constructor for class org.ros.master.uri.StaticMasterUriProvider
 
StatusCode - Enum in org.ros.internal.node.response
 
stopPeriodicUpdates() - Method in class org.ros.time.NtpTimeProvider
Stops periodically updating the current time offset.
StringListResultFactory - Class in org.ros.internal.node.response
 
StringListResultFactory() - Constructor for class org.ros.internal.node.response.StringListResultFactory
 
StringResultFactory - Class in org.ros.internal.node.response
 
StringResultFactory() - Constructor for class org.ros.internal.node.response.StringResultFactory
 
submit(Callable<T>) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
submit(Runnable, T) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
submit(Runnable) - Method in class org.ros.concurrent.DefaultScheduledExecutorService
 
submit(Callable<Boolean>) - Method in class org.ros.concurrent.RetryingExecutorService
Submit a new Callable to be executed.
submit(Callable<T>) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
submit(Runnable, T) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
submit(Runnable) - Method in class org.ros.concurrent.SharedScheduledExecutorService
 
subscribe(GraphName, NodeIdentifier) - Method in class org.ros.internal.node.server.ParameterServer
 
subscribeParam(GraphName) - Method in class org.ros.internal.node.client.ParameterClient
 
subscribeParam(String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
subscribeParam(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Retrieves the parameter value from server and subscribe to updates to that param.
Subscriber<T> - Interface in org.ros.node.topic
Subscribes to messages of a given type on a given ROS topic.
SubscriberDeclaration - Class in org.ros.internal.node.topic
 
SubscriberDeclaration(SubscriberIdentifier, TopicDeclaration) - Constructor for class org.ros.internal.node.topic.SubscriberDeclaration
 
SubscriberFactory - Class in org.ros.internal.node.topic
A factory for Subscriber instances.
SubscriberFactory(NodeIdentifier, TopicParticipantManager, ScheduledExecutorService) - Constructor for class org.ros.internal.node.topic.SubscriberFactory
 
SubscriberHandshake - Class in org.ros.internal.node.topic
Handshake logic from the subscriber side of a topic connection.
SubscriberHandshake(ConnectionHeader) - Constructor for class org.ros.internal.node.topic.SubscriberHandshake
 
SubscriberIdentifier - Class in org.ros.internal.node.topic
 
SubscriberIdentifier(NodeIdentifier, TopicIdentifier) - Constructor for class org.ros.internal.node.topic.SubscriberIdentifier
 
SubscriberListener<T> - Interface in org.ros.node.topic
A lifecycle listener for Subscriber instances.
subtract(Vector3) - Method in class org.ros.rosjava_geometry.Vector3
 
SUPPORTED - Static variable in interface org.ros.internal.transport.ProtocolNames
 
SwitchableMasterUriProvider - Class in org.ros.master.uri
A proxying MasterUriProvider which can be switched between providers.
SwitchableMasterUriProvider(MasterUriProvider) - Constructor for class org.ros.master.uri.SwitchableMasterUriProvider
 
SwitchableMasterUriProvider.MasterUriProviderSwitcher - Interface in org.ros.master.uri
Perform a switch between MasterUriProvider instances for the SwitchableMasterUriProvider.
switchProvider(MasterUriProvider) - Method in interface org.ros.master.uri.SwitchableMasterUriProvider.MasterUriProviderSwitcher
Switch the provider in use.
switchProvider(SwitchableMasterUriProvider.MasterUriProviderSwitcher) - Method in class org.ros.master.uri.SwitchableMasterUriProvider
Switch between providers.
SYSTEM_STATE_PUBLISHERS - Static variable in class org.ros.internal.node.server.master.MasterServer
Position in the MasterServer.getSystemState() for publisher information.
SYSTEM_STATE_SERVICES - Static variable in class org.ros.internal.node.server.master.MasterServer
Position in the MasterServer.getSystemState() for service information.
SYSTEM_STATE_SUBSCRIBERS - Static variable in class org.ros.internal.node.server.master.MasterServer
Position in the MasterServer.getSystemState() for subscriber information.
SystemState - Class in org.ros.master.client
The state of the ROS graph as understood by the master.
SystemState(Collection<TopicSystemState>) - Constructor for class org.ros.master.client.SystemState
 
SystemStateResultFactory - Class in org.ros.internal.node.response
A ResultFactory to take an object and turn it into a SystemState instance.
SystemStateResultFactory() - Constructor for class org.ros.internal.node.response.SystemStateResultFactory
 

T

takeFirst() - Method in class org.ros.concurrent.CircularBlockingDeque
Retrieves the head of the queue, blocking if necessary until an entry is available.
takeLast() - Method in class org.ros.concurrent.CircularBlockingDeque
Retrieves the tail of the queue, blocking if necessary until an entry is available.
Talker - Class in org.ros.rosjava_tutorial_pubsub
Talker() - Constructor for class org.ros.rosjava_tutorial_pubsub.Talker
 
TCP_NODELAY - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
TcpClient - Class in org.ros.internal.transport.tcp
 
TcpClient(ChannelGroup, Executor) - Constructor for class org.ros.internal.transport.tcp.TcpClient
 
TcpClientManager - Class in org.ros.internal.transport.tcp
 
TcpClientManager(Executor) - Constructor for class org.ros.internal.transport.tcp.TcpClientManager
 
TcpClientPipelineFactory - Class in org.ros.internal.transport.tcp
 
TcpClientPipelineFactory(ChannelGroup) - Constructor for class org.ros.internal.transport.tcp.TcpClientPipelineFactory
 
TCPROS - Static variable in interface org.ros.internal.transport.ProtocolNames
 
TCPROS_PORT - Static variable in interface org.ros.CommandLineVariables
 
TcpRosProtocolDescription - Class in org.ros.internal.transport.tcp
 
TcpRosProtocolDescription(AdvertiseAddress) - Constructor for class org.ros.internal.transport.tcp.TcpRosProtocolDescription
 
TcpRosServer - Class in org.ros.internal.transport.tcp
The TCP server which is used for data communication between publishers and subscribers or between a service and a service client.
TcpRosServer(BindAddress, AdvertiseAddress, TopicParticipantManager, ServiceManager, ScheduledExecutorService) - Constructor for class org.ros.internal.transport.tcp.TcpRosServer
 
TcpServerHandshakeHandler - Class in org.ros.internal.transport.tcp
A ChannelHandler which will process the TCP server handshake.
TcpServerHandshakeHandler(TopicParticipantManager, ServiceManager) - Constructor for class org.ros.internal.transport.tcp.TcpServerHandshakeHandler
 
TcpServerPipelineFactory - Class in org.ros.internal.transport.tcp
 
TcpServerPipelineFactory(ChannelGroup, TopicParticipantManager, ServiceManager) - Constructor for class org.ros.internal.transport.tcp.TcpServerPipelineFactory
 
TimeProvider - Interface in org.ros.time
Provide time.
toConnectionHeader() - Method in class org.ros.internal.node.server.NodeIdentifier
 
toConnectionHeader() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
toConnectionHeader() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
toConnectionHeader() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
toConnectionHeader() - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
toConnectionHeader() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
toConnectionHeader() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
toConnectionHeader() - Method in class org.ros.internal.node.topic.TopicIdentifier
 
toDeclaration() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
toDeclaration() - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
toGlobal() - Method in class org.ros.namespace.GraphName
Convert name to a global name representation.
toIdentifier() - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
toInetAddress() - Method in class org.ros.address.AdvertiseAddress
 
toInetSocketAddress() - Method in class org.ros.address.AdvertiseAddress
 
toInetSocketAddress() - Method in class org.ros.address.BindAddress
 
toInt() - Method in enum org.ros.internal.node.response.StatusCode
 
toList() - Method in class org.ros.internal.node.response.Response
 
toList() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
toList() - Method in class org.ros.internal.transport.ProtocolDescription
 
toLocalUptime(double) - Method in class org.ros.time.RemoteUptimeClock
Returns the estimated local uptime in seconds for the given remote uptime.
toMatrix() - Method in class org.ros.rosjava_geometry.Transform
 
toNodeIdentifier() - Method in class org.ros.internal.node.server.SlaveServer
 
TOPIC - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 
TOPIC_MESSAGE_TYPE_WILDCARD - Static variable in interface org.ros.node.topic.Subscriber
The message type given when a Subscriber chooses not to commit to a specific message type.
TopicDeclaration - Class in org.ros.internal.node.topic
A topic in a ROS graph.
TopicDeclaration(TopicIdentifier, TopicDescription) - Constructor for class org.ros.internal.node.topic.TopicDeclaration
 
TopicIdentifier - Class in org.ros.internal.node.topic
The identifier for a topic in a ROS graph.
TopicIdentifier(GraphName) - Constructor for class org.ros.internal.node.topic.TopicIdentifier
 
TopicListResultFactory - Class in org.ros.internal.node.response
A ResultFactory to take an object and turn it into a list of TopicDeclaration instances.
TopicListResultFactory() - Constructor for class org.ros.internal.node.response.TopicListResultFactory
 
TopicParticipant - Interface in org.ros.internal.node.topic
Represents a ROS topic.
TopicParticipantManager - Class in org.ros.internal.node.topic
Manages a collection of Publishers and Subscribers.
TopicParticipantManager() - Constructor for class org.ros.internal.node.topic.TopicParticipantManager
 
TopicParticipantManagerListener - Interface in org.ros.internal.node.topic
Listener for TopicParticipantManager events.
TopicRegistrationInfo - Class in org.ros.internal.node.server.master
All information known to the manager about a topic.
TopicRegistrationInfo(GraphName) - Constructor for class org.ros.internal.node.server.master.TopicRegistrationInfo
 
Topics - Interface in org.ros
ROS topics.
TopicSystemState - Class in org.ros.master.client
Information about a topic.
TopicSystemState(String, Set<String>, Set<String>) - Constructor for class org.ros.master.client.TopicSystemState
 
TopicType - Class in org.ros.master.client
A simple collection of information about a topic.
TopicType(String, String) - Constructor for class org.ros.master.client.TopicType
 
TopicTypeListResultFactory - Class in org.ros.internal.node.response
A ResultFactory to take an object and turn it into a list of TopicType instances.
TopicTypeListResultFactory() - Constructor for class org.ros.internal.node.response.TopicTypeListResultFactory
 
toPointMessage(Point) - Method in class org.ros.rosjava_geometry.Vector3
 
toPoseMessage(Pose) - Method in class org.ros.rosjava_geometry.Transform
 
toPoseStampedMessage(FrameName, Time, PoseStamped) - Method in class org.ros.rosjava_geometry.Transform
 
toQuaternionMessage(Quaternion) - Method in class org.ros.rosjava_geometry.Quaternion
 
toRelative() - Method in class org.ros.namespace.GraphName
Convert name to a relative name representation.
toString() - Method in class org.ros.address.AdvertiseAddress
 
toString() - Method in class org.ros.address.BindAddress
 
toString() - Method in class org.ros.internal.node.response.Response
 
toString() - Method in enum org.ros.internal.node.response.StatusCode
 
toString() - Method in class org.ros.internal.node.server.NodeIdentifier
 
toString() - Method in class org.ros.internal.node.service.DefaultServiceClient
 
toString() - Method in class org.ros.internal.node.service.DefaultServiceServer
 
toString() - Method in class org.ros.internal.node.service.ServiceDeclaration
 
toString() - Method in class org.ros.internal.node.service.ServiceIdentifier
 
toString() - Method in class org.ros.internal.node.topic.DefaultPublisher
 
toString() - Method in class org.ros.internal.node.topic.DefaultSubscriber
 
toString() - Method in class org.ros.internal.node.topic.PublisherDeclaration
 
toString() - Method in class org.ros.internal.node.topic.PublisherIdentifier
 
toString() - Method in class org.ros.internal.node.topic.SubscriberDeclaration
 
toString() - Method in class org.ros.internal.node.topic.SubscriberIdentifier
 
toString() - Method in class org.ros.internal.node.topic.TopicDeclaration
 
toString() - Method in class org.ros.internal.node.topic.TopicIdentifier
 
toString() - Method in class org.ros.internal.transport.ConnectionHeader
 
toString() - Method in class org.ros.internal.transport.ProtocolDescription
 
toString() - Method in class org.ros.internal.transport.tcp.AbstractNamedChannelHandler
 
toString() - Method in class org.ros.namespace.GraphName
 
toString() - Method in class org.ros.rosjava_geometry.FrameName
 
toString() - Method in class org.ros.rosjava_geometry.FrameTransform
 
toString() - Method in class org.ros.rosjava_geometry.Quaternion
 
toString() - Method in class org.ros.rosjava_geometry.Transform
 
toString() - Method in class org.ros.rosjava_geometry.Vector3
 
toTransformMessage(Transform) - Method in class org.ros.rosjava_geometry.Transform
 
toTransformStampedMessage(TransformStamped) - Method in class org.ros.rosjava_geometry.FrameTransform
 
toUri(String) - Method in class org.ros.address.AdvertiseAddress
 
toVector3Message(Vector3) - Method in class org.ros.rosjava_geometry.Vector3
 
transform(FrameName, FrameName) - Method in class org.ros.rosjava_geometry.FrameTransformTree
 
transform(String, String) - Method in class org.ros.rosjava_geometry.FrameTransformTree
 
Transform - Class in org.ros.rosjava_geometry
A transformation in terms of translation, rotation, and scale.
Transform(Vector3, Quaternion) - Constructor for class org.ros.rosjava_geometry.Transform
 
TransformBenchmark - Class in org.ros.rosjava_benchmarks
 
TransformBenchmark() - Constructor for class org.ros.rosjava_benchmarks.TransformBenchmark
 
translation(double, double, double) - Static method in class org.ros.rosjava_geometry.Transform
 
translation(Vector3) - Static method in class org.ros.rosjava_geometry.Transform
 
TYPE - Static variable in interface org.ros.internal.transport.ConnectionHeaderFields
 

U

UDPROS - Static variable in interface org.ros.internal.transport.ProtocolNames
 
unregisterPublisher(PublisherIdentifier) - Method in class org.ros.internal.node.client.MasterClient
Unregisters the specified PublisherDeclaration.
unregisterPublisher(GraphName, GraphName) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Unregister a publisher.
unregisterPublisher(GraphName, GraphName) - Method in class org.ros.internal.node.server.master.MasterServer
Unregister a Publisher.
unregisterPublisher(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Unregister the caller as a publisher of the topic.
unregisterPublisher(String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
unregisterService(NodeIdentifier, ServiceServer<?, ?>) - Method in class org.ros.internal.node.client.MasterClient
Unregisters the specified ServiceServer.
unregisterService(GraphName, GraphName, URI) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Unregister a service.
unregisterService(GraphName, GraphName, URI) - Method in class org.ros.internal.node.server.master.MasterServer
Unregister a service from the master.
unregisterService(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Unregister the caller as a provider of the specified service.
unregisterService(String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
unregisterSubscriber(NodeIdentifier, Subscriber<?>) - Method in class org.ros.internal.node.client.MasterClient
Unregisters the specified Subscriber.
unregisterSubscriber(GraphName, GraphName) - Method in class org.ros.internal.node.server.master.MasterRegistrationManagerImpl
Unregister a subscriber.
unregisterSubscriber(GraphName, GraphName) - Method in class org.ros.internal.node.server.master.MasterServer
Unregister a Subscriber.
unregisterSubscriber(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.MasterXmlRpcEndpoint
Unregister the caller as a publisher of the topic.
unregisterSubscriber(String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
Unsigned - Class in org.ros.math
Provides conversions from unsigned values to bitwise equal signed values.
unsubscribeParam(GraphName) - Method in class org.ros.internal.node.client.ParameterClient
 
unsubscribeParam(String, String, String) - Method in class org.ros.internal.node.xmlrpc.MasterXmlRpcEndpointImpl
 
unsubscribeParam(String, String, String) - Method in interface org.ros.internal.node.xmlrpc.ParameterServerXmlRpcEndpoint
Unsubscribes from updates to the specified param.
update(TransformStamped) - Method in class org.ros.rosjava_geometry.FrameTransformTree
Updates the tree with the provided TransformStamped message.
update() - Method in class org.ros.time.RemoteUptimeClock
Update this RemoteUptimeClock with the latest uptime from the remote clock.
updateParameter(GraphName, Object) - Method in class org.ros.internal.node.parameter.ParameterManager
 
updatePublishers(Collection<PublisherIdentifier>) - Method in class org.ros.internal.node.topic.DefaultSubscriber
Updates the list of Publishers for the topic that this Subscriber is interested in.
updateTime() - Method in class org.ros.time.NtpTimeProvider
Update the current time offset from the configured NTP host.
UriListResultFactory - Class in org.ros.internal.node.response
A ResultFactory to take an object and turn it into a list of URLIs.
UriListResultFactory() - Constructor for class org.ros.internal.node.response.UriListResultFactory
 
UriResultFactory - Class in org.ros.internal.node.response
 
UriResultFactory() - Constructor for class org.ros.internal.node.response.UriResultFactory
 
USE_SIM_TIME - Static variable in interface org.ros.Parameters
 

V

valueOf(String) - Static method in enum org.ros.internal.node.response.StatusCode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.ros.internal.node.response.StatusCode
Returns an array containing the constants of this enum type, in the order they are declared.
Vector3 - Class in org.ros.rosjava_geometry
A three dimensional vector.
Vector3(double, double, double) - Constructor for class org.ros.rosjava_geometry.Vector3
 
VoidResultFactory - Class in org.ros.internal.node.response
 
VoidResultFactory() - Constructor for class org.ros.internal.node.response.VoidResultFactory
 

W

WallTimeProvider - Class in org.ros.time
Provides wallclock (actual) time.
WallTimeProvider() - Constructor for class org.ros.time.WallTimeProvider
 
WallTimeRate - Class in org.ros.concurrent
 
WallTimeRate(int) - Constructor for class org.ros.concurrent.WallTimeRate
 
WatchdogTimer - Class in org.ros.concurrent
A WatchdogTimer expects to receive a WatchdogTimer.pulse() at least once every WatchdogTimer.period WatchdogTimer.units.
WatchdogTimer(ScheduledExecutorService, long, TimeUnit, Runnable) - Constructor for class org.ros.concurrent.WatchdogTimer
 
write(ChannelBuffer) - Method in class org.ros.internal.transport.tcp.TcpClient
 

X

xAxis() - Static method in class org.ros.rosjava_geometry.Vector3
 
XmlRpcClientFactory<T extends XmlRpcEndpoint> - Class in org.ros.internal.node.xmlrpc
Modified version of org.apache.xmlrpc.client.util.ClientFactory that requires timeouts in calls.
XmlRpcClientFactory(XmlRpcClient, TypeConverterFactory) - Constructor for class org.ros.internal.node.xmlrpc.XmlRpcClientFactory
Creates a new instance.
XmlRpcClientFactory(XmlRpcClient) - Constructor for class org.ros.internal.node.xmlrpc.XmlRpcClientFactory
Creates a new instance.
XmlRpcEndpoint - Interface in org.ros.internal.node.xmlrpc
Represents the XML-RPC interface for a client or server.
XmlRpcServer - Class in org.ros.internal.node.server
Base class for an XML-RPC server.
XmlRpcServer(BindAddress, AdvertiseAddress) - Constructor for class org.ros.internal.node.server.XmlRpcServer
 
XmlRpcTimeoutException - Exception in org.ros.internal.node.xmlrpc
 
XmlRpcTimeoutException() - Constructor for exception org.ros.internal.node.xmlrpc.XmlRpcTimeoutException
 
XmlRpcTimeoutException(Exception) - Constructor for exception org.ros.internal.node.xmlrpc.XmlRpcTimeoutException
 
xRotation(double) - Static method in class org.ros.rosjava_geometry.Transform
 

Y

yAxis() - Static method in class org.ros.rosjava_geometry.Vector3
 
yRotation(double) - Static method in class org.ros.rosjava_geometry.Transform
 

Z

zAxis() - Static method in class org.ros.rosjava_geometry.Vector3
 
zero() - Static method in class org.ros.rosjava_geometry.Vector3
 
zRotation(double) - Static method in class org.ros.rosjava_geometry.Transform
 
A B C D E F G H I J L M N O P Q R S T U V W X Y Z