Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- accept() - Method in class zmq.io.net.tcp.TcpListener
- accept(T) - Method in interface zmq.util.function.Consumer
-
Performs this operation on the given argument.
- ACCEPT_FAILED - Enum constant in enum org.zeromq.ZMonitor.Event
- ACCEPTED - Enum constant in enum org.zeromq.ZMonitor.Event
- acceptEvent() - Method in class zmq.io.IOObject
- acceptEvent() - Method in class zmq.io.net.tcp.TcpListener
- acceptEvent() - Method in interface zmq.poll.IPollEvents
-
Called by I/O thread when file descriptor is ready for accept.
- act(int) - Method in class org.zeromq.ZActor.Double
- act(int) - Method in interface org.zeromq.ZStar.Star
-
Where acting takes place ...
Hint: Can be used to process the events or input acquired from the previous step, or ...
Key point: in the middle of a loop.
Decision: to act on the next loop or not - ACTIVATE_READ - Enum constant in enum zmq.Command.Type
- ACTIVATE_WRITE - Enum constant in enum zmq.Command.Type
- activated(Pipe) - Method in class zmq.socket.FQ
- activated(Pipe) - Method in class zmq.socket.LB
- activated(Pipe) - Method in class zmq.socket.pubsub.Dist
- active - Variable in class zmq.Ctx
- active - Variable in class zmq.io.SessionBase
- active - Variable in class zmq.Mailbox
- active - Variable in class zmq.socket.clientserver.Server.Outpipe
- active - Variable in class zmq.socket.FQ
- active - Variable in class zmq.socket.LB
- active - Variable in class zmq.socket.pubsub.Dist
- active - Variable in class zmq.socket.reqrep.Router.Outpipe
- active - Variable in class zmq.socket.Stream.Outpipe
- active - Variable in class zmq.SocketBase
- active() - Method in class zmq.socket.pubsub.Dist
- ACTIVE - Enum constant in enum zmq.pipe.Pipe.State
- ACTIVE - Enum constant in enum zmq.Proxy.State
- actor - Variable in class org.zeromq.ZActor.ActorFortune
- actor - Variable in class org.zeromq.ZActor.Double
- ActorFortune(ZActor.Actor) - Constructor for class org.zeromq.ZActor.ActorFortune
- actorName - Variable in class org.zeromq.ZAuth.AuthActor
- add(byte[]) - Method in class org.zeromq.ZMsg
- add(long, TimerHandler, Object...) - Method in class org.zeromq.timer.ZTicket
-
Add ticket to the set.
- add(long, TimerHandler, Object...) - Method in class org.zeromq.timer.ZTimer
-
Add timer to the set, timer repeats forever, or until cancel is called.
- add(long, ZTimer.Handler, Object...) - Method in class org.zeromq.ZTimer
-
Deprecated.Add timer to the set, timer repeats forever, or until cancel is called.
- add(long, Timers.Handler, Object...) - Method in class zmq.util.Timers
-
Add timer to the set, timer repeats forever, or until cancel is called.
- add(Object, ZPoller.ItemHolder) - Method in class org.zeromq.ZPoller
- add(String) - Method in class org.zeromq.ZMsg
- add(ZMetadata, ZConfig) - Method in class org.zeromq.ZCert
- add(ZFrame) - Method in class org.zeromq.ZMsg
- add(ZMonitor.Event...) - Method in class org.zeromq.ZMonitor
-
Adds event types to monitor.
- add(Msg, int, int) - Method in class zmq.socket.pubsub.Trie
- add(Msg, Pipe) - Method in class zmq.socket.pubsub.Mtrie
- ADD_EVENTS - Static variable in class org.zeromq.ZMonitor
- addAll(Collection<? extends ZFrame>) - Method in class org.zeromq.ZMsg
- addComment(String) - Method in class org.zeromq.ZConfig
-
add comment
- added(byte[], int, Pipe) - Method in interface zmq.socket.pubsub.Trie.ITrieHandler
- added(byte[], int, Pipe) - Method in class zmq.socket.pubsub.XSub.SendSubscription
- addEndpoint(String, Own, Pipe) - Method in class zmq.SocketBase
- addEvents(ZMQ.Socket) - Method in class org.zeromq.ZMonitor.MonitorActor
- addFd(SelectableChannel) - Method in class zmq.io.IOObject
- addFirst(byte[]) - Method in class org.zeromq.ZMsg
- addFirst(String) - Method in class org.zeromq.ZMsg
- addFirst(ZFrame) - Method in class org.zeromq.ZMsg
- addHandle(SelectableChannel, IPollEvents) - Method in class zmq.poll.Poller
- addHelper(Msg, int, int, Pipe) - Method in class zmq.socket.pubsub.Mtrie
- addLast(byte[]) - Method in class org.zeromq.ZMsg
- addLast(String) - Method in class org.zeromq.ZMsg
- addLast(ZFrame) - Method in class org.zeromq.ZMsg
- addOnTop(Pipe) - Method in class zmq.socket.pubsub.Mtrie
- addPoller(ZMQ.PollItem, ZLoop.IZLoopHandler, Object) - Method in class org.zeromq.ZLoop
- addProperty(ByteBuffer, String, byte[]) - Method in class zmq.io.mechanism.Mechanism
- addProperty(ByteBuffer, String, String) - Method in class zmq.io.mechanism.Mechanism
- addProperty(Msg, String, byte[]) - Method in class zmq.io.mechanism.Mechanism
- addProperty(Msg, String, String) - Method in class zmq.io.mechanism.Mechanism
- addr - Variable in class zmq.io.net.tcp.TcpConnecter
- addr - Variable in class zmq.io.SessionBase
- addr - Variable in class zmq.ZMQ.Event
- addReconnectTimer() - Method in class zmq.io.net.tcp.TcpConnecter
- address - Variable in class org.zeromq.ZAuth.ZapReply
- address - Variable in class org.zeromq.ZAuth.ZapRequest
- address - Variable in class org.zeromq.ZMonitor.MonitorActor
- address - Variable in class org.zeromq.ZMonitor.ZEvent
-
The address of the source of the event.
- address - Variable in class org.zeromq.ZMQ.Event
- address - Variable in class zmq.io.net.Address
- address - Variable in class zmq.io.net.ipc.IpcAddress
- address - Variable in class zmq.io.net.ipc.IpcListener
- address - Variable in class zmq.io.net.tcp.TcpAddress
- address - Variable in class zmq.io.net.tcp.TcpListener
- address - Variable in class zmq.SocketBase.SimpleURI
- address() - Method in class zmq.io.net.Address
- address() - Method in interface zmq.io.net.Address.IZAddress
- address() - Method in class zmq.io.net.ipc.IpcAddress
- address() - Method in class zmq.io.net.tcp.TcpAddress
- address(Address.IZAddress) - Method in class zmq.io.net.tcp.TcpListener
- Address - Class in zmq.io.net
- Address(String, String) - Constructor for class zmq.io.net.Address
-
Deprecated.
- Address(SocketAddress) - Constructor for class zmq.io.net.Address
- Address(NetProtocol, String) - Constructor for class zmq.io.net.Address
- Address.IZAddress - Interface in zmq.io.net
- addSignaler(Signaler) - Method in class zmq.MailboxSafe
- addString(String) - Method in class org.zeromq.ZMsg
-
Add a String as a new ZFrame to the end of list
- addTicket(long, TimerHandler, Object...) - Method in class org.zeromq.timer.ZTicker
- addTimer(int, int, ZLoop.IZLoopHandler, Object) - Method in class org.zeromq.ZLoop
- addTimer(long, int) - Method in class zmq.io.IOObject
- addTimer(long, TimerHandler, Object...) - Method in class org.zeromq.timer.ZTicker
- addTimer(long, IPollEvents, int) - Method in class zmq.poll.PollerBase
- adjustLoad(int) - Method in class zmq.poll.PollerBase
- affinity - Variable in class zmq.Options
- afternm(byte[], byte[], int, byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- afternm(ByteBuffer, ByteBuffer, int, ByteBuffer, byte[]) - Method in class zmq.io.mechanism.curve.Curve
- agent - Variable in class org.zeromq.ZAuth
- agent - Variable in class org.zeromq.ZMonitor
- agent - Variable in class org.zeromq.ZProxy
- agent - Variable in class org.zeromq.ZStar
- agent() - Method in class org.zeromq.ZStar
-
Returns the Corbeille endpoint.
- agent(ZMQ.Socket, String) - Method in class org.zeromq.ZStar
-
Deprecated.
- alive - Variable in class org.zeromq.timer.ZTicket.Ticket
- alive - Variable in class org.zeromq.ZProxy.ProxyActor.State
- alive - Variable in class zmq.io.IOObject
- alive - Variable in class zmq.util.Timers.Timer
- ALIVE - Enum constant in enum org.zeromq.ZProxy.State
- ALIVE - Static variable in class org.zeromq.ZProxy
- all - Variable in class org.zeromq.ZPoller
- ALL - Enum constant in enum org.zeromq.ZMonitor.Event
- allocate(int) - Method in class zmq.io.coder.Decoder
- allocate(int) - Method in class zmq.io.coder.v2.V2Decoder
- allocate(int) - Method in interface zmq.msg.MsgAllocator
- allocate(int) - Method in class zmq.msg.MsgAllocatorDirect
- allocate(int) - Method in class zmq.msg.MsgAllocatorHeap
- allocate(int) - Method in class zmq.msg.MsgAllocatorThreshold
- allocator - Variable in class zmq.io.coder.Decoder
- allocator - Variable in class zmq.Options
- allocator(Class<?>) - Method in class zmq.Options
- allow(String) - Method in class org.zeromq.ZAuth
-
Allow (whitelist) a single IP address.
- ALLOW - Static variable in class org.zeromq.ZAuth
- allowAny - Variable in class org.zeromq.ZAuth.SimpleCurveAuth
- anonymousPipes - Variable in class zmq.socket.reqrep.Router
- append(byte[]) - Method in class org.zeromq.ZMsg
-
Adds bytes as a new frame in the message.
- append(String) - Method in class org.zeromq.ZMsg
-
Adds a string as a new frame in the message.
- append(ZMsg) - Method in class org.zeromq.ZMsg
- apply() - Method in class zmq.io.coder.Decoder.EightByteSizeReady
- apply() - Method in class zmq.io.coder.Decoder.FlagsReady
- apply() - Method in class zmq.io.coder.Decoder.MessageReady
- apply() - Method in class zmq.io.coder.Decoder.OneByteSizeReady
- apply() - Method in interface zmq.io.coder.IDecoder.Step
- apply(ZMQ.Socket) - Method in class org.zeromq.ZCert
- apply(T) - Method in interface zmq.util.function.Function
-
Applies this function to the given argument.
- apply(T, U) - Method in interface zmq.util.function.BiFunction
-
Applies this function to the given arguments.
- apply(Trie.ITrieHandler, Pipe) - Method in class zmq.socket.pubsub.Trie
- applyHelper(byte[], int, int, Trie.ITrieHandler, Pipe) - Method in class zmq.socket.pubsub.Trie
- arg - Variable in class org.zeromq.ZLoop.SPoller
- arg - Variable in class org.zeromq.ZLoop.STimer
- arg - Variable in class zmq.Command
- arg - Variable in class zmq.ZMQ.Event
- args - Variable in class org.zeromq.timer.ZTicket.Ticket
- args - Variable in class org.zeromq.ZProxy.ProxyActor
- args - Variable in class org.zeromq.ZThread.ShimThread
- args - Variable in class zmq.util.Timers.Timer
- assertKey(int, int, String) - Method in class org.zeromq.ZCert
- asServer - Variable in class zmq.Options
- asType - Variable in class zmq.Options
- attach(Pipe) - Method in class zmq.socket.FQ
- attach(Pipe) - Method in class zmq.socket.LB
- attach(Pipe) - Method in class zmq.socket.pubsub.Dist
- ATTACH - Enum constant in enum zmq.Command.Type
- attachedRunnable - Variable in class org.zeromq.ZThread.ShimThread
- attachPipe(Pipe) - Method in class zmq.io.SessionBase
- attachPipe(Pipe, boolean) - Method in class zmq.SocketBase
- attachPipe(Pipe, boolean, boolean) - Method in class zmq.SocketBase
- AuthActor(String, Map<String, ZAuth.Auth>) - Constructor for class org.zeromq.ZAuth.AuthActor
- authorize(ZAuth.ZapRequest, boolean) - Method in interface org.zeromq.ZAuth.Auth
-
Callback for authorizing a connection.
- authorize(ZAuth.ZapRequest, boolean) - Method in class org.zeromq.ZAuth.SimpleCurveAuth
- authorize(ZAuth.ZapRequest, boolean) - Method in class org.zeromq.ZAuth.SimpleNullAuth
- authorize(ZAuth.ZapRequest, boolean) - Method in class org.zeromq.ZAuth.SimplePlainAuth
- auths - Variable in class org.zeromq.ZAuth.AuthActor
- await() - Method in interface org.zeromq.ZStar.Exit
-
Causes the current thread to wait in blocking mode until the end of the remote operations, unless the thread is interrupted.
- await() - Method in class org.zeromq.ZStar.Plateau
- await(long, TimeUnit) - Method in interface org.zeromq.ZStar.Exit
-
Causes the current thread to wait in blocking mode until the end of the remote operations, unless the thread is interrupted, or the specified waiting time elapses.
- await(long, TimeUnit) - Method in class org.zeromq.ZStar.Plateau
- awaitSilent() - Method in interface org.zeromq.ZStar.Exit
-
Causes the current thread to wait in blocking mode until the end of the remote operations.
- awaitSilent() - Method in class org.zeromq.ZStar.Plateau
B
- back - Variable in class zmq.pipe.DBuffer
- back() - Method in class zmq.pipe.DBuffer
- back() - Method in class zmq.pipe.YQueue
- BACK - Enum constant in enum org.zeromq.ZProxy.Plug
- backChunk - Variable in class zmq.pipe.YQueue
- backend - Variable in class org.zeromq.ZProxy.ProxyActor
- backlog - Variable in class zmq.Options
- backPos - Variable in class zmq.pipe.YQueue
- backPos() - Method in class zmq.pipe.YQueue
- backstage(ZMQ.Socket, ZPoller, int) - Method in interface org.zeromq.ZActor.Actor
-
Called when the actor received a control message from its pipe during a loop.
- backstage(ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZActor.Duo
- backstage(ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZActor.SimpleActor
- backstage(ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZAuth.AuthActor
- backstage(ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZMonitor.MonitorActor
- backstage(ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZProxy.ProxyActor
- base - Variable in class org.zeromq.ZMQ.PollItem
- base - Variable in class org.zeromq.ZMQ.Socket
- base() - Method in class org.zeromq.ZMQ.PollItem
- base() - Method in class org.zeromq.ZMQ.Socket
-
DO NOT USE if you're trying to build a special proxy
- beacon - Variable in class org.zeromq.ZBeacon
- beacon - Variable in class org.zeromq.ZBeacon.Builder
- beacon(byte[]) - Method in class org.zeromq.ZBeacon.Builder
- beforenm(byte[], byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- BEFORENM - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- beginChunk - Variable in class zmq.pipe.YQueue
- beginPos - Variable in class zmq.pipe.YQueue
- BiFunction<T,
U, - Interface in zmq.util.functionR> -
Represents a function that accepts two arguments and produces a result.
- BINARY_FORMAT - Static variable in class org.zeromq.proto.ZPicture
- bind(String) - Method in class org.zeromq.ZMQ.Socket
-
Bind to network interface.
- bind(String) - Method in class org.zeromq.ZSocket
-
Creates an endpoint for accepting connections and binds to it.
- bind(String) - Method in class zmq.SocketBase
- bind(SocketBase, String) - Static method in class zmq.ZMQ
- BIND - Enum constant in enum zmq.Command.Type
- BIND - Enum constant in enum zmq.Ctx.Side
- BIND_FAILED - Enum constant in enum org.zeromq.ZMonitor.Event
- bindPipe - Variable in class zmq.Ctx.PendingConnection
- bindToRandomPort(String) - Method in class org.zeromq.ZMQ.Socket
-
Bind to network interface to a random port.
- bindToRandomPort(String, int, int) - Method in class org.zeromq.ZMQ.Socket
-
Bind to network interface to a random port.
- blacklist - Variable in class org.zeromq.ZAuth.AuthActor
- Blob - Class in zmq.util
- Blob(byte[]) - Constructor for class zmq.util.Blob
- blocking - Variable in class org.zeromq.ZBeacon.Builder
- blocking(boolean) - Method in class org.zeromq.ZBeacon.Builder
-
Deprecated.ignored
- blocky - Variable in class zmq.Ctx
- BODY - Enum constant in enum zmq.socket.radiodish.Dish.DishSession.State
- BODY - Enum constant in enum zmq.socket.radiodish.Radio.RadioSession.State
- BODY - Enum constant in enum zmq.socket.reqrep.Req.ReqSession.State
- BOTTOM - Enum constant in enum zmq.socket.reqrep.Req.ReqSession.State
- box(byte[], byte[], int, byte[], byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- box(ByteBuffer, ByteBuffer, int, ByteBuffer, byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- BOXZERO - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- breakaleg(ZContext, ZStar.Fortune, ZMQ.Socket, Object...) - Method in interface org.zeromq.ZStar.Entourage
-
Called when the show is about to start.
- breathe() - Method in class org.zeromq.ZActor.Double
- breathe() - Method in interface org.zeromq.ZStar.Star
-
Called when the star in on stage, just before acting.
Hint: Can be used to poll events or get input/events from other sources, or ...
Key point: a loop just started. - broadcastAddress - Variable in class org.zeromq.ZBeacon.BroadcastClient
- broadcastClient - Variable in class org.zeromq.ZBeacon
- BroadcastClient(InetAddress, InetAddress, int, AtomicLong) - Constructor for class org.zeromq.ZBeacon.BroadcastClient
- broadcastInterval - Variable in class org.zeromq.ZBeacon.BroadcastClient
- broadcastInterval - Variable in class org.zeromq.ZBeacon
- broadcastInterval - Variable in class org.zeromq.ZBeacon.Builder
- broadcastInterval(long) - Method in class org.zeromq.ZBeacon.Builder
- broadcastServer - Variable in class org.zeromq.ZBeacon
- BroadcastServer(int, boolean) - Constructor for class org.zeromq.ZBeacon.BroadcastServer
- buf - Variable in class zmq.io.coder.DecoderBase
- buf - Variable in class zmq.Msg
- buf - Variable in class zmq.util.Blob
- buf() - Method in class zmq.Msg
- buffer - Variable in class org.zeromq.util.ZDigest
- buffer - Variable in class org.zeromq.ZCertStore.Hasher
- buffer - Variable in class zmq.io.coder.EncoderBase
- buffer - Variable in class zmq.io.coder.raw.RawDecoder
- bufferSize - Variable in class zmq.io.coder.EncoderBase
- bufsize - Variable in class zmq.io.coder.DecoderBase
- build() - Method in class org.zeromq.ZBeacon.Builder
- build() - Method in class zmq.Msg.Builder
- Builder() - Constructor for class org.zeromq.ZBeacon.Builder
- Builder() - Constructor for class zmq.Msg.Builder
- bytes() - Method in class org.zeromq.util.ZMetadata
- bytes() - Method in enum zmq.io.mechanism.curve.Curve.Size
- bytes() - Method in class zmq.io.Metadata
- bytes(ByteBuffer) - Static method in class zmq.util.Utils
- bytes(ByteBuffer) - Static method in class zmq.Utils
-
Deprecated.
- bytes(ByteBuffer, int, int) - Method in class zmq.io.Metadata
C
- c - Variable in class zmq.pipe.YPipe
- call() - Method in interface zmq.Signaler.IoOperation
- cancel() - Method in class org.zeromq.timer.ZTicket.Ticket
-
Cancels a ticket.
- cancel() - Method in class org.zeromq.timer.ZTimer.Timer
-
Cancels a timer.
- cancel() - Method in class org.zeromq.ZMQ.CancellationToken
-
Cancel a pending the send/receive operation.
- cancel() - Method in class zmq.util.Timers.Timer
-
Cancels a timer.
- cancel(AtomicBoolean) - Method in class zmq.SocketBase
- cancel(ZTimer.Timer) - Method in class org.zeromq.ZTimer
-
Deprecated.use
ZTimer.Timer.cancel()
instead - cancel(Timers.Timer) - Method in class zmq.util.Timers
-
Deprecated.use
Timers.Timer.cancel()
instead - CANCEL - Enum constant in enum zmq.Command.Type
- canceled - Variable in class org.zeromq.ZMQ.CancellationToken
- CancellationToken(SocketBase) - Constructor for class org.zeromq.ZMQ.CancellationToken
- cancelled - Variable in class zmq.poll.Poller.Handle
- cancelled - Variable in class zmq.poll.PollerBase.TimerInfo
- cancelTimer(int) - Method in class zmq.io.IOObject
- cancelTimer(IPollEvents, int) - Method in class zmq.poll.PollerBase
- canReceiveDisconnectMsg - Variable in class zmq.Options
- canReceiveHiccupMsg - Variable in class zmq.Options
- canSendHelloMsg - Variable in class zmq.Options
- capture - Variable in class org.zeromq.ZProxy.ProxyActor
- capture(SocketBase, Msg, int) - Method in class zmq.Proxy
- CAPTURE - Enum constant in enum org.zeromq.ZProxy.Plug
- certStore - Variable in class org.zeromq.ZAuth.SimpleCurveAuth
- changed - Variable in class zmq.poll.PollerBase
- channel - Variable in class org.zeromq.ZPoller.CompositePollItem
- channel - Variable in class zmq.poll.PollItem
- Channel - Class in zmq.socket
- Channel(Ctx, int, int) - Constructor for class zmq.socket.Channel
- CHANNEL - Enum constant in enum org.zeromq.SocketType
-
Flag to specify CHANNEL socket.
- CHANNEL - Enum constant in enum zmq.socket.Sockets
- ChannelForwardHolder() - Constructor for class zmq.Ctx.ChannelForwardHolder
- channels - Variable in class org.zeromq.ZPoller.ComposeEventsHandler
- CHARSET - Static variable in class org.zeromq.ZMQ
- CHARSET - Static variable in class zmq.ZMQ
- check() - Method in class zmq.Msg
- check(ByteBuffer) - Method in class zmq.socket.pubsub.Trie
- check(Options) - Method in enum zmq.io.mechanism.Mechanisms
- checkArgument(boolean, String) - Static method in class org.zeromq.Utils
- checkArgument(boolean, String) - Static method in class zmq.util.Utils
- checkArgument(boolean, Supplier<String>) - Static method in class zmq.util.Utils
- checkAvailable(int) - Method in class org.zeromq.proto.ZNeedle
- checkContext(Ctx) - Static method in class zmq.ZMQ
- checkCustomCodec(Object, Class<T>) - Method in class zmq.Options
- checkDestroy() - Method in class zmq.SocketBase
- checkForChanges() - Method in class org.zeromq.ZCertStore
-
Check if files in the certificate folders have been added or removed.
- checkHwm() - Method in class zmq.pipe.Pipe
- checkHwm() - Method in class zmq.socket.pubsub.Dist
- checkProtocol(String) - Method in class zmq.SocketBase
- checkProxyConnection() - Method in class zmq.io.net.tcp.SocksConnecter
- checkRead() - Method in class zmq.pipe.DBuffer
- checkRead() - Method in class zmq.pipe.Pipe
- checkRead() - Method in class zmq.pipe.YPipe
- checkRead() - Method in interface zmq.pipe.YPipeBase
- checkRead() - Method in class zmq.pipe.YPipeConflate
- checkSocket(SocketBase) - Static method in class zmq.ZMQ
- checkTag() - Method in class zmq.Ctx
-
Deprecated.use
Ctx.isActive()
instead - checkTermAcks() - Method in class zmq.Own
- checkWrite() - Method in class zmq.pipe.Pipe
- child(ZConfig, Matcher, int, String, AtomicInteger) - Static method in class org.zeromq.ZConfig
- children - Variable in class org.zeromq.ZConfig
- choose(Address.IZAddress, Options) - Method in interface zmq.io.net.SelectorProviderChooser
- chooseIoThread(long) - Method in class zmq.Ctx
- chooseIoThread(long) - Method in class zmq.ZObject
- chooser(Class<?>) - Method in class zmq.Options
- Chunk(int, int) - Constructor for class zmq.pipe.YQueue.Chunk
- cleanForwarded() - Method in class zmq.Ctx
-
Clean all empty references
- cleanPipes() - Method in class zmq.io.SessionBase
- clear() - Method in class org.zeromq.ZMsg
- clear() - Method in class zmq.util.MultiMap
- clearSignalers() - Method in class zmq.MailboxSafe
- client(String) - Method in class org.zeromq.ZBeacon.Builder
-
Deprecated.
- client(InetAddress) - Method in class org.zeromq.ZBeacon.Builder
- Client - Class in zmq.socket.clientserver
- Client(Ctx, int, int) - Constructor for class zmq.socket.clientserver.Client
- CLIENT - Enum constant in enum org.zeromq.SocketType
-
Flag to specify CLIENT socket.
- CLIENT - Enum constant in enum zmq.socket.Sockets
- Client and server roles - Search tag in class org.zeromq.ZMQ.Curve
- Section
- clientExHandler - Variable in class org.zeromq.ZBeacon.Builder
- clientExHandler - Variable in class org.zeromq.ZBeacon
- clientHost - Variable in class org.zeromq.ZBeacon.Builder
- clientKey - Variable in class org.zeromq.ZAuth.ZapRequest
- clock - Variable in class org.zeromq.timer.ZTicket
- clock - Variable in class zmq.util.Timers
- clock() - Method in class zmq.poll.PollerBase
- Clock - Class in zmq.util
- Clock() - Constructor for class zmq.util.Clock
- CLOCK_PRECISION - Enum constant in enum zmq.Config
- close() - Method in class org.zeromq.ManagedContext
- close() - Method in interface org.zeromq.ZAgent
-
Closes the pipe.
- close() - Method in class org.zeromq.ZAgent.SimpleAgent
- close() - Method in class org.zeromq.ZAuth
-
Destructor.
- close() - Method in class org.zeromq.ZContext
- close() - Method in class org.zeromq.ZMonitor
-
Stops the monitoring and closes the actor.
- close() - Method in class org.zeromq.ZMQ.Context
-
Destroys the ØMQ context context.
- close() - Method in class org.zeromq.ZMQ.Poller
- close() - Method in class org.zeromq.ZMQ.Socket
-
This is an explicit "destructor".
- close() - Method in class org.zeromq.ZPoller
-
Destroys the poller.
- close() - Method in class org.zeromq.ZSocket
- close() - Method in class org.zeromq.ZStar
- close() - Method in class zmq.io.IOThread
- close() - Method in class zmq.io.net.tcp.TcpConnecter
- close() - Method in class zmq.io.net.tcp.TcpListener
- close() - Method in class zmq.Mailbox
- close() - Method in class zmq.MailboxSafe
- close() - Method in class zmq.Reaper
- close() - Method in class zmq.Signaler
- close() - Method in class zmq.SocketBase
- close(Selector) - Method in class org.zeromq.ZMQ.Context
-
Closes a Selector that was created within this context.
- close(ZPoller, ZMQ.Socket) - Method in class org.zeromq.ZMonitor.MonitorActor
- close(SocketBase) - Static method in class zmq.ZMQ
- CLOSE - Static variable in class org.zeromq.ZMonitor
- CLOSE_FAILED - Enum constant in enum org.zeromq.ZMonitor.Event
- closed - Variable in class org.zeromq.ZMQ.Context
- closed(ZMQ.Socket) - Method in interface org.zeromq.ZActor.Actor
-
Called when a created socket has been closed.
- closed(ZMQ.Socket) - Method in class org.zeromq.ZActor.Duo
- closed(ZMQ.Socket) - Method in class org.zeromq.ZActor.SimpleActor
- CLOSED - Enum constant in enum org.zeromq.ZMonitor.Event
- closeSelector(Selector) - Method in class org.zeromq.ZContext
-
Deprecated.
ZContext.createSelector()
was exposed by mistake. while waiting for the API to disappear, this method is provided to allow releasing resources. - closeSelector(Selector) - Method in class zmq.Ctx
- closeSocket(ZMQ.Socket) - Method in class org.zeromq.ZContext
-
Close managed socket within this context and remove from sockets list.
- closeZeroLinger(SocketBase) - Static method in class zmq.ZMQ
- cnClient - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- cnCookie - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cnNonce - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cnNonce - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- cnPeerNonce - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cnPeerNonce - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- cnPrecom - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cnPrecom - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- cnPublic - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cnPublic - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- cnSecret - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cnSecret - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- cnServer - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- code - Variable in enum org.zeromq.ZMonitor.Event
- code - Variable in enum org.zeromq.ZMonitor.ProtocolCode
- code - Variable in class org.zeromq.ZMonitor.ZEvent
-
The numerical code of the event.
- code - Variable in enum org.zeromq.ZMQ.Error
- code - Variable in exception class org.zeromq.ZMQException
- code - Variable in enum zmq.io.coder.IDecoder.Step.Result
- command(String, boolean) - Method in class org.zeromq.ZProxy
-
Sends a command message to the proxy actor.
- command(ZProxy.Command, boolean) - Method in class org.zeromq.ZProxy
-
Sends a command message to the proxy actor.
- command(ZProxy.Command, ZMsg, boolean) - Method in class org.zeromq.ZProxy
-
Sends a command message to the proxy actor.
- Command - Class in zmq
- Command() - Constructor for enum org.zeromq.ZProxy.Command
- Command(ZObject, Command.Type) - Constructor for class zmq.Command
- Command(ZObject, Command.Type, Object) - Constructor for class zmq.Command
- COMMAND - Static variable in class zmq.Msg
- COMMAND_FLAG - Static variable in interface zmq.io.coder.v2.V2Protocol
- COMMAND_PIPE_GRANULARITY - Enum constant in enum zmq.Config
- Command.Type - Enum in zmq
- comments - Variable in class org.zeromq.ZConfig
- comparator - Variable in class zmq.util.MultiMap
- compare(ByteBuffer, byte[], int, int) - Method in class zmq.io.mechanism.Mechanism
- compare(Map.Entry<V, K>, Map.Entry<V, K>) - Method in class zmq.util.MultiMap.EntryComparator
- compare(Msg, String, boolean) - Method in class zmq.io.mechanism.Mechanism
- compareTo(ZTicket.Ticket) - Method in class org.zeromq.timer.ZTicket.Ticket
- compatible - Variable in enum zmq.socket.Sockets
- compatible(int) - Method in enum zmq.io.net.NetProtocol
- compatible(int, String) - Static method in enum zmq.socket.Sockets
- compatibles - Variable in enum zmq.io.net.NetProtocol
- ComposeEventsHandler(BiFunction<ZMQ.Socket, Integer, Boolean>, BiFunction<SelectableChannel, Integer, Boolean>) - Constructor for class org.zeromq.ZPoller.ComposeEventsHandler
- CompositePollItem(Object) - Constructor for class org.zeromq.ZPoller.CompositePollItem
- computeLwm(int) - Static method in class zmq.pipe.Pipe
- condition - Variable in class zmq.MailboxSafe
- Config - Enum in zmq
- Config(int) - Constructor for enum zmq.Config
- CONFIG - Enum constant in enum org.zeromq.ZProxy.Command
- CONFIG - Static variable in class org.zeromq.ZProxy
- configure(ZMQ.Socket, ZMsg, ZMQ.Socket, ZMQ.Socket, ZMQ.Socket, Object...) - Method in interface org.zeromq.ZProxy.Proxy
-
Configures the proxy with a custom message.
- configure(ZMQ.Socket, ZMsg, ZMQ.Socket, ZMQ.Socket, ZMQ.Socket, Object...) - Method in class org.zeromq.ZProxy.Proxy.SimpleProxy
- configure(ZMQ.Socket, ZProxy.Plug, Object...) - Method in interface org.zeromq.ZProxy.Proxy
-
Configures the given socket.
- configure(ZMsg) - Method in class org.zeromq.ZProxy
-
Configures the proxy.
- configure(ZMsg, boolean) - Method in interface org.zeromq.ZAuth.Auth
-
Configures with ad-hoc message.
- configure(ZMsg, boolean) - Method in class org.zeromq.ZAuth.SimpleCurveAuth
- configure(ZMsg, boolean) - Method in class org.zeromq.ZAuth.SimpleNullAuth
- configure(ZMsg, boolean) - Method in class org.zeromq.ZAuth.SimplePlainAuth
- configureCurve(String) - Method in class org.zeromq.ZAuth
-
Configure CURVE authentication
- configurePlain(String, String) - Method in class org.zeromq.ZAuth
-
Configure PLAIN authentication for a given domain.
- conflate - Variable in class zmq.Options
- conflate - Variable in class zmq.pipe.Pipe
- connect() - Method in class zmq.io.net.tcp.TcpConnecter
- connect(String) - Method in class org.zeromq.ZMQ.Socket
-
Connects the socket to an endpoint and then accepts incoming connections on that endpoint.
- connect(String) - Method in class org.zeromq.ZSocket
-
Connects the socket to an endpoint and then accepts incoming connections on that endpoint.
- connect(String) - Method in class zmq.SocketBase
- connect(SocketBase, String) - Static method in class zmq.ZMQ
- CONNECT - Enum constant in enum zmq.Ctx.Side
- CONNECT_DELAYED - Enum constant in enum org.zeromq.ZMonitor.Event
- CONNECT_RETRIED - Enum constant in enum org.zeromq.ZMonitor.Event
- CONNECTED - Enum constant in enum org.zeromq.ZMonitor.Event
- CONNECTED - Enum constant in enum zmq.io.mechanism.curve.CurveClientMechanism.State
- CONNECTED - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- connectEvent() - Method in class zmq.io.IOObject
- connectEvent() - Method in class zmq.io.net.tcp.TcpConnecter
- connectEvent() - Method in interface zmq.poll.IPollEvents
-
Called by I/O thread when file descriptor might be ready for connecting.
- connectInprocSockets(SocketBase, Options, Ctx.PendingConnection, Ctx.Side) - Method in class zmq.Ctx
- connectInternal(String) - Method in class zmq.SocketBase
- CONNECTION - Enum constant in enum zmq.io.StreamEngine.ErrorReason
- connectPeer(String) - Method in class org.zeromq.ZMQ.Socket
-
create outgoing connection from socket and return the connection routing id in thread-safe and atomic way.
- connectPeer(String) - Method in class zmq.SocketBase
- connectPeer(SocketBase, String) - Static method in class zmq.ZMQ
- connectPending(String, SocketBase) - Method in class zmq.Ctx
- connectPending(String, SocketBase) - Method in class zmq.ZObject
- connectPipe - Variable in class zmq.Ctx.PendingConnection
- connectRid - Variable in class zmq.SocketBase
- connectToProxy() - Method in class zmq.io.net.tcp.SocksConnecter
- Consumer<T> - Interface in zmq.util.function
-
Represents an operation that accepts a single input argument and returns no result.
- contains(Object) - Method in class org.zeromq.ZMsg
- contains(V) - Method in class zmq.util.MultiMap
- containsAll(Collection<?>) - Method in class org.zeromq.ZMsg
- containsPublicKey(byte[]) - Method in class org.zeromq.ZCertStore
-
Check if a public key is in the certificate store.
- containsPublicKey(String) - Method in class org.zeromq.ZCertStore
-
check if a z85-based public key is in the certificate store.
- contentSize() - Method in class org.zeromq.ZMsg
- context - Variable in class org.zeromq.ZActor.Double
- context - Variable in class org.zeromq.ZContext
-
Reference to underlying Context object
- context - Variable in class org.zeromq.ZLoop
- context - Variable in class org.zeromq.ZMQ.Poller
- context - Variable in class org.zeromq.ZStar
- context(int) - Static method in class org.zeromq.ZMQ
-
Create a new Context.
- Context(int) - Constructor for class org.zeromq.ZMQ.Context
-
Class constructor.
- ContextHolder() - Constructor for class org.zeromq.ManagedContext.ContextHolder
- Contexts - Search tag in class org.zeromq.ZMQ
- Section
- cookieKey - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- count - Variable in class zmq.socket.pubsub.Mtrie
- count - Variable in class zmq.socket.pubsub.Trie
- counter - Static variable in class org.zeromq.ZProxy
- cpipe - Variable in class zmq.Mailbox
- cpipe - Variable in class zmq.MailboxSafe
- create() - Method in interface org.zeromq.ZAgent.SelectorCreator
-
Deprecated.Creates and opens a selector.
- create(int, Ctx, int, int) - Static method in enum zmq.socket.Sockets
- create(String) - Static method in class zmq.SocketBase.SimpleURI
- create(SelectableChannel, ZPoller.EventsHandler, int) - Method in class org.zeromq.ZPoller
- create(SelectableChannel, ZPoller.EventsHandler, int) - Method in interface org.zeromq.ZPoller.ItemCreator
-
Creates a new holder for a poll item.
- create(SelectableChannel, ZPoller.EventsHandler, int) - Method in class org.zeromq.ZPoller.SimpleCreator
- create(ZContext, ZMQ.Socket, int, ZStar.Star, Object...) - Method in class org.zeromq.ZActor.ActorFortune
- create(ZContext, ZMQ.Socket, int, ZStar.Star, Object...) - Method in interface org.zeromq.ZStar.Fortune
-
Creates a star.
- create(ZContext, ZMQ.Socket, Selector, int, ZStar.Star, Object...) - Method in interface org.zeromq.ZStar.Fortune
-
Deprecated.
- create(ZContext, ZProxy.Plug, Object...) - Method in interface org.zeromq.ZProxy.Proxy
-
Creates and initializes (bind, options ...) the socket for the given plug in the proxy.
- create(ZMQ.Socket, String) - Static method in class org.zeromq.ZAgent.Creator
- create(ZMQ.Socket, ZPoller.EventsHandler, int) - Method in class org.zeromq.ZPoller
- create(ZMQ.Socket, ZPoller.EventsHandler, int) - Method in interface org.zeromq.ZPoller.ItemCreator
-
Creates a new holder for a poll item.
- create(ZMQ.Socket, ZPoller.EventsHandler, int) - Method in class org.zeromq.ZPoller.SimpleCreator
- create(Ctx, int, int) - Method in enum zmq.socket.Sockets
- create(IOThread, boolean, SocketBase, Options, Address) - Method in enum zmq.socket.Sockets
- create(SessionBase, Address, Options) - Method in enum zmq.io.mechanism.Mechanisms
- createAgent(ZContext) - Method in class org.zeromq.ZAuth.AuthActor
- createBlob(byte[]) - Static method in class zmq.util.Blob
- createBlob(byte[], boolean) - Static method in class zmq.util.Blob
- createBlob(Msg) - Static method in class zmq.util.Blob
- createCancellationToken() - Method in class org.zeromq.ZMQ.Socket
-
Create a
ZMQ.CancellationToken
to cancel send/receive operations for this socket. - createContainer(int) - Method in class org.zeromq.ZPoller
-
Deprecated.
- createContext() - Static method in class zmq.ZMQ
- createDefaultName(String, int) - Static method in class org.zeromq.ZStar.SimpleSet
- createItem() - Method in class org.zeromq.ZPoller.CompositePollItem
- createPoller(int) - Method in class org.zeromq.ZContext
- createSelector() - Method in class org.zeromq.ZContext
-
Deprecated.this was exposed by mistake.
- createSelector() - Method in class zmq.Ctx
- createSession(IOThread, boolean, SocketBase, Options, Address) - Static method in enum zmq.socket.Sockets
- createSocket(int) - Method in class org.zeromq.ManagedContext
- createSocket(int) - Method in class org.zeromq.ZContext
-
Deprecated.
- createSocket(int) - Method in class zmq.Ctx
- createSocket(SocketType) - Method in class org.zeromq.ZContext
-
Creates a new managed socket within this ZContext instance.
- createSockets(ZContext, Object...) - Method in interface org.zeromq.ZActor.Actor
-
Creates and initializes sockets for the double.
- createSockets(ZContext, Object...) - Method in class org.zeromq.ZActor.Duo
- createSockets(ZContext, Object...) - Method in class org.zeromq.ZActor.SimpleActor
- createSockets(ZContext, Object...) - Method in class org.zeromq.ZAuth.AuthActor
- createSockets(ZContext, Object...) - Method in class org.zeromq.ZMonitor.MonitorActor
- createSockets(ZContext, Object...) - Method in class org.zeromq.ZProxy.ProxyActor
- createWorker(String) - Method in class zmq.poll.PollerBase
- creator - Variable in class org.zeromq.ZPoller
- Creator() - Constructor for class org.zeromq.ZAgent.Creator
- credential - Variable in class zmq.pipe.Pipe
- CREDENTIAL - Static variable in class zmq.Msg
- cryptoBox - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- cryptoBox - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- ctx - Variable in class org.zeromq.ManagedContext
- ctx - Variable in class org.zeromq.ZMQ.Context
- ctx - Variable in class org.zeromq.ZThread.ShimThread
- ctx - Variable in class zmq.poll.Poller
- ctx - Variable in class zmq.Signaler
- ctx - Variable in class zmq.ZObject
- Ctx - Class in zmq
- Ctx() - Constructor for class zmq.Ctx
- Ctx.ChannelForwardHolder - Class in zmq
-
A class that holds the informations needed to forward channel in monitor sockets.
- Ctx.Endpoint - Class in zmq
- Ctx.PendingConnection - Class in zmq
- Ctx.Side - Enum in zmq
- ctxTerminated - Variable in class zmq.SocketBase
- CtxTerminatedException() - Constructor for exception class zmq.ZError.CtxTerminatedException
- current - Variable in class zmq.socket.FQ
- current - Variable in class zmq.socket.LB
- currentLine - Variable in exception class org.zeromq.ZConfig.ReadException
- currentLineNumber - Variable in exception class org.zeromq.ZConfig.ReadException
- currentOut - Variable in class zmq.socket.reqrep.Router
- currentOut - Variable in class zmq.socket.Stream
- currentReconnectIvl - Variable in class zmq.io.net.tcp.TcpConnecter
- Curve - Class in zmq.io.mechanism.curve
- Curve() - Constructor for class org.zeromq.ZMQ.Curve
- Curve() - Constructor for class zmq.io.mechanism.curve.Curve
- CURVE - Enum constant in enum org.zeromq.ZMQ.Socket.Mechanism
- CURVE - Enum constant in enum zmq.io.mechanism.Mechanisms
- CURVE_ALLOW_ANY - Static variable in class org.zeromq.ZAuth
- CURVE_KEYSIZE - Static variable in class zmq.Options
- CURVE_KEYSIZE_Z85 - Static variable in class zmq.Options
- Curve.Size - Enum in zmq.io.mechanism.curve
- CurveClientMechanism - Class in zmq.io.mechanism.curve
- CurveClientMechanism(SessionBase, Options) - Constructor for class zmq.io.mechanism.curve.CurveClientMechanism
- CurveClientMechanism.State - Enum in zmq.io.mechanism.curve
- curvePublicKey - Variable in class zmq.Options
- curveSecretKey - Variable in class zmq.Options
- curveServerKey - Variable in class zmq.Options
- CurveServerMechanism - Class in zmq.io.mechanism.curve
- CurveServerMechanism(SessionBase, Address, Options) - Constructor for class zmq.io.mechanism.curve.CurveServerMechanism
- CurveServerMechanism.State - Enum in zmq.io.mechanism.curve
- curveVariant(ZCertStore.Fingerprinter) - Static method in class org.zeromq.ZAuth
- custom(ZMQ.Socket, String, ZMQ.Socket, ZMQ.Socket, ZMQ.Socket, Object...) - Method in interface org.zeromq.ZProxy.Proxy
-
Handles a custom command not recognized by the proxy.
- custom(ZMQ.Socket, String, ZMQ.Socket, ZMQ.Socket, ZMQ.Socket, Object...) - Method in class org.zeromq.ZProxy.Proxy.SimpleProxy
D
- data - Variable in class org.zeromq.util.ZData
- data - Variable in class org.zeromq.ZFrame
- data - Variable in class zmq.util.MultiMap
- data() - Method in class org.zeromq.util.ZDigest
- data() - Method in class zmq.Msg
-
Returns the message data.
- data() - Method in class zmq.util.Blob
- DATA - Enum constant in enum zmq.Msg.Type
- dbuffer - Variable in class zmq.pipe.YPipeConflate
- DBuffer<T> - Class in zmq.pipe
- DBuffer() - Constructor for class zmq.pipe.DBuffer
- Dealer - Class in zmq.socket.reqrep
- Dealer(Ctx, int, int) - Constructor for class zmq.socket.reqrep.Dealer
- DEALER - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a DEALER socket (aka XREQ).
- DEALER - Enum constant in enum zmq.socket.Sockets
- DEALER - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- decode(String) - Static method in class zmq.util.Z85
- decode(ByteBuffer, int, ValueReference<Integer>) - Method in class zmq.io.coder.DecoderBase
- decode(ByteBuffer, int, ValueReference<Integer>) - Method in interface zmq.io.coder.IDecoder
- decode(ByteBuffer, int, ValueReference<Integer>) - Method in class zmq.io.coder.raw.RawDecoder
- decode(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- decode(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- decode(Msg) - Method in class zmq.io.mechanism.Mechanism
- decodeAndPush - Variable in class zmq.io.StreamEngine
- decodeAndPush(Msg) - Method in class zmq.io.StreamEngine
- decodeCurrentInputs() - Method in class zmq.io.StreamEngine
- DECODED - Enum constant in enum zmq.io.coder.IDecoder.Step.Result
- decodeDataAfterHandshake(int) - Method in class zmq.io.StreamEngine
- decoder - Variable in class zmq.io.StreamEngine
- decoder - Variable in class zmq.Options
- decoder - Static variable in class zmq.util.Z85
- Decoder - Class in zmq.io.coder
- Decoder(Errno, int, long, MsgAllocator) - Constructor for class zmq.io.coder.Decoder
- Decoder.EightByteSizeReady - Class in zmq.io.coder
- Decoder.FlagsReady - Class in zmq.io.coder
- Decoder.MessageReady - Class in zmq.io.coder
- Decoder.OneByteSizeReady - Class in zmq.io.coder
- DecoderBase - Class in zmq.io.coder
- DecoderBase(Errno, int) - Constructor for class zmq.io.coder.DecoderBase
- DEFAULT_BROADCAST_ADDRESS - Static variable in class org.zeromq.ZBeacon
- DEFAULT_BROADCAST_HOST - Static variable in class org.zeromq.ZBeacon
- DEFAULT_BROADCAST_HOST_ADDRESS - Static variable in class org.zeromq.ZBeacon
- DEFAULT_BROADCAST_INTERVAL - Static variable in class org.zeromq.ZBeacon
- delay - Variable in class org.zeromq.timer.ZTicket.Ticket
- delay - Variable in class org.zeromq.ZLoop.STimer
- delay - Variable in class zmq.pipe.Pipe
- delayedStart - Variable in class zmq.io.net.tcp.TcpConnecter
- delegate - Variable in class org.zeromq.timer.ZTimer.Timer
- delegate - Variable in class org.zeromq.ZTimer.Timer
-
Deprecated.
- delete(File) - Static method in class zmq.util.Utils
- delete(File) - Static method in class zmq.Utils
-
Deprecated.
- DELIMITER - Enum constant in enum zmq.Msg.Type
- DELIMITER_RECEIVED - Enum constant in enum zmq.pipe.Pipe.State
- deny(String) - Method in class org.zeromq.ZAuth
-
Deny (blacklist) a single IP address.
- DENY - Static variable in class org.zeromq.ZAuth
- descendingIterator() - Method in class org.zeromq.ZMsg
- destination - Variable in class zmq.Command
- destroy() - Method in class org.zeromq.ZAuth
-
Destructor.
- destroy() - Method in class org.zeromq.ZContext
-
Destructor.
- destroy() - Method in class org.zeromq.ZFrame
-
Destructor.
- destroy() - Method in class org.zeromq.ZLoop
-
Deprecated.no-op behaviour
- destroy() - Method in class org.zeromq.ZMonitor
-
Stops the monitoring and closes the actor.
- destroy() - Method in class org.zeromq.ZMsg
-
Destructor.
- destroy() - Method in class org.zeromq.ZPoller
-
Destroys the poller without exception.
- destroy() - Method in class zmq.Ctx
- destroy() - Method in class zmq.io.coder.DecoderBase
- destroy() - Method in class zmq.io.coder.EncoderBase
- destroy() - Method in interface zmq.io.coder.IDecoder
- destroy() - Method in interface zmq.io.coder.IEncoder
- destroy() - Method in class zmq.io.coder.raw.RawDecoder
- destroy() - Method in class zmq.io.mechanism.Mechanism
- destroy() - Method in class zmq.io.net.tcp.TcpConnecter
- destroy() - Method in class zmq.io.net.tcp.TcpListener
- destroy() - Method in class zmq.io.SessionBase
- destroy() - Method in class zmq.io.StreamEngine
- destroy() - Method in class zmq.Own
- destroy() - Method in class zmq.poll.Poller
- destroy() - Method in class zmq.socket.Channel
- destroy() - Method in class zmq.socket.clientserver.Server
- destroy() - Method in class zmq.socket.Pair
- destroy() - Method in class zmq.socket.reqrep.Router
- destroy() - Method in class zmq.SocketBase
- destroy(Selector) - Method in interface org.zeromq.ZAgent.SelectorCreator
-
Deprecated.Destroys the previously opened selector.
- destroy(SocketBase) - Method in class org.zeromq.ManagedContext
- destroyContext(Ctx) - Static method in class zmq.ZMQ
- destroyed - Variable in class zmq.SocketBase
- destroyed(ZContext, ZMQ.Socket, ZPoller) - Method in interface org.zeromq.ZActor.Actor
-
Called when the current double has been destroyed.
- destroyed(ZContext, ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZActor.Duo
- destroyed(ZContext, ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZActor.SimpleActor
- destroyed(ZContext, ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZProxy.ProxyActor
- destroySocket(ZMQ.Socket) - Method in class org.zeromq.ZContext
-
Deprecated.Not to be used any more.
ZMQ.Socket
handle the close itself. It also override linger settings. - destroySocket(SocketBase) - Method in class zmq.Ctx
- destroySocket(SocketBase) - Method in class zmq.ZObject
- detachedRunnable - Variable in class org.zeromq.ZThread.ShimThread
- device(int, ZMQ.Socket, ZMQ.Socket) - Static method in class org.zeromq.ZMQ
-
Deprecated.
- device(int, SocketBase, SocketBase) - Static method in class zmq.ZMQ
- dictionary - Variable in class zmq.io.Metadata
- direct - Static variable in class zmq.msg.MsgAllocatorThreshold
- dirty - Variable in class org.zeromq.ZLoop
- disconnect(String) - Method in class org.zeromq.ZMQ.Socket
-
Disconnect from remote application.
- disconnect(String) - Method in class org.zeromq.ZSocket
-
Disconnecting a socket from an endpoint.
- disconnect(SocketBase, String) - Static method in class zmq.ZMQ
- DISCONNECTED - Enum constant in enum org.zeromq.ZMonitor.Event
- disconnectMsg - Variable in class zmq.Options
- disconnectMsg - Variable in class zmq.pipe.Pipe
- disconnectPeer(int) - Method in class zmq.SocketBase
- disconnectPeer(SocketBase, int) - Static method in class zmq.ZMQ
- Dish - Class in zmq.socket.radiodish
- Dish(Ctx, int, int) - Constructor for class zmq.socket.radiodish.Dish
- DISH - Enum constant in enum org.zeromq.SocketType
-
Flag to specify DISH socket.
- DISH - Enum constant in enum zmq.socket.Sockets
- Dish.DishSession - Class in zmq.socket.radiodish
- Dish.DishSession.State - Enum in zmq.socket.radiodish
- DishSession(IOThread, boolean, SocketBase, Options, Address) - Constructor for class zmq.socket.radiodish.Dish.DishSession
- dispatch() - Method in class org.zeromq.ZPoller
- dispatch(Collection<? extends ZPoller.ItemHolder>, int) - Method in class org.zeromq.ZPoller
-
Dispatches the polled events.
- dispatch(Set<ZPoller.CompositePollItem>, int) - Method in class org.zeromq.ZPoller
- dist - Variable in class zmq.socket.pubsub.XPub
- dist - Variable in class zmq.socket.pubsub.XSub
- dist - Variable in class zmq.socket.radiodish.Dish
- dist - Variable in class zmq.socket.radiodish.Radio
- Dist - Class in zmq.socket.pubsub
- Dist() - Constructor for class zmq.socket.pubsub.Dist
- distribute(Msg) - Method in class zmq.socket.pubsub.Dist
- domain - Variable in class org.zeromq.ZAuth.ZapRequest
- DONE - Enum constant in enum zmq.Command.Type
- DONTWAIT - Static variable in class org.zeromq.ZFrame
- DONTWAIT - Static variable in class org.zeromq.ZMQ
-
Socket flag to indicate a nonblocking send or recv mode.
- Double(ZContext, ZMQ.Socket, ZActor.Actor, Object...) - Constructor for class org.zeromq.ZActor.Double
- DOWNSTREAM - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- Draft - Annotation Type in zmq.util
-
Documents an API in DRAFT state.
- dropping - Variable in class zmq.socket.LB
- dump() - Method in class org.zeromq.ZMsg
- dump(Appendable) - Method in class org.zeromq.ZMsg
-
Dump the message in human readable format.
- dump(ByteBuffer, int, int) - Static method in class zmq.util.Utils
- Duo(ZActor.Actor, ZActor.Actor) - Constructor for class org.zeromq.ZActor.Duo
- duplicate() - Method in class org.zeromq.ZFrame
-
Creates a new frame that duplicates an existing frame
- duplicate() - Method in class org.zeromq.ZMsg
-
Creates copy of this ZMsg.
- DYNFROM - Static variable in class org.zeromq.ZMQ.Socket
- DYNTO - Static variable in class org.zeromq.ZMQ.Socket
E
- EACCESS - Enum constant in enum org.zeromq.ZMQ.Error
- EACCESS - Static variable in class zmq.ZError
- EADDRINUSE - Enum constant in enum org.zeromq.ZMQ.Error
- EADDRINUSE - Static variable in class zmq.ZError
- EADDRNOTAVAIL - Enum constant in enum org.zeromq.ZMQ.Error
- EADDRNOTAVAIL - Static variable in class zmq.ZError
- EAFNOSUPPORT - Enum constant in enum org.zeromq.ZMQ.Error
- EAFNOSUPPORT - Static variable in class zmq.ZError
- EAGAIN - Enum constant in enum org.zeromq.ZMQ.Error
- EAGAIN - Static variable in class zmq.ZError
- ECANCELED - Static variable in class zmq.ZError
- ECONNABORTED - Enum constant in enum org.zeromq.ZMQ.Error
- ECONNABORTED - Static variable in class zmq.ZError
- ECONNREFUSED - Enum constant in enum org.zeromq.ZMQ.Error
- ECONNREFUSED - Static variable in class zmq.ZError
- ECONNRESET - Enum constant in enum org.zeromq.ZMQ.Error
- ECONNRESET - Static variable in class zmq.ZError
- EFAULT - Enum constant in enum org.zeromq.ZMQ.Error
- EFAULT - Static variable in class zmq.ZError
- EFSM - Enum constant in enum org.zeromq.ZMQ.Error
- EFSM - Static variable in class zmq.ZError
- EHOSTUNREACH - Enum constant in enum org.zeromq.ZMQ.Error
- EHOSTUNREACH - Static variable in class zmq.ZError
- eightByteSizeReady - Variable in class zmq.io.coder.Decoder
- eightByteSizeReady() - Method in class zmq.io.coder.Decoder
- eightByteSizeReady() - Method in class zmq.io.coder.v1.V1Decoder
- eightByteSizeReady() - Method in class zmq.io.coder.v2.V2Decoder
- EightByteSizeReady() - Constructor for class zmq.io.coder.Decoder.EightByteSizeReady
- EINPROGRESS - Enum constant in enum org.zeromq.ZMQ.Error
- EINPROGRESS - Static variable in class zmq.ZError
- EINTR - Enum constant in enum org.zeromq.ZMQ.Error
- EINTR - Static variable in class zmq.ZError
- EINVAL - Enum constant in enum org.zeromq.ZMQ.Error
- EINVAL - Static variable in class zmq.ZError
- EIOEXC - Enum constant in enum org.zeromq.ZMQ.Error
- EIOEXC - Static variable in class zmq.ZError
- EISCONN - Enum constant in enum org.zeromq.ZMQ.Error
- EISCONN - Static variable in class zmq.ZError
- element() - Method in class org.zeromq.ZMsg
- eligible - Variable in class zmq.socket.pubsub.Dist
- eligible() - Method in class zmq.socket.pubsub.Dist
- EMFILE - Enum constant in enum org.zeromq.ZMQ.Error
- EMFILE - Static variable in class zmq.ZError
- emptySlots - Variable in class zmq.Ctx
- EMSGSIZE - Enum constant in enum org.zeromq.ZMQ.Error
- EMSGSIZE - Static variable in class zmq.ZError
- EMTHREAD - Enum constant in enum org.zeromq.ZMQ.Error
- EMTHREAD - Static variable in class zmq.ZError
- enableIpv4Mapping(SelectableChannel) - Static method in class zmq.io.net.tcp.TcpUtils
- encode(byte[], int) - Static method in class zmq.util.Z85
- encode(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- encode(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- encode(Msg) - Method in class zmq.io.mechanism.Mechanism
- encode(ValueReference<ByteBuffer>, int) - Method in class zmq.io.coder.EncoderBase
- encode(ValueReference<ByteBuffer>, int) - Method in interface zmq.io.coder.IEncoder
- encoded() - Method in class zmq.io.coder.EncoderBase
- encoded() - Method in interface zmq.io.coder.IEncoder
- encoder - Variable in class zmq.io.StreamEngine
- encoder - Variable in class zmq.Options
- encoder - Static variable in class zmq.util.Z85
- Encoder - Class in zmq.io.coder
- Encoder(Errno, int) - Constructor for class zmq.io.coder.Encoder
- EncoderBase - Class in zmq.io.coder
- EncoderBase(Errno, int) - Constructor for class zmq.io.coder.EncoderBase
- encodingError() - Method in class zmq.io.coder.EncoderBase
- endChunk - Variable in class zmq.pipe.YQueue
- endpoint - Variable in class zmq.Ctx.PendingConnection
- endpoint - Variable in class zmq.io.net.tcp.SocksConnecter
- endpoint - Variable in class zmq.io.net.tcp.TcpListener
- endpoint - Variable in class zmq.io.StreamEngine
- endpoint - Variable in class zmq.SocketBase.EndpointPipe
- Endpoint(SocketBase, Options) - Constructor for class zmq.Ctx.Endpoint
- EndpointPipe(Own, Pipe) - Constructor for class zmq.SocketBase.EndpointPipe
- endpoints - Variable in class zmq.Ctx
- endpoints - Variable in class zmq.SocketBase
- endpointsSync - Variable in class zmq.Ctx
- endPos - Variable in class zmq.pipe.YQueue
- ENETDOWN - Enum constant in enum org.zeromq.ZMQ.Error
- ENETDOWN - Static variable in class zmq.ZError
- ENETRESET - Enum constant in enum org.zeromq.ZMQ.Error
- ENETRESET - Static variable in class zmq.ZError
- ENETUNREACH - Enum constant in enum org.zeromq.ZMQ.Error
- ENETUNREACH - Static variable in class zmq.ZError
- engine - Variable in class zmq.io.SessionBase
- engineError(boolean, StreamEngine.ErrorReason) - Method in class zmq.io.SessionBase
- EngineNotImplemented - Class in zmq.io
- EngineNotImplemented() - Constructor for class zmq.io.EngineNotImplemented
- ENOBUFS - Enum constant in enum org.zeromq.ZMQ.Error
- ENOBUFS - Static variable in class zmq.ZError
- ENOCOMPATPROTO - Enum constant in enum org.zeromq.ZMQ.Error
- ENOCOMPATPROTO - Static variable in class zmq.ZError
- ENOENT - Enum constant in enum org.zeromq.ZMQ.Error
- ENOENT - Static variable in class zmq.ZError
- ENOTCONN - Enum constant in enum org.zeromq.ZMQ.Error
- ENOTCONN - Static variable in class zmq.ZError
- ENOTSOCK - Enum constant in enum org.zeromq.ZMQ.Error
- ENOTSOCK - Static variable in class zmq.ZError
- ENOTSUP - Enum constant in enum org.zeromq.ZMQ.Error
- ENOTSUP - Static variable in class zmq.ZError
- enterInEvent() - Method in class zmq.SocketBase
- entract() - Method in class org.zeromq.ZActor.Double
- entract() - Method in interface org.zeromq.ZStar.Star
-
Called as an interval between each act.
Hint: Can be used to perform decisions to continue next loop or not, or to send computed data to outputs, or ...
Key point: at the end of a loop.
Decision: to act on the next loop or not - entries() - Method in class zmq.util.MultiMap
- entries() - Method in class zmq.util.Timers
- EntryComparator() - Constructor for class zmq.util.MultiMap.EntryComparator
- epgm - Enum constant in enum zmq.io.net.NetProtocol
- EPROTO - Enum constant in enum org.zeromq.ZMQ.Error
- EPROTO - Static variable in class zmq.ZError
- EPROTONOSUPPORT - Enum constant in enum org.zeromq.ZMQ.Error
- EPROTONOSUPPORT - Static variable in class zmq.ZError
- equals(byte[]) - Method in class org.zeromq.util.ZData
- equals(Object) - Method in class org.zeromq.util.ZData
- equals(Object) - Method in class org.zeromq.util.ZMetadata
- equals(Object) - Method in class org.zeromq.ZFrame
- equals(Object) - Method in class org.zeromq.ZMQ.PollItem
- equals(Object) - Method in class org.zeromq.ZMsg
- equals(Object) - Method in class org.zeromq.ZPoller.ZPollItem
- equals(Object) - Method in class zmq.io.Metadata
- equals(Object) - Method in class zmq.poll.Poller.Handle
- equals(Object) - Method in class zmq.poll.PollerBase.TimerInfo
- equals(Object) - Method in class zmq.util.Blob
- ERR - Static variable in class org.zeromq.ZPoller
- errno - Variable in class zmq.Ctx
- errno - Variable in class zmq.io.coder.DecoderBase
- errno - Variable in class zmq.io.coder.EncoderBase
- errno - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- errno - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- errno - Variable in class zmq.io.StreamEngine
- errno - Variable in class zmq.Mailbox
- errno - Variable in class zmq.MailboxSafe
- errno - Variable in class zmq.Options
- errno - Variable in class zmq.Own
- errno - Variable in class zmq.Signaler
- errno() - Method in class org.zeromq.ZMQ.Socket
- errno() - Method in class zmq.Ctx
- errno() - Method in class zmq.io.coder.DecoderBase
- errno() - Method in class zmq.io.coder.EncoderBase
- errno() - Method in class zmq.SocketBase
- errno(int) - Method in class zmq.io.coder.DecoderBase
- errno(int) - Method in class zmq.io.coder.EncoderBase
- Errno - Class in zmq.util
- Errno() - Constructor for class zmq.util.Errno
- error - Variable in class zmq.io.coder.EncoderBase
- error() - Method in class zmq.io.net.tcp.SocksConnecter
- error(Object) - Method in class org.zeromq.ZPoller
- error(SelectableChannel) - Method in class org.zeromq.ZPoller
- error(ZMQ.Socket) - Method in class org.zeromq.ZPoller
- error(StreamEngine.ErrorReason) - Method in class zmq.io.StreamEngine
- Error(int) - Constructor for enum org.zeromq.ZMQ.Error
- Error(int, String) - Constructor for enum org.zeromq.ZMQ.Error
- ERROR - Enum constant in enum zmq.io.coder.IDecoder.Step.Result
- ERROR - Enum constant in enum zmq.io.mechanism.Mechanism.Status
- ERROR - Static variable in class org.zeromq.ZMonitor.MonitorActor
- ERROR - Static variable in class zmq.io.mechanism.NullMechanism
- ERROR_COMMAND_RECEIVED - Enum constant in enum zmq.io.mechanism.plain.PlainClientMechanism.State
- ERROR_COMMAND_SENT - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- ERROR_RECEIVED - Enum constant in enum zmq.io.mechanism.curve.CurveClientMechanism.State
- ERROR_SENT - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- errorCommandReceived - Variable in class zmq.io.mechanism.NullMechanism
- errorCommandSent - Variable in class zmq.io.mechanism.NullMechanism
- ErrorReason() - Constructor for enum zmq.io.StreamEngine.ErrorReason
- errors - Variable in class org.zeromq.ZLoop.SPoller
- ESOCKET - Enum constant in enum org.zeromq.ZMQ.Error
- ESOCKET - Static variable in class zmq.ZError
- ETERM - Enum constant in enum org.zeromq.ZMQ.Error
- ETERM - Static variable in class zmq.ZError
- ETIMEDOUT - Enum constant in enum org.zeromq.ZMQ.Error
- ETIMEDOUT - Static variable in class zmq.ZError
- event - Variable in class org.zeromq.ZMQ.Event
- event - Variable in class zmq.ZMQ.Event
- event(String, Object, int) - Method in class zmq.SocketBase
- Event(int) - Constructor for enum org.zeromq.ZMonitor.Event
- Event(int, Object, Object, String) - Constructor for class org.zeromq.ZMQ.Event
- Event(int, Object, String) - Constructor for class org.zeromq.ZMQ.Event
- Event(int, String, Object) - Constructor for class zmq.ZMQ.Event
- Event(int, String, Object, int) - Constructor for class zmq.ZMQ.Event
- EVENT_ACCEPT_FAILED - Static variable in class org.zeromq.ZMQ
-
EVENT_ACCEPT_FAILED: could not accept client connection.
- EVENT_ACCEPTED - Static variable in class org.zeromq.ZMQ
-
EVENT_ACCEPTED: connection accepted to bound interface.
- EVENT_ALL - Static variable in class org.zeromq.ZMQ
-
EVENT_ALL: all events known.
- EVENT_BIND_FAILED - Static variable in class org.zeromq.ZMQ
-
EVENT_BIND_FAILED: socket could not bind to an address.
- EVENT_CLOSE_FAILED - Static variable in class org.zeromq.ZMQ
-
EVENT_CLOSE_FAILED: connection couldn't be closed.
- EVENT_CLOSED - Static variable in class org.zeromq.ZMQ
-
EVENT_CLOSED: connection closed.
- EVENT_CONNECT_DELAYED - Static variable in class org.zeromq.ZMQ
-
EVENT_CONNECT_DELAYED: synchronous connect failed, it's being polled.
- EVENT_CONNECT_RETRIED - Static variable in class org.zeromq.ZMQ
-
EVENT_CONNECT_RETRIED: asynchronous connect / reconnection attempt.
- EVENT_CONNECTED - Static variable in class org.zeromq.ZMQ
-
EVENT_CONNECTED: connection established.
- EVENT_DELAYED - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- EVENT_DISCONNECTED - Static variable in class org.zeromq.ZMQ
-
EVENT_DISCONNECTED: broken session.
- EVENT_HANDSHAKE_PROTOCOL - Static variable in class org.zeromq.ZMQ
-
EVENT_HANDSHAKE_PROTOCOL: protocol has been successfully negotiated.
- EVENT_LISTENING - Static variable in class org.zeromq.ZMQ
-
EVENT_LISTENING: socket bound to an address, ready to accept connections.
- EVENT_MONITOR_STOPPED - Static variable in class org.zeromq.ZMQ
-
EVENT_MONITOR_STOPPED: monitor has been stopped.
- EVENT_RETRIED - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- eventAccepted(String, SelectableChannel) - Method in class zmq.SocketBase
- eventAcceptFailed(String, int) - Method in class zmq.SocketBase
- eventBindFailed(String, int) - Method in class zmq.SocketBase
- eventClosed(String, SelectableChannel) - Method in class zmq.SocketBase
- eventCloseFailed(String, int) - Method in class zmq.SocketBase
- eventConnectDelayed(String, int) - Method in class zmq.SocketBase
- eventConnected(String, SelectableChannel) - Method in class zmq.SocketBase
- eventConnectRetried(String, int) - Method in class zmq.SocketBase
- eventDisconnected(String, SelectableChannel) - Method in class zmq.SocketBase
- eventHandshakeFailedAuth(String, int) - Method in class zmq.SocketBase
- eventHandshakeFailedNoDetail(String, int) - Method in class zmq.SocketBase
- eventHandshakeFailedProtocol(String, int) - Method in class zmq.SocketBase
- eventHandshaken(String, int) - Method in class zmq.SocketBase
- eventHandshakeSucceeded(String, int) - Method in class zmq.SocketBase
- eventListening(String, SelectableChannel) - Method in class zmq.SocketBase
- events - Variable in class org.zeromq.ZMonitor.MonitorActor
- events(SelectableChannel, int) - Method in class org.zeromq.ZActor.Double
- events(SelectableChannel, int) - Method in class org.zeromq.ZPoller.ComposeEventsHandler
- events(SelectableChannel, int) - Method in class org.zeromq.ZPoller.CompositePollItem
- events(SelectableChannel, int) - Method in interface org.zeromq.ZPoller.EventsHandler
-
Called when the poller intercepts events.
- events(ZMQ.Socket, int) - Method in class org.zeromq.ZActor.Double
- events(ZMQ.Socket, int) - Method in class org.zeromq.ZPoller.ComposeEventsHandler
- events(ZMQ.Socket, int) - Method in class org.zeromq.ZPoller.CompositePollItem
- events(ZMQ.Socket, int) - Method in interface org.zeromq.ZPoller.EventsHandler
-
Called when the poller intercepts events.
- EVENTVALUES - Static variable in class org.zeromq.ZMonitor.ZEvent
- exccode(IOException) - Static method in class zmq.ZError
- execute() - Method in class org.zeromq.timer.ZTicker
- execute() - Method in class org.zeromq.timer.ZTicket
-
Execute the tickets.
- execute() - Method in class org.zeromq.timer.ZTimer
-
Execute the timers.
- execute() - Method in class org.zeromq.ZTimer
-
Deprecated.Execute the timers.
- execute() - Method in class zmq.util.Timers
-
Execute the timers.
- executeTimers() - Method in class zmq.poll.PollerBase
- exhandler - Variable in class zmq.Ctx
- exit - Variable in class org.zeromq.ZAuth
- exit - Variable in class org.zeromq.ZMonitor
- exit - Variable in class org.zeromq.ZProxy
- exit - Variable in class org.zeromq.ZStar.Plateau
- exit() - Method in class org.zeromq.ZProxy
-
Stops the proxy and exits.
- exit() - Method in class org.zeromq.ZStar
-
Returns the control of the proper exit of the remote operations.
- exit(boolean) - Method in class org.zeromq.ZProxy
-
Deprecated.The call is synchronous: the sync parameter is ignored, as it leads to many mistakes in case of a provided ZContext.
- EXIT - Enum constant in enum org.zeromq.ZProxy.Command
- EXIT - Static variable in class org.zeromq.ZProxy
- EXITED - Enum constant in enum org.zeromq.ZProxy.State
- EXITED - Static variable in class org.zeromq.ZProxy
- exnotification - Variable in class zmq.Ctx
- exnotification - Variable in class zmq.poll.Poller
- EXPECT_HELLO - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- EXPECT_INITIATE - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- EXPECT_READY - Enum constant in enum zmq.io.mechanism.curve.CurveClientMechanism.State
- EXPECT_WELCOME - Enum constant in enum zmq.io.mechanism.curve.CurveClientMechanism.State
- EXPECT_ZAP_REPLY - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- extractFlags(Msg) - Method in class zmq.SocketBase
- extractString(Charset, ByteBuffer, int, int, int) - Static method in class zmq.util.Wire
F
- f - Variable in class zmq.pipe.YPipe
- family() - Method in interface zmq.io.net.Address.IZAddress
- family() - Method in class zmq.io.net.ipc.IpcAddress
- family() - Method in class zmq.io.net.tcp.TcpAddress
- fd - Variable in class zmq.io.net.tcp.TcpConnecter
- fd - Variable in class zmq.io.net.tcp.TcpListener
- fd - Variable in class zmq.io.StreamEngine
- fd - Variable in class zmq.poll.Poller.Handle
- fd() - Method in class zmq.Msg
- fdTable - Variable in class zmq.poll.Poller
- fileDesc - Variable in class zmq.Msg
- fileDesc - Variable in class zmq.SocketBase
- fillValues(String, Map<String, String>) - Method in class org.zeromq.ZConfig
- filter - Variable in class zmq.Options
- filter(Object, int) - Method in class org.zeromq.ZPoller
- find(V) - Method in class zmq.util.MultiMap
- find(Mechanisms) - Static method in enum org.zeromq.ZMQ.Socket.Mechanism
- findAddress(boolean, boolean) - Method in class zmq.io.net.ipc.IpcAddress
- findByCode(int) - Static method in enum org.zeromq.ZMonitor.Event
-
Find the
ZMonitor.Event
associated with the numerical event code. - findByCode(int) - Static method in enum org.zeromq.ZMonitor.ProtocolCode
-
Find the
ZMonitor.ProtocolCode
associated with the numerical error code send witheventHandshakeXXX
. - findByCode(int) - Static method in enum org.zeromq.ZMQ.Error
- findEndpoint(String) - Method in class zmq.Ctx
- findEndpoint(String) - Method in class zmq.ZObject
- findOpenPort() - Static method in class org.zeromq.Utils
- findOpenPort() - Static method in class zmq.util.Utils
- findOpenPort() - Static method in class zmq.Utils
-
Deprecated.
- finger - Variable in class org.zeromq.ZCertStore
- fingerprinter - Variable in class org.zeromq.ZAuth.SimpleCurveAuth
- fingerprints - Variable in class org.zeromq.ZCertStore
- finished(ZMQ.Socket) - Method in interface org.zeromq.ZActor.Actor
-
Called when the stage is finished.
- finished(ZMQ.Socket) - Method in class org.zeromq.ZActor.Duo
- finished(ZMQ.Socket) - Method in class org.zeromq.ZActor.SimpleActor
- finishTerminating() - Method in class zmq.Reaper
- fire() - Method in interface org.zeromq.ZStar.Set
-
Is the set on fire ?
- fire() - Method in class org.zeromq.ZStar.SimpleSet
- flag - Variable in class zmq.ZMQ.Event
- flags - Variable in class zmq.Msg
- flags() - Method in class zmq.Msg
- flagsReady - Variable in class zmq.io.coder.Decoder
- flagsReady() - Method in class zmq.io.coder.Decoder
- flagsReady() - Method in class zmq.io.coder.v1.V1Decoder
- flagsReady() - Method in class zmq.io.coder.v2.V2Decoder
- FlagsReady() - Constructor for class zmq.io.coder.Decoder.FlagsReady
- flow(ZProxy.Plug, ZMQ.Socket, ZMQ.Socket, ZProxy.Plug, ZMQ.Socket) - Method in interface org.zeromq.ZProxy.Pump
-
Transfers a message from one source to one destination, with an optional capture.
- flow(ZProxy.Plug, ZMQ.Socket, ZMQ.Socket, ZProxy.Plug, ZMQ.Socket) - Method in class org.zeromq.ZProxy.ZmqPump
- flow(ZProxy.Plug, ZMQ.Socket, ZMQ.Socket, ZProxy.Plug, ZMQ.Socket) - Method in class org.zeromq.ZProxy.ZPump
- flush() - Method in class zmq.io.SessionBase
- flush() - Method in class zmq.pipe.Pipe
- flush() - Method in class zmq.pipe.YPipe
- flush() - Method in interface zmq.pipe.YPipeBase
- flush() - Method in class zmq.pipe.YPipeConflate
- fork(ZContext, ZThread.IAttachedRunnable, Object...) - Static method in class org.zeromq.ZThread
- fork(ZThread.IAttachedRunnable, Object...) - Method in class org.zeromq.ZContext
-
Create an attached thread, An attached thread gets a ctx and a PAIR pipe back to its parent.
- FORMAT - Static variable in class org.zeromq.proto.ZPicture
- forward(int) - Method in class org.zeromq.proto.ZNeedle
- forward(SocketBase, SocketBase, SocketBase) - Method in class zmq.Proxy
- forwardChannel(SelectableChannel) - Method in class zmq.Ctx
-
Forward a channel in a monitor socket.
- FORWARDER - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- forwardHolder - Variable in class zmq.Ctx
- fq - Variable in class zmq.socket.clientserver.Client
- fq - Variable in class zmq.socket.clientserver.Server
- fq - Variable in class zmq.socket.pipeline.Pull
- fq - Variable in class zmq.socket.pubsub.XSub
- fq - Variable in class zmq.socket.radiodish.Dish
- fq - Variable in class zmq.socket.reqrep.Dealer
- fq - Variable in class zmq.socket.reqrep.Router
- fq - Variable in class zmq.socket.scattergather.Gather
- fq - Variable in class zmq.socket.Stream
- FQ - Class in zmq.socket
- FQ() - Constructor for class zmq.socket.FQ
- frames - Variable in class org.zeromq.ZMsg
-
Hold internal list of ZFrame objects
- fromType(int) - Static method in enum zmq.socket.Sockets
- front - Variable in class zmq.pipe.DBuffer
- front() - Method in class zmq.pipe.DBuffer
- front() - Method in class zmq.pipe.YQueue
- FRONT - Enum constant in enum org.zeromq.ZProxy.Plug
- frontend - Variable in class org.zeromq.ZProxy.ProxyActor
- frontPos() - Method in class zmq.pipe.YQueue
- Function<T,
R> - Interface in zmq.util.function -
Represents a function that accepts one argument and produces a result.
G
- Gather - Class in zmq.socket.scattergather
- Gather(Ctx, int, int) - Constructor for class zmq.socket.scattergather.Gather
- GATHER - Enum constant in enum org.zeromq.SocketType
-
Flag to specify GATHER socket.
- GATHER - Enum constant in enum zmq.socket.Sockets
- generateKeyPair() - Static method in class org.zeromq.ZMQ.Curve
-
Returns a newly generated random keypair consisting of a public key and a secret key.
- get() - Method in class zmq.io.StreamEngine.ProducePongMessage
- get() - Method in class zmq.Msg
- get() - Method in class zmq.util.Errno
- get() - Method in interface zmq.util.function.Supplier
-
Gets a result.
- get() - Method in class zmq.util.ValueReference
- get(int) - Method in class zmq.Ctx
- get(int) - Method in class zmq.Msg
- get(String) - Method in class org.zeromq.util.ZMetadata
- get(String) - Method in class zmq.io.Metadata
- get(BiFunction<ByteBuffer, Integer, T>, int) - Method in class org.zeromq.proto.ZNeedle
- getAddress() - Method in class org.zeromq.ZMQ.Event
- getAddress() - Method in class zmq.io.net.ipc.IpcListener
- getAddress() - Method in class zmq.io.net.Listener
- getAddress() - Method in class zmq.io.net.tcp.TcpListener
- getAddress() - Method in class zmq.SocketBase.SimpleURI
- getAffinity() - Method in class org.zeromq.ZMQ.Socket
- getAsServerCurve() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the naming is inconsistent with jzmq, please use
ZMQ.Socket.getCurveServer()
instead - getAsServerPlain() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the naming is inconsistent with jzmq, please use
ZMQ.Socket.getPlainServer()
instead - getBacklog() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_BACKLOG option shall retrieve the maximum length of the queue of outstanding peer connections for the specified socket; this only applies to connection-oriented transports.
- getBeacon() - Method in class org.zeromq.ZBeacon
- getBlock(int) - Method in class org.zeromq.proto.ZNeedle
- getBlocky() - Method in class org.zeromq.ZMQ.Context
-
Deprecated.use
ZMQ.Context.isBlocky()
instead - getBroadcastInterval() - Method in class org.zeromq.ZBeacon
- getBuffer() - Method in class zmq.io.coder.DecoderBase
- getBuffer() - Method in interface zmq.io.coder.IDecoder
- getBuffer() - Method in class zmq.io.coder.raw.RawDecoder
- getBytes(int, byte[], int, int) - Method in class zmq.Msg
- getBytes(int, ByteBuffer, int) - Method in class zmq.Msg
- getCertificatesCount() - Method in class org.zeromq.ZCertStore
- getChannel() - Method in class zmq.poll.PollItem
- getChannel(SocketBase) - Method in class zmq.ZMQ.Event
-
Resolve the channel that was associated with this event.
- getChild(String) - Method in class org.zeromq.ZConfig
- getCode() - Method in enum org.zeromq.ZMQ.Error
- getConflate() - Method in class org.zeromq.ZMQ.Socket
-
If in conflate mode, a socket shall keep only one message in its inbound/outbound queue, this message being the last message received/the last message to be sent.
- getContext() - Method in class org.zeromq.ZContext
- getContextOption(Ctx, int) - Static method in class zmq.ZMQ
- getCredential() - Method in class zmq.pipe.Pipe
- getCredential() - Method in class zmq.socket.Channel
- getCredential() - Method in class zmq.socket.clientserver.Client
- getCredential() - Method in class zmq.socket.clientserver.Server
- getCredential() - Method in class zmq.socket.FQ
- getCredential() - Method in class zmq.socket.Pair
- getCredential() - Method in class zmq.socket.pipeline.Pull
- getCredential() - Method in class zmq.socket.pubsub.XSub
- getCredential() - Method in class zmq.socket.reqrep.Dealer
- getCredential() - Method in class zmq.socket.reqrep.Router
- getCredential() - Method in class zmq.socket.scattergather.Gather
- getCredential() - Method in class zmq.SocketBase
- getCtx() - Method in class zmq.ZObject
- getCurvePublicKey() - Method in class org.zeromq.ZMQ.Socket
-
Retrieves the current long term public key for the socket in binary format of 32 bytes.
- getCurveSecretKey() - Method in class org.zeromq.ZMQ.Socket
-
Retrieves the current long term secret key for the socket in binary format of 32 bytes.
- getCurveServer() - Method in class org.zeromq.ZMQ.Socket
-
Tells if the socket will act as server for CURVE security.
- getCurveServerKey() - Method in class org.zeromq.ZMQ.Socket
-
Retrieves the current server key for the socket in binary format of 32 bytes.
- getData() - Method in class org.zeromq.ZFrame
- getDelayAttachOnConnect() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.use
ZMQ.Socket.setImmediate(boolean)
instead (inverted logic: immediate = true <==> delay attach on connect = false) - getEndpoint() - Method in class zmq.io.SessionBase
- getEndPoint() - Method in class zmq.io.EngineNotImplemented
- getEndPoint() - Method in interface zmq.io.IEngine
- getEndPoint() - Method in class zmq.io.StreamEngine
- getErrorCode() - Method in exception class org.zeromq.ZMQException
- getEvent() - Method in class org.zeromq.ZMQ.Event
- getEvents() - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_EVENTS' option shall retrieve event flags for the specified socket.
- getFd() - Method in class zmq.Mailbox
- getFd() - Method in class zmq.Signaler
- getFD() - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_FD' option shall retrieve file descriptor associated with the 0MQ socket.
- getFD() - Method in class zmq.SocketBase
- getFirst() - Method in class org.zeromq.ZMsg
- getForwardedChannel(Integer) - Method in class zmq.Ctx
-
Retrieve a channel, using the handle returned by
Ctx.forwardChannel(SelectableChannel)
. - getFullVersion() - Static method in class org.zeromq.ZMQ
- getGlobalHandler() - Method in class org.zeromq.ZPoller
-
Returns the global events handler for all registered sockets.
- getGroup() - Method in class org.zeromq.ZFrame
-
Gets the group used for RADIO/DISH sockets.
- getGroup() - Method in class zmq.Msg
-
Retrieve the group for RADIO/DISH sockets
- getHandshakeIvl() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HANDSHAKE_IVL option shall retrieve the maximum handshake interval for the specified socket.
- getHeartbeatContext() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_CONTEXT option shall set the ping context of the peer for ZMTP heartbeats.
- getHeartbeatIvl() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_IVL option shall set the interval between sending ZMTP heartbeats for the specified socket.
- getHeartbeatTimeout() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_TIMEOUT option shall set how long to wait before timing-out a connection after sending a PING ZMTP command and not receiving any traffic.
- getHeartbeatTtl() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_TTL option shall set the timeout on the remote peer for ZMTP heartbeats.
- getHWM() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- getIdentity() - Method in class org.zeromq.ZMQ.Socket
- getIdentity() - Method in class zmq.pipe.Pipe
- getImmediate() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the state of the attach on connect value.
- getInstance() - Static method in class org.zeromq.ManagedContext
- getInt(int) - Method in class zmq.Msg
- getIoThreads() - Method in class org.zeromq.ZContext
- getIOThreads() - Method in class org.zeromq.ZMQ.Context
-
The size of the 0MQ thread pool to handle I/O operations.
- getIPv4Only() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.use
ZMQ.Socket.isIPv6()
instead (inverted logic: ipv4 = true <==> ipv6 = false) - getIPv6() - Method in class org.zeromq.ZMQ.Context
- getIPv6() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the IPv6 option for the socket.
- getItem(int) - Method in class org.zeromq.ZMQ.Poller
-
Get the PollItem associated with an index.
- getLast() - Method in class org.zeromq.ZMsg
- getLastEndpoint() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_LAST_ENDPOINT option shall retrieve the last endpoint bound for TCP and IPC transports.
- getLinger() - Method in class org.zeromq.ZContext
- getLinger() - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_LINGER' option shall retrieve the period for pending outbound messages to linger in memory after closing the socket.
- getList() - Method in class org.zeromq.proto.ZNeedle
- getListener() - Method in class org.zeromq.ZBeacon
- getListener(IOThread, SocketBase, Options) - Method in enum zmq.io.net.NetProtocol
- getLoad() - Method in class zmq.io.IOThread
- getLoad() - Method in class zmq.poll.PollerBase
- getLong(int) - Method in class zmq.Msg
- getLongString() - Method in class org.zeromq.proto.ZNeedle
- getLongString(ByteBuffer, int) - Static method in class zmq.util.Wire
- getLongString(Charset, ByteBuffer, int) - Static method in class zmq.util.Wire
- getMailbox() - Method in class zmq.io.IOThread
- getMailbox() - Method in class zmq.Reaper
- getMailbox() - Method in class zmq.SocketBase
- getMajorVersion() - Static method in class org.zeromq.ZMQ
- getMap() - Method in class org.zeromq.proto.ZNeedle
- getMaxMsgSize() - Method in class org.zeromq.ZMQ.Socket
-
The option shall retrieve limit for the inbound messages.
- getMaxSockets() - Method in class org.zeromq.ZMQ.Context
-
The maximum number of sockets allowed on the context
- getMechanism() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_MECHANISM option shall retrieve the current security mechanism for the socket.
- getMessage() - Method in enum org.zeromq.ZMQ.Error
- getMessageGroup(Msg) - Method in class zmq.ZMQ
- getMessageMetadata(Msg, String) - Static method in class zmq.ZMQ
- getMessageOption(Msg, int) - Static method in class zmq.ZMQ
- getMessageRoutingId(Msg) - Method in class zmq.ZMQ
- getMeta(String) - Method in class org.zeromq.ZCert
- getMetadata() - Method in class org.zeromq.ZCert
- getMetadata() - Method in class zmq.Msg
- getMetadata(String) - Method in class org.zeromq.ZCertStore
- getMinorVersion() - Static method in class org.zeromq.ZMQ
- getMsgAllocationHeapThreshold() - Method in class org.zeromq.ZMQ.Socket
-
Gets the limit threshold where messages of a given size will be allocated using Direct ByteBuffer.
- getMulticastHops() - Method in class org.zeromq.ZMQ.Socket
- getName() - Method in class org.zeromq.ZConfig
- getNewReconnectIvl() - Method in class zmq.io.net.tcp.SocksConnecter
- getNewReconnectIvl() - Method in class zmq.io.net.tcp.TcpConnecter
- getNext() - Method in class org.zeromq.ZMQ.Poller
-
Deprecated.use getSize instead
- getNotificationExceptionHandler() - Method in class org.zeromq.ZContext
- getNotificationExceptionHandler() - Method in class org.zeromq.ZMQ.Context
- getNotificationExceptionHandler() - Method in class zmq.Ctx
- getNumber1() - Method in class org.zeromq.proto.ZNeedle
- getNumber2() - Method in class org.zeromq.proto.ZNeedle
- getNumber4() - Method in class org.zeromq.proto.ZNeedle
- getNumber8() - Method in class org.zeromq.proto.ZNeedle
- getOption(int) - Method in class org.zeromq.ZSocket
- getPatchVersion() - Static method in class org.zeromq.ZMQ
- getPeerIpAddress(SocketChannel) - Static method in class zmq.io.net.tcp.TcpUtils
- getPeerIpAddress(SocketChannel) - Static method in class zmq.util.Utils
- getPeerIpAddress(SocketChannel) - Static method in class zmq.Utils
-
Deprecated.
- getPlainPassword() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_PLAIN_PASSWORD option shall retrieve the last password set for the PLAIN security mechanism.
- getPlainServer() - Method in class org.zeromq.ZMQ.Socket
-
Returns the ZMQ_PLAIN_SERVER option, if any, previously set on the socket.
- getPlainUsername() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_PLAIN_USERNAME option shall retrieve the last username set for the PLAIN security mechanism.
- getPoller() - Method in class zmq.io.IOThread
- getPrefix() - Method in class org.zeromq.ZBeacon
- getProtocol() - Method in class zmq.SocketBase.SimpleURI
- getProtocol(String) - Static method in enum zmq.io.net.NetProtocol
- getPublicKey() - Method in class org.zeromq.ZCert
- getPublicKeyAsZ85() - Method in class org.zeromq.ZCert
- getRate() - Method in class org.zeromq.ZMQ.Socket
- getRawSocket() - Method in class org.zeromq.ZMQ.PollItem
- getRawSocket() - Method in class zmq.poll.PollItem
- getRcvHWM() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RCVHWM option shall return the high water mark for inbound messages on the specified socket.
- getReaper() - Method in class zmq.Ctx
- getReceiveBufferSize() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RCVBUF option shall retrieve the underlying kernel receive buffer size for the specified socket.
- getReceiveTimeOut() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the timeout for recv operation on the socket.
- getReconnectIVL() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RECONNECT_IVL option shall retrieve the initial reconnection interval for the specified socket.
- getReconnectIVLMax() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RECONNECT_IVL_MAX option shall retrieve the maximum reconnection interval for the specified socket.
- getRecoveryInterval() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RECOVERY_IVL option shall retrieve the recovery interval for multicast transports using the specified socket.
- getReqCorrelate() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- getReqRelaxed() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- getRoutingId() - Method in class org.zeromq.ZFrame
-
Return frame routing ID, if the frame came from a ZMQ_SERVER socket.
- getRoutingId() - Method in class zmq.Msg
-
Return the routing id of a message.
- getRoutingId() - Method in class zmq.pipe.Pipe
- getSecretKey() - Method in class org.zeromq.ZCert
- getSecretKeyAsZ85() - Method in class org.zeromq.ZCert
- getSelectorProviderChooser() - Method in class org.zeromq.ZMQ.Socket
-
Return the custom
SelectorProvider
chooser. - getSendBufferSize() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_SNDBUF option shall retrieve the underlying kernel transmit buffer size for the specified socket.
- getSendTimeOut() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the timeout for send operation on the socket.
- getShort(int) - Method in class zmq.Msg
- getShortString() - Method in class org.zeromq.proto.ZNeedle
- getShortString(ByteBuffer, int) - Static method in class zmq.util.Wire
- getShortString(Charset, ByteBuffer, int) - Static method in class zmq.util.Wire
- getSize() - Method in class org.zeromq.ZMQ.Poller
-
Get the current poll set size.
- getSndHWM() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_SNDHWM option shall return the high water mark for outbound messages on the specified socket.
- getSocket() - Method in class org.zeromq.ZMQ.PollItem
- getSocket() - Method in class zmq.io.SessionBase
- getSocket() - Method in class zmq.poll.PollItem
- getSocket(int) - Method in class org.zeromq.ZMQ.Poller
-
Get the socket associated with an index.
- getSocketOpt(int) - Method in class zmq.Options
- getSocketOpt(int) - Method in class zmq.SocketBase
- getSocketOption(SocketBase, int) - Static method in class zmq.ZMQ
- getSocketOptionExt(SocketBase, int) - Static method in class zmq.ZMQ
- getSocketOptx(int) - Method in class zmq.SocketBase
- getSockets() - Method in class org.zeromq.ZContext
-
Return a copy of the list of currently open sockets.
- getSocketType() - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_TYPE option shall retrieve the socket type for the specified 'socket'.
- getSocketType() - Method in class org.zeromq.ZSocket
-
Retrieve the socket type for the current 'socket'.
- getSocksProxy() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_SOCKS_PROXY option shall retrieve the SOCKS5 proxy address in string format.
- getString() - Method in class org.zeromq.proto.ZNeedle
- getString(Charset) - Method in class org.zeromq.ZFrame
- getSwap() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- getTCPKeepAlive() - Method in class org.zeromq.ZMQ.Socket
- getTCPKeepAliveCount() - Method in class org.zeromq.ZMQ.Socket
- getTCPKeepAliveIdle() - Method in class org.zeromq.ZMQ.Socket
- getTCPKeepAliveInterval() - Method in class org.zeromq.ZMQ.Socket
- getTCPKeepAliveSetting() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- getTid() - Method in class zmq.ZObject
- getTimeout() - Method in class org.zeromq.ZMQ.Poller
-
Deprecated.Timeout handling has been moved to the poll() methods.
- getTos() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the IP_TOS option for the socket.
- getType() - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_TYPE option shall retrieve the socket type for the specified 'socket'.
- getType() - Method in class org.zeromq.ZSocket
-
Retrieve the socket type for the current 'socket'.
- getUInt16(byte[]) - Static method in class zmq.util.Wire
- getUInt16(ByteBuffer, int) - Static method in class zmq.util.Wire
- getUInt32(byte[], int) - Static method in class zmq.util.Wire
- getUInt32(ByteBuffer) - Static method in class zmq.util.Wire
- getUInt32(ByteBuffer, int) - Static method in class zmq.util.Wire
- getUInt32(Msg, int) - Static method in class zmq.util.Wire
- getUInt64(ByteBuffer, int) - Static method in class zmq.util.Wire
- getUInt64(Msg, int) - Static method in class zmq.util.Wire
- getUInt8(ByteBuffer, int) - Static method in class zmq.util.Wire
- getUncaughtExceptionHandler() - Method in class org.zeromq.ZContext
- getUncaughtExceptionHandler() - Method in class org.zeromq.ZMQ.Context
- getUncaughtExceptionHandler() - Method in class zmq.Ctx
- getUserId() - Method in class zmq.io.mechanism.Mechanism
- getValue() - Method in class org.zeromq.ZMQ.Event
- getValue() - Method in enum zmq.Config
- getValue(String) - Method in class org.zeromq.ZConfig
- getValue(String, String) - Method in class org.zeromq.ZConfig
- getValues() - Method in class org.zeromq.ZConfig
- getValues(K) - Method in class zmq.util.MultiMap
- getVersionString() - Static method in class org.zeromq.ZMQ
- getWriteIndex() - Method in class zmq.Msg
- getZapDomain() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_ZAP_DOMAIN option shall retrieve the last ZAP domain set for the socket.
- getZAPDomain() - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_ZAP_DOMAIN option shall retrieve the last ZAP domain set for the socket.
- globalHandler - Variable in class org.zeromq.ZPoller.CompositePollItem
- globalHandler - Variable in class org.zeromq.ZPoller
- greetingRecv - Variable in class zmq.io.StreamEngine
- greetingSend - Variable in class zmq.io.StreamEngine
- greetingSize - Variable in class zmq.io.StreamEngine
- group - Variable in class org.zeromq.ZFrame
- group - Variable in class zmq.Msg
- group - Variable in class zmq.socket.radiodish.Dish.DishSession
- GROUP - Enum constant in enum zmq.socket.radiodish.Dish.DishSession.State
- GROUP - Enum constant in enum zmq.socket.radiodish.Radio.RadioSession.State
- GSSAPI - Enum constant in enum zmq.io.mechanism.Mechanisms
- GssapiClientMechanism - Class in zmq.io.mechanism.gssapi
- GssapiClientMechanism(SessionBase, Options) - Constructor for class zmq.io.mechanism.gssapi.GssapiClientMechanism
- GssapiServerMechanism - Class in zmq.io.mechanism.gssapi
- GssapiServerMechanism(SessionBase, Address, Options) - Constructor for class zmq.io.mechanism.gssapi.GssapiServerMechanism
- gssPlaintext - Variable in class zmq.Options
- gssPrincipal - Variable in class zmq.Options
- gssServicePrincipal - Variable in class zmq.Options
H
- handle - Variable in class org.zeromq.ZBeacon.BroadcastServer
- handle - Variable in class zmq.io.net.tcp.TcpConnecter
- handle - Variable in class zmq.io.net.tcp.TcpListener
- handle - Variable in class zmq.io.StreamEngine
- handle - Variable in class zmq.SocketBase
- handle(ZLoop, ZMQ.PollItem, Object) - Method in interface org.zeromq.ZLoop.IZLoopHandler
- Handle(SelectableChannel, IPollEvents) - Constructor for class zmq.poll.Poller.Handle
- handleErrorReason(String) - Method in class zmq.io.mechanism.Mechanism
- handleMessage(ByteBuffer, InetAddress) - Method in class org.zeromq.ZBeacon.BroadcastServer
- handleNode(ZConfig, int) - Method in interface org.zeromq.ZConfig.IVisitor
- handler - Variable in class org.zeromq.timer.ZTicket.Ticket
- handler - Variable in class org.zeromq.ZAuth.ZapRequest
- handler - Variable in class org.zeromq.ZLoop.SPoller
- handler - Variable in class org.zeromq.ZLoop.STimer
- handler - Variable in class org.zeromq.ZPoller.ZPollItem
- handler - Variable in class zmq.io.IOObject
- handler - Variable in class zmq.poll.Poller.Handle
- handler - Variable in class zmq.util.Timers.Timer
- handler() - Method in class org.zeromq.ZPoller.CompositePollItem
- handler() - Method in interface org.zeromq.ZPoller.ItemHolder
- handler() - Method in class org.zeromq.ZPoller.ZPollItem
- handler(ZPoller.EventsHandler) - Method in class org.zeromq.ZPoller.CompositePollItem
- handleSource - Variable in class zmq.Ctx.ChannelForwardHolder
- handover - Variable in class zmq.socket.reqrep.Router
- handshake() - Method in class zmq.io.StreamEngine
- HANDSHAKE_FAILED_AUTH - Enum constant in enum org.zeromq.ZMonitor.Event
- HANDSHAKE_FAILED_AUTH - Static variable in class org.zeromq.ZMQ
-
Failed authentication requests.
- HANDSHAKE_FAILED_NO_DETAIL - Enum constant in enum org.zeromq.ZMonitor.Event
- HANDSHAKE_FAILED_NO_DETAIL - Static variable in class org.zeromq.ZMQ
-
Unspecified system errors during handshake.
- HANDSHAKE_FAILED_PROTOCOL - Enum constant in enum org.zeromq.ZMonitor.Event
- HANDSHAKE_FAILED_PROTOCOL - Static variable in class org.zeromq.ZMQ
-
Protocol errors between ZMTP peers or between server and ZAP handler.
- HANDSHAKE_PROTOCOL - Enum constant in enum org.zeromq.ZMonitor.Event
- HANDSHAKE_SUCCEEDED - Enum constant in enum org.zeromq.ZMonitor.Event
- HANDSHAKE_SUCCEEDED - Static variable in class org.zeromq.ZMQ
-
Handshake complete successfully with successful authentication (if enabled).
- HANDSHAKE_TIMER_ID - Static variable in class zmq.io.StreamEngine
- handshakeIvl - Variable in class zmq.Options
- handshaking - Variable in class zmq.io.StreamEngine
- HANDSHAKING - Enum constant in enum zmq.io.mechanism.Mechanism.Status
- hasData() - Method in class org.zeromq.ZFrame
-
Convenience method to ascertain if this frame contains some message data
- hasEvent(int) - Method in class zmq.poll.PollItem
- hasHandshakeTimer - Variable in class zmq.io.StreamEngine
- hashCode() - Method in class org.zeromq.util.ZData
- hashCode() - Method in class org.zeromq.util.ZMetadata
- hashCode() - Method in class org.zeromq.ZFrame
- hashCode() - Method in class org.zeromq.ZMQ.PollItem
- hashCode() - Method in class org.zeromq.ZMsg
- hashCode() - Method in class org.zeromq.ZPoller.ZPollItem
- hashCode() - Method in class zmq.io.Metadata
- hashCode() - Method in class zmq.poll.Poller.Handle
- hashCode() - Method in class zmq.poll.PollerBase.TimerInfo
- hashCode() - Method in class zmq.util.Blob
- hasHeartbeatTimer - Variable in class zmq.io.StreamEngine
- Hasher() - Constructor for class org.zeromq.ZCertStore.Hasher
- hasIn() - Method in class zmq.socket.FQ
- hasIn() - Method in class zmq.SocketBase
- hasLingerTimer - Variable in class zmq.io.SessionBase
- hasMessage - Variable in class zmq.socket.pubsub.XSub
- hasMore() - Method in class org.zeromq.ZFrame
- hasMore() - Method in class zmq.Msg
- hasMsg - Variable in class zmq.pipe.DBuffer
- hasMulticastLoop() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- hasOut() - Method in class zmq.socket.LB
- hasOut() - Method in class zmq.socket.pubsub.Dist
- hasOut() - Method in class zmq.SocketBase
- hasReceiveMore() - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_RCVMORE' option shall return a boolean value indicating if the multi-part message currently being read from the specified 'socket' has more message parts to follow.
- hasReceiveMore() - Method in class org.zeromq.ZSocket
-
Returns a boolean value indicating if the multipart message currently being read from the
Socket
and has more message parts to follow. - hasSameData(ZFrame) - Method in class org.zeromq.ZFrame
-
Returns true if both frames have byte - for byte identical data
- hasTimeoutTimer - Variable in class zmq.io.StreamEngine
- hasTtlTimer - Variable in class zmq.io.StreamEngine
- hasValues(K) - Method in class zmq.util.MultiMap
- heap - Static variable in class zmq.msg.MsgAllocatorThreshold
- HEARTBEAT_IVL_TIMER_ID - Static variable in class zmq.io.StreamEngine
- HEARTBEAT_TIMEOUT_TIMER_ID - Static variable in class zmq.io.StreamEngine
- HEARTBEAT_TTL_TIMER_ID - Static variable in class zmq.io.StreamEngine
- heartbeatContext - Variable in class zmq.io.StreamEngine
- heartbeatContext - Variable in class zmq.Options
- heartbeatInterval - Variable in class zmq.Options
- heartbeatTimeout - Variable in class zmq.io.StreamEngine
- heartbeatTimeout - Variable in class zmq.Options
- heartbeatTimeout() - Method in class zmq.io.StreamEngine
- heartbeatTtl - Variable in class zmq.Options
- helloMsg - Variable in class zmq.Options
- HelloMsgSession - Class in zmq.io
- HelloMsgSession(IOThread, boolean, SocketBase, Options, Address) - Constructor for class zmq.io.HelloMsgSession
- HEX_CHAR - Static variable in class org.zeromq.util.ZData
- hiccup() - Method in class zmq.pipe.Pipe
- HICCUP - Enum constant in enum zmq.Command.Type
- hiccuped(Pipe) - Method in class zmq.io.SessionBase
- hiccuped(Pipe) - Method in interface zmq.pipe.Pipe.IPipeEvents
- hiccuped(Pipe) - Method in class zmq.SocketBase
- hiccupMsg - Variable in class zmq.Options
- holders - Variable in class org.zeromq.ZPoller.CompositePollItem
- host() - Method in class zmq.io.net.Address
- hot - Variable in class org.zeromq.ZProxy.ProxyActor.State
- hwm - Variable in class zmq.pipe.Pipe
I
- id - Variable in class zmq.poll.PollerBase.TimerInfo
- IDecoder - Interface in zmq.io.coder
- IDecoder.Step - Interface in zmq.io.coder
- IDecoder.Step.Result - Enum in zmq.io.coder
- identifyPeer(Pipe, boolean) - Method in class zmq.socket.reqrep.Router
- identifyPeer(Pipe, boolean) - Method in class zmq.socket.Stream
- identity - Variable in class org.zeromq.ZAuth.ZapReply
- identity - Variable in class org.zeromq.ZAuth.ZapRequest
- identity - Variable in class zmq.io.mechanism.Mechanism
- identity - Variable in class zmq.Options
- identity - Variable in class zmq.pipe.Pipe
- Identity() - Constructor for class org.zeromq.ZProxy.ZPump.Identity
- IDENTITY - Static variable in class org.zeromq.ZProxy.ZPump
- IDENTITY - Static variable in class zmq.io.Metadata
- IDENTITY - Static variable in class zmq.Msg
- identityMsg() - Method in class zmq.io.StreamEngine
- identitySent - Variable in class zmq.socket.reqrep.Router
- identitySent - Variable in class zmq.socket.Stream
- identitySize - Variable in class zmq.Options
- IEncoder - Interface in zmq.io.coder
- IEngine - Interface in zmq.io
- ignoreLocalAddress - Variable in class org.zeromq.ZBeacon.BroadcastServer
- ignoreLocalAddress - Variable in class org.zeromq.ZBeacon.Builder
- ignoreLocalAddress(boolean) - Method in class org.zeromq.ZBeacon.Builder
- IMailbox - Interface in zmq
- immediate - Variable in class zmq.Options
- IN - Static variable in class org.zeromq.ZPoller
- IN_BATCH_SIZE - Enum constant in enum zmq.Config
- inActive - Variable in class zmq.pipe.Pipe
- INBOUND_POLL_RATE - Enum constant in enum zmq.Config
- incompleteIn - Variable in class zmq.io.SessionBase
- incSeqnum() - Method in class zmq.io.SessionBase
- incSeqnum() - Method in class zmq.Own
- INET - Enum constant in enum zmq.io.net.StandardProtocolFamily
- INET6 - Enum constant in enum zmq.io.net.StandardProtocolFamily
- inEvent() - Method in class zmq.io.IOObject
- inEvent() - Method in class zmq.io.IOThread
- inEvent() - Method in class zmq.io.net.tcp.SocksConnecter
- inEvent() - Method in class zmq.io.net.tcp.TcpConnecter
- inEvent() - Method in class zmq.io.StreamEngine
- inEvent() - Method in interface zmq.poll.IPollEvents
-
Called by I/O thread when file descriptor is ready for reading.
- inEvent() - Method in class zmq.Reaper
- inEvent() - Method in class zmq.SocketBase
- init(boolean, Address) - Method in class zmq.io.net.pgm.PgmReceiver
- init(boolean, Address) - Method in class zmq.io.net.pgm.PgmSender
- init(int) - Method in class zmq.poll.PollItem
- init(int) - Static method in class zmq.ZMQ
- init(Address, boolean, boolean) - Method in class zmq.io.net.norm.NormEngine
- initDelimiter() - Method in class zmq.Msg
- initiateConnect() - Method in class zmq.io.net.tcp.SocksConnecter
- initJoin() - Method in class zmq.Msg
- initLeave() - Method in class zmq.Msg
- initSlots() - Method in class zmq.Ctx
- initStep(Runnable, boolean) - Method in class zmq.io.coder.EncoderBase
- inpipe - Variable in class zmq.pipe.Pipe
- inpos - Variable in class zmq.io.StreamEngine
- inproc - Enum constant in enum zmq.io.net.NetProtocol
- INPROC_CONNECTED - Enum constant in enum zmq.Command.Type
- inprocs - Variable in class zmq.SocketBase
- inProgress - Variable in class zmq.io.coder.Decoder
- inProgress - Variable in class zmq.io.coder.EncoderBase
- inProgress - Variable in class zmq.io.coder.raw.RawDecoder
- inputStopped - Variable in class zmq.io.StreamEngine
- insert(K, V) - Method in class zmq.util.MultiMap
- insert(ZTicket.Ticket) - Method in class org.zeromq.timer.ZTicket
- insert(Timers.Timer) - Method in class zmq.util.Timers
- insize - Variable in class zmq.io.StreamEngine
- inSocket - Variable in class org.zeromq.ZMQQueue
- INSTANCE - Static variable in class org.zeromq.ManagedContext.ContextHolder
- instantiate(Class<T>, int, long) - Method in class zmq.io.StreamEngine
- InstantiationException(String) - Constructor for exception class zmq.ZError.InstantiationException
- InstantiationException(String, Throwable) - Constructor for exception class zmq.ZError.InstantiationException
- InstantiationException(Throwable) - Constructor for exception class zmq.ZError.InstantiationException
- interest - Variable in class zmq.poll.PollItem
- interestOps() - Method in class zmq.poll.PollItem
- interestOps(int) - Method in class zmq.poll.PollItem
- interfaceAddress - Variable in class org.zeromq.ZBeacon.BroadcastClient
- internalClose() - Method in class org.zeromq.ZMQ.Socket
- interval - Variable in class zmq.util.Timers.Timer
- interview(ZMQ.Socket) - Method in class org.zeromq.ZActor.ActorFortune
- interview(ZMQ.Socket) - Method in interface org.zeromq.ZStar.Fortune
-
The show is over.
- inverse - Variable in class zmq.util.MultiMap
- invoke(Pipe, byte[], int, XPub) - Method in interface zmq.socket.pubsub.Mtrie.IMtrieHandler
- invoke(Pipe, byte[], int, XPub) - Method in class zmq.socket.pubsub.XPub.MarkAsMatching
- invoke(Pipe, byte[], int, XPub) - Method in class zmq.socket.pubsub.XPub.SendUnsubscription
- ioError - Variable in class zmq.io.StreamEngine
- IOException(IOException) - Constructor for exception class zmq.ZError.IOException
- ioObject - Variable in class zmq.io.net.tcp.TcpConnecter
- ioObject - Variable in class zmq.io.net.tcp.TcpListener
- ioObject - Variable in class zmq.io.SessionBase
- ioObject - Variable in class zmq.io.StreamEngine
- IOObject - Class in zmq.io
- IOObject(IOThread, IPollEvents) - Constructor for class zmq.io.IOObject
- ioThread - Variable in class zmq.io.SessionBase
- IOThread - Class in zmq.io
- IOThread(Ctx, int) - Constructor for class zmq.io.IOThread
- ioThreadCount - Variable in class zmq.Ctx
- ioThreads - Variable in class org.zeromq.ZContext
-
Number of io threads allocated to this context, default 1
- ioThreads - Variable in class zmq.Ctx
- ipc - Enum constant in enum zmq.io.net.NetProtocol
- ipcAcceptFilters - Variable in class zmq.Options
- IpcAddress - Class in zmq.io.net.ipc
- IpcAddress(String) - Constructor for class zmq.io.net.ipc.IpcAddress
- IpcAddress.IpcAddressMask - Class in zmq.io.net.ipc
- IpcAddressMask(String, boolean) - Constructor for class zmq.io.net.ipc.IpcAddress.IpcAddressMask
- IpcConnecter - Class in zmq.io.net.ipc
- IpcConnecter(IOThread, SessionBase, Options, Address, boolean) - Constructor for class zmq.io.net.ipc.IpcConnecter
- IpcListener - Class in zmq.io.net.ipc
- IpcListener(IOThread, SocketBase, Options) - Constructor for class zmq.io.net.ipc.IpcListener
- IPollEvents - Interface in zmq.poll
- ipv6 - Variable in class zmq.Ctx
- ipv6 - Variable in class zmq.Options
- is(int) - Method in class zmq.util.Errno
- isActive() - Method in class zmq.Ctx
- isActive() - Method in class zmq.SocketBase
- isAsServerCurve() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the naming is inconsistent with jzmq, please use
ZMQ.Socket.getCurveServer()
instead - isAsServerPlain() - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the naming is inconsistent with jzmq, please use
ZMQ.Socket.getPlainServer()
instead - isBlocky() - Method in class org.zeromq.ZMQ.Context
- isCancellationRequested() - Method in class org.zeromq.ZMQ.CancellationToken
- isClosed - Variable in class org.zeromq.ZMQ.Socket
- isClosed - Variable in class org.zeromq.ZSocket
- isClosed() - Method in class org.zeromq.ZContext
- isClosed() - Method in class org.zeromq.ZMQ.Context
- isCommand() - Method in class zmq.Msg
- isConflate() - Method in class org.zeromq.ZMQ.Socket
-
If in conflate mode, a socket shall keep only one message in its inbound/outbound queue, this message being the last message received/the last message to be sent.
- isCredential() - Method in class zmq.Msg
- isDelimiter() - Method in class zmq.Msg
- isDelimiter(Msg) - Static method in class zmq.pipe.Pipe
- isEmpty() - Method in class org.zeromq.ZContext
- isEmpty() - Method in class org.zeromq.ZMsg
- isEmpty() - Method in class zmq.io.Metadata
- isEmpty() - Method in class zmq.poll.PollerBase
- isEmpty() - Method in class zmq.util.MultiMap
- isError() - Method in class org.zeromq.ZMQ.Event
-
Used to check if the event is an error.
- isError() - Method in class org.zeromq.ZMQ.PollItem
- isError() - Method in class zmq.io.coder.EncoderBase
- isError() - Method in class zmq.poll.PollItem
- isError(SelectableChannel) - Method in class org.zeromq.ZPoller
-
Tells if a channel is in error from this poller.
- isError(ZMQ.Socket) - Method in class org.zeromq.ZPoller
-
Tells if a socket is in error from this poller.
- isExited() - Method in interface org.zeromq.ZStar.Exit
-
Checks in non-blocking mode, if the remote operations have ended.
- isExited() - Method in class org.zeromq.ZStar.Plateau
- isIdentity() - Method in class zmq.Msg
- isImmediate() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the state of the attach on connect value.
- isInEvent() - Method in class zmq.SocketBase
- isInEventThreadLocal - Variable in class zmq.SocketBase
- isIPv6() - Method in class org.zeromq.ZMQ.Context
- isIPv6() - Method in class org.zeromq.ZMQ.Socket
-
Retrieve the IPv6 option for the socket.
- isJoin() - Method in class zmq.Msg
- isLeave() - Method in class zmq.Msg
- isMain() - Method in class org.zeromq.ZContext
- isMechanism(ByteBuffer) - Method in enum zmq.io.mechanism.Mechanisms
- isMulticast - Variable in enum zmq.io.net.NetProtocol
- isReadable() - Method in class org.zeromq.ZMQ.PollItem
- isReadable() - Method in class zmq.poll.PollItem
- isReadable(SelectableChannel) - Method in class org.zeromq.ZPoller
-
Tells if a channel is readable from this poller.
- isReadable(ZMQ.Socket) - Method in class org.zeromq.ZPoller
-
Tells if a socket is readable from this poller.
- isRedundant() - Method in class zmq.socket.pubsub.Mtrie
- isRedundant() - Method in class zmq.socket.pubsub.Trie
- isResolved() - Method in class zmq.io.net.Address
- isRunning - Variable in class org.zeromq.ZBeacon.BroadcastClient
- isRunning - Variable in class org.zeromq.ZBeacon.BroadcastServer
- isStarted() - Method in class org.zeromq.ZProxy
-
Binary inquiry for the status of the proxy.
- isTerminated() - Method in class org.zeromq.ZMQ.Context
-
Returns true if terminate() has been called on ctx.
- isTerminating() - Method in class zmq.Own
- isWarn() - Method in class org.zeromq.ZMQ.Event
-
Used to check if the event is a warning.
- isWindows - Static variable in class zmq.io.net.tcp.TcpListener
- isWritable() - Method in class org.zeromq.ZMQ.PollItem
- isWritable() - Method in class zmq.poll.PollItem
- isWritable(SelectableChannel) - Method in class org.zeromq.ZPoller
-
Tells if a channel is writable from this poller.
- isWritable(ZMQ.Socket) - Method in class org.zeromq.ZPoller
-
Tells if a socket is writable from this poller.
- item - Variable in class org.zeromq.ZLoop.SPoller
- item - Variable in class org.zeromq.ZPoller.CompositePollItem
- item() - Method in class org.zeromq.ZPoller.CompositePollItem
- item() - Method in interface org.zeromq.ZPoller.ItemHolder
- item() - Method in class org.zeromq.ZPoller.ZPollItem
- items - Variable in class org.zeromq.ZMQ.Poller
- items - Variable in class org.zeromq.ZPoller
- items() - Method in class org.zeromq.ZPoller
- items(Object) - Method in class org.zeromq.ZPoller
- iterator() - Method in class org.zeromq.ZMsg
J
- join(String) - Method in class org.zeromq.ZMQ.Socket
-
Joins a group.
- join(String) - Method in class zmq.SocketBase
- join(SocketBase, String) - Static method in class zmq.ZMQ
- JOIN - Enum constant in enum zmq.Msg.Type
- JOIN_BYTES - Static variable in class zmq.socket.radiodish.Dish.DishSession
K
- key(V) - Method in class zmq.util.MultiMap
- KEY - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- KEY_SIZE - Static variable in class org.zeromq.ZMQ.Curve
- KEY_SIZE_Z85 - Static variable in class org.zeromq.ZMQ.Curve
- Key differences to conventional sockets - Search tag in class org.zeromq.ZMQ.Socket
- Section
- Key encoding - Search tag in class org.zeromq.ZMQ.Curve
- Section
- keypair() - Method in class zmq.io.mechanism.curve.Curve
-
Generates a pair of keys for use with this class.
- KeyPair(String, String) - Constructor for class org.zeromq.ZMQ.Curve.KeyPair
- keypairZ85() - Method in class zmq.io.mechanism.curve.Curve
-
Generates a pair of Z85-encoded keys for use with this class.
- keySet() - Method in class org.zeromq.util.ZMetadata
- keySet() - Method in class zmq.io.Metadata
L
- LARGE_FLAG - Static variable in interface zmq.io.coder.v2.V2Protocol
- lastEndpoint - Variable in class zmq.Options
- lastIn - Variable in class zmq.socket.Channel
- lastIn - Variable in class zmq.socket.FQ
- lastIn - Variable in class zmq.socket.Pair
- lastPipe - Variable in class zmq.socket.pubsub.XPub
- lastTsc - Variable in class zmq.SocketBase
- launchChild(Own) - Method in class zmq.Own
- lb - Variable in class zmq.socket.clientserver.Client
- lb - Variable in class zmq.socket.pipeline.Push
- lb - Variable in class zmq.socket.reqrep.Dealer
- lb - Variable in class zmq.socket.scattergather.Scatter
- LB - Class in zmq.socket
- LB() - Constructor for class zmq.socket.LB
- leave(String) - Method in class org.zeromq.ZMQ.Socket
-
Leaves a group.
- leave(String) - Method in class zmq.SocketBase
- leave(SocketBase, String) - Static method in class zmq.ZMQ
- LEAVE - Enum constant in enum zmq.Msg.Type
- LEAVE_BYTES - Static variable in class zmq.socket.radiodish.Dish.DishSession
- leaveInEvent() - Method in class zmq.SocketBase
- LEFT - Static variable in class org.zeromq.ZConfig
- lights(String, int) - Method in interface org.zeromq.ZStar.Set
-
Puts the performance name on the front door with big lights.
- lights(String, int) - Method in class org.zeromq.ZStar.SimpleSet
- linger - Variable in class org.zeromq.ZContext
-
Linger timeout, default 0
- linger - Variable in class zmq.Options
- LINGER_TIMER_ID - Static variable in class zmq.io.SessionBase
- listener - Variable in class org.zeromq.ZBeacon.Builder
- listener - Variable in class org.zeromq.ZBeacon
- listener(ZBeacon.Listener) - Method in class org.zeromq.ZBeacon.Builder
- Listener - Class in zmq.io.net
- Listener(IOThread, SocketBase, Options) - Constructor for class zmq.io.net.Listener
- LISTENING - Enum constant in enum org.zeromq.ZMonitor.Event
- liveNodes - Variable in class zmq.socket.pubsub.Mtrie
- liveNodes - Variable in class zmq.socket.pubsub.Trie
- load - Variable in class zmq.poll.PollerBase
- load(DataInputStream) - Static method in class org.zeromq.ZMsg
-
Load / append a ZMsg from an open DataInputStream
- load(String) - Static method in class org.zeromq.ZConfig
- load(ZConfig, List<String>, int, AtomicInteger) - Static method in class org.zeromq.ZConfig
- loadFiles() - Method in class org.zeromq.ZCertStore
- loadMsg(Msg) - Method in class zmq.io.coder.EncoderBase
- loadMsg(Msg) - Method in interface zmq.io.coder.IEncoder
- loadPasswords(boolean) - Method in class org.zeromq.ZAuth.SimplePlainAuth
- local - Static variable in class zmq.util.Errno
- location - Variable in class org.zeromq.ZCertStore
- lock - Variable in class org.zeromq.ManagedContext
- lock - Variable in class org.zeromq.ZAgent.SimpleAgent
- lock() - Method in class zmq.SocketBase
- locked - Variable in class org.zeromq.ZAgent.SimpleAgent
- log(String, boolean, String) - Method in class org.zeromq.ZMonitor.MonitorActor
- looped(ZMQ.Socket, ZPoller) - Method in interface org.zeromq.ZActor.Actor
-
Called at the end of each loop.
- looped(ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZActor.Duo
- looped(ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZActor.SimpleActor
- looped(ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZProxy.ProxyActor
- looping(ZMQ.Socket, ZPoller) - Method in interface org.zeromq.ZActor.Actor
-
Called every time just before a loop starts.
- looping(ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZActor.Duo
- looping(ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZActor.SimpleActor
- looping(ZMQ.Socket, ZPoller) - Method in class org.zeromq.ZProxy.ProxyActor
- lossy - Variable in class zmq.socket.pubsub.XPub
- lwm - Variable in class zmq.pipe.Pipe
M
- mailbox - Variable in class zmq.io.IOThread
- mailbox - Variable in class zmq.Reaper
- mailbox - Variable in class zmq.SocketBase
- Mailbox - Class in zmq
- Mailbox(Ctx, String, int) - Constructor for class zmq.Mailbox
- mailboxHandle - Variable in class zmq.io.IOThread
- mailboxHandle - Variable in class zmq.Reaper
- MailboxSafe - Class in zmq
- MailboxSafe(Ctx, ReentrantLock, String) - Constructor for class zmq.MailboxSafe
- main - Variable in class org.zeromq.ZActor.Duo
- main - Variable in class org.zeromq.ZContext
-
Indicates if context object is owned by main thread (useful for multi-threaded applications)
- makeSimpleAuths() - Static method in class org.zeromq.ZAuth
- makeVersion(int, int, int) - Static method in class org.zeromq.ZMQ
- makeVersion(int, int, int) - Static method in class zmq.ZMQ
- maksInterrupt(Signaler.IoOperation<O>) - Method in class zmq.Signaler
- ManagedContext - Class in org.zeromq
- ManagedContext() - Constructor for class org.zeromq.ManagedContext
- ManagedContext.ContextHolder - Class in org.zeromq
- mandatory - Variable in class zmq.socket.reqrep.Router
- manual - Variable in class zmq.socket.pubsub.XPub
- manualSubscriptions - Variable in class zmq.socket.pubsub.XPub
- map - Static variable in enum org.zeromq.ZMQ.Error
- map - Variable in class zmq.Ctx.ChannelForwardHolder
- MAP - Static variable in enum org.zeromq.ZMonitor.Event
- MAP - Static variable in enum org.zeromq.ZMonitor.ProtocolCode
- markAsMatching - Static variable in class zmq.socket.pubsub.XPub
- markAsMatching(Pipe) - Method in class zmq.socket.pubsub.XPub
- MarkAsMatching() - Constructor for class zmq.socket.pubsub.XPub.MarkAsMatching
- match(ByteBuffer, int, Mtrie.IMtrieHandler, XPub) - Method in class zmq.socket.pubsub.Mtrie
- match(Msg) - Method in class zmq.socket.pubsub.XSub
- match(Pipe) - Method in class zmq.socket.pubsub.Dist
- matchAddress(SocketAddress) - Method in class zmq.io.net.ipc.IpcAddress.IpcAddressMask
- matchAddress(SocketAddress) - Method in class zmq.io.net.tcp.TcpAddress.TcpAddressMask
- matching - Variable in class zmq.socket.pubsub.Dist
- matching() - Method in class zmq.socket.pubsub.Dist
- MAX_COMMAND_DELAY - Enum constant in enum zmq.Config
- MAX_GROUP_LENGTH - Static variable in class zmq.Msg
- MAX_IO_EVENTS - Enum constant in enum zmq.Config
- MAX_WM_DELTA - Enum constant in enum zmq.Config
- maxmsgsize - Variable in class zmq.io.coder.Decoder
- maxMsgSize - Variable in class zmq.Options
- maxSocketId - Static variable in class zmq.Ctx
- maxSockets - Variable in class zmq.Ctx
- maybeRebuildSelector(int, long, long) - Method in class zmq.poll.Poller
- mayRaise() - Method in class org.zeromq.ZMQ.Socket
- mayRaise() - Method in class org.zeromq.ZSocket
- mech - Variable in enum org.zeromq.ZMQ.Socket.Mechanism
- mechanism - Variable in class org.zeromq.ZAuth.ZapRequest
- mechanism - Variable in class zmq.io.StreamEngine
- mechanism - Variable in class zmq.Options
- Mechanism - Class in zmq.io.mechanism
- Mechanism(Mechanisms) - Constructor for enum org.zeromq.ZMQ.Socket.Mechanism
- Mechanism(SessionBase, Address, Options) - Constructor for class zmq.io.mechanism.Mechanism
- Mechanism.Status - Enum in zmq.io.mechanism
- mechanismReady() - Method in class zmq.io.StreamEngine
- Mechanisms - Enum in zmq.io.mechanism
- Mechanisms() - Constructor for enum zmq.io.mechanism.Mechanisms
- memoryPtr - Variable in class zmq.pipe.YQueue
- message - Variable in enum org.zeromq.ZMQ.Error
- message - Variable in class zmq.socket.pubsub.XSub
- MESSAGE_PIPE_GRANULARITY - Enum constant in enum zmq.Config
- MESSAGE_SEPARATOR - Static variable in class org.zeromq.ZMQ
- MESSAGE_SEPARATOR - Static variable in class zmq.ZMQ
- messageBegins - Variable in class zmq.socket.reqrep.Req
- messageIncomplete() - Method in class zmq.io.coder.Decoder
- messageReady - Variable in class zmq.io.coder.Decoder
- messageReady - Variable in class zmq.io.coder.Encoder
- messageReady() - Method in class zmq.io.coder.Decoder
- messageReady() - Method in class zmq.io.coder.Encoder
- messageReady() - Method in class zmq.io.coder.raw.RawEncoder
- messageReady() - Method in class zmq.io.coder.v1.V1Decoder
- messageReady() - Method in class zmq.io.coder.v1.V1Encoder
- messageReady() - Method in class zmq.io.coder.v2.V2Decoder
- messageReady() - Method in class zmq.io.coder.v2.V2Encoder
- MessageReady() - Constructor for class zmq.io.coder.Decoder.MessageReady
- Messages - Search tag in class org.zeromq.ZMQ
- Section
- Messaging patterns - Search tag in class org.zeromq.ZMQ.Socket
- Section
- metadata - Variable in class org.zeromq.util.ZMetadata
- metadata - Variable in class org.zeromq.ZAuth.ZapReply
- metadata - Variable in class org.zeromq.ZAuth.ZapRequest
- metadata - Variable in class org.zeromq.ZCert
- metadata - Variable in class zmq.io.StreamEngine
- metadata - Variable in class zmq.Msg
- Metadata - Class in zmq.io
- Metadata() - Constructor for class zmq.io.Metadata
- Metadata(Properties) - Constructor for class zmq.io.Metadata
- Metadata.ParseListener - Interface in zmq.io
-
Call backs during parsing process
- min - Variable in class zmq.socket.pubsub.Mtrie
- min - Variable in class zmq.socket.pubsub.Trie
- modified(byte[], File) - Method in class org.zeromq.ZCertStore
- monitor - Variable in class org.zeromq.ZMonitor.MonitorActor
- monitor(String, int) - Method in class org.zeromq.ZMQ.Socket
-
Start a monitoring socket where events can be received.
- monitor(String, int) - Method in class zmq.SocketBase
-
Register the address for a monitor.
- MONITOR_STOPPED - Enum constant in enum org.zeromq.ZMonitor.Event
- MonitorActor(ZMQ.Socket) - Constructor for class org.zeromq.ZMonitor.MonitorActor
- monitored - Variable in class org.zeromq.ZMonitor.MonitorActor
- monitorEvent(ZMQ.Event) - Method in class zmq.SocketBase
- monitorEvents - Variable in class zmq.SocketBase
- monitorSocket - Variable in class zmq.SocketBase
- monitorSocket(SocketBase, String, int) - Static method in class zmq.ZMQ
- monitorSync - Variable in class zmq.SocketBase
- more - Variable in class org.zeromq.ZFrame
- more - Variable in class zmq.socket.FQ
- more - Variable in class zmq.socket.LB
- more - Variable in class zmq.socket.pubsub.Dist
- more - Variable in class zmq.socket.pubsub.XPub
- more - Variable in class zmq.socket.pubsub.XSub
- MORE - Static variable in class org.zeromq.ZFrame
- MORE - Static variable in class zmq.Msg
- MORE_DATA - Enum constant in enum zmq.io.coder.IDecoder.Step.Result
- MORE_FLAG - Static variable in interface zmq.io.coder.v1.V1Protocol
- moreIn - Variable in class zmq.socket.reqrep.Router
- moreOut - Variable in class zmq.socket.reqrep.Router
- moreOut - Variable in class zmq.socket.Stream
- msg() - Method in class org.zeromq.ZAuth.ZapReply
- msg() - Method in class zmq.io.coder.Decoder
- msg() - Method in interface zmq.io.coder.IDecoder
- msg() - Method in class zmq.io.coder.raw.RawDecoder
- Msg - Class in zmq
- Msg() - Constructor for class zmq.Msg
- Msg(byte[]) - Constructor for class zmq.Msg
- Msg(int) - Constructor for class zmq.Msg
- Msg(ByteBuffer) - Constructor for class zmq.Msg
- Msg(Msg) - Constructor for class zmq.Msg
- Msg(Msg, ByteArrayOutputStream) - Constructor for class zmq.Msg
- MSG_ALLOCATION_HEAP_THRESHOLD - Enum constant in enum zmq.Config
- Msg.Builder - Class in zmq
- Msg.Type - Enum in zmq
- MsgAllocator - Interface in zmq.msg
- MsgAllocatorDirect - Class in zmq.msg
- MsgAllocatorDirect() - Constructor for class zmq.msg.MsgAllocatorDirect
- MsgAllocatorHeap - Class in zmq.msg
- MsgAllocatorHeap() - Constructor for class zmq.msg.MsgAllocatorHeap
- MsgAllocatorThreshold - Class in zmq.msg
- MsgAllocatorThreshold() - Constructor for class zmq.msg.MsgAllocatorThreshold
- MsgAllocatorThreshold(int) - Constructor for class zmq.msg.MsgAllocatorThreshold
- msgBinaryPicture(String, Object...) - Method in class org.zeromq.proto.ZPicture
-
Creates a binary encoded 'picture' message to the socket (or actor), so it can be sent.
- msgFlags - Variable in class zmq.io.coder.v2.V2Decoder
- msgInit() - Static method in class zmq.ZMQ
- msgInitWithSize(int) - Static method in class zmq.ZMQ
- Msgs - Class in zmq.io
- Msgs() - Constructor for class zmq.io.Msgs
- msgSize(Msg) - Static method in class zmq.ZMQ
- msgsRead - Variable in class zmq.pipe.Pipe
- msgsWritten - Variable in class zmq.pipe.Pipe
- msleep(long) - Static method in class org.zeromq.ZMQ
- msleep(long) - Static method in class zmq.ZMQ
- Mtrie - Class in zmq.socket.pubsub
- Mtrie() - Constructor for class zmq.socket.pubsub.Mtrie
- Mtrie.IMtrieHandler - Interface in zmq.socket.pubsub
- multicastHops - Variable in class zmq.Options
- MultiMap<K,
V> - Class in zmq.util - MultiMap() - Constructor for class zmq.util.MultiMap
- MultiMap.EntryComparator - Class in zmq.util
- Multiple contexts - Search tag in class org.zeromq.ZMQ
- Section
N
- name - Variable in class org.zeromq.ZConfig
- name - Variable in class org.zeromq.ZProxy.ProxyActor
- name - Variable in class zmq.io.IOThread
- name - Variable in class zmq.io.net.ipc.IpcAddress
- name - Variable in class zmq.Mailbox
- name - Variable in class zmq.MailboxSafe
- name - Variable in class zmq.Reaper
- name() - Method in interface zmq.io.net.ProtocolFamily
- name(int) - Static method in enum zmq.socket.Sockets
- needle - Variable in class org.zeromq.proto.ZNeedle
- NetProtocol - Enum in zmq.io.net
- NetProtocol(boolean, boolean, boolean, Sockets...) - Constructor for enum zmq.io.net.NetProtocol
- newMsgFlag - Variable in class zmq.io.coder.EncoderBase
- newPipe - Variable in class zmq.io.HelloMsgSession
- newProxy(ZContext, String, ZAgent.SelectorCreator, ZProxy.Proxy, String, Object...) - Static method in class org.zeromq.ZProxy
-
Deprecated.
- newProxy(ZContext, String, ZProxy.Proxy, String, Object...) - Static method in class org.zeromq.ZProxy
-
Creates a new low-level proxy for better performances.
- newStringMsg(String...) - Static method in class org.zeromq.ZMsg
-
Create a new ZMsg from one or more Strings
- newTimers - Variable in class org.zeromq.ZLoop
- newZProxy(ZContext, String, ZAgent.SelectorCreator, ZProxy.Proxy, String, Object...) - Static method in class org.zeromq.ZProxy
-
Deprecated.
- newZProxy(ZContext, String, ZProxy.Proxy, String, Object...) - Static method in class org.zeromq.ZProxy
-
Creates a new proxy in a ZeroMQ way.
- next - Variable in class zmq.io.coder.DecoderBase
- next - Variable in class zmq.io.coder.EncoderBase
- next - Variable in class zmq.pipe.YQueue.Chunk
- next - Variable in class zmq.socket.pubsub.Mtrie
- next - Variable in class zmq.socket.pubsub.Trie
- next() - Method in class zmq.io.coder.EncoderBase
- nextEvent() - Method in class org.zeromq.ZMonitor
-
Gets the next event, blocking for it until available.
- nextEvent(boolean) - Method in class org.zeromq.ZMonitor
-
Gets the next event, blocking for it until available if requested.
- nextEvent(int) - Method in class org.zeromq.ZMonitor
-
Gets the next event, blocking for it until available if requested.
- nextHandshakeCommand - Variable in class zmq.io.StreamEngine
- nextHandshakeCommand() - Method in class zmq.io.StreamEngine
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.gssapi.GssapiClientMechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.gssapi.GssapiServerMechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.Mechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.NullMechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- nextHandshakeCommand(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- nextIdentity - Variable in class zmq.io.StreamEngine
- nextMsg - Variable in class zmq.io.StreamEngine
- nextReply() - Method in class org.zeromq.ZAuth
-
Retrieves the next ZAP reply.
- nextReply(boolean) - Method in class org.zeromq.ZAuth
-
Retrieves the next ZAP reply.
- nextReply(int) - Method in class org.zeromq.ZAuth
-
Retrieves the next ZAP reply.
- nextRid - Variable in class zmq.socket.clientserver.Server
- nextRid - Variable in class zmq.socket.reqrep.Router
- nextRid - Variable in class zmq.socket.Stream
- nextStep(byte[], int, Runnable, boolean) - Method in class zmq.io.coder.EncoderBase
- nextStep(byte[], int, IDecoder.Step) - Method in class zmq.io.coder.DecoderBase
-
Deprecated.
- nextStep(ByteBuffer, int, Runnable, boolean) - Method in class zmq.io.coder.EncoderBase
- nextStep(ByteBuffer, Runnable, boolean) - Method in class zmq.io.coder.EncoderBase
- nextStep(ByteBuffer, IDecoder.Step) - Method in class zmq.io.coder.DecoderBase
- nextStep(Msg, Runnable, boolean) - Method in class zmq.io.coder.EncoderBase
- nextStep(Msg, IDecoder.Step) - Method in class zmq.io.coder.DecoderBase
- NOBLOCK - Static variable in class org.zeromq.ZMQ
- NONCE - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- norm - Enum constant in enum zmq.io.net.NetProtocol
- NormEngine - Class in zmq.io.net.norm
- NormEngine(IOThread, Options) - Constructor for class zmq.io.net.norm.NormEngine
- now() - Method in class org.zeromq.timer.ZTicket
- now() - Method in class zmq.util.Timers
- nowMS() - Static method in class zmq.util.Clock
- nowNS() - Static method in class zmq.util.Clock
-
High precision timestamp in nanoseconds.
- nowUS() - Static method in class zmq.util.Clock
-
High precision timestamp in microseconds.
- NULL - Enum constant in enum org.zeromq.ZMQ.Socket.Mechanism
- NULL - Enum constant in enum zmq.io.mechanism.Mechanisms
- NullMechanism - Class in zmq.io.mechanism
- NullMechanism(SessionBase, Address, Options) - Constructor for class zmq.io.mechanism.NullMechanism
- number - Variable in class org.zeromq.ZStar.Plateau
O
- Objects - Class in zmq.util
- Objects() - Constructor for class zmq.util.Objects
- offer(ZFrame) - Method in class org.zeromq.ZMsg
- offerFirst(ZFrame) - Method in class org.zeromq.ZMsg
- offerLast(ZFrame) - Method in class org.zeromq.ZMsg
- OK - Static variable in class org.zeromq.ZAuth.AuthActor
- OK - Static variable in class org.zeromq.ZMonitor.MonitorActor
- OK - Static variable in class zmq.io.mechanism.NullMechanism
- onBeacon(InetAddress, byte[]) - Method in interface org.zeromq.ZBeacon.Listener
- oneByteSizeReady - Variable in class zmq.io.coder.Decoder
- oneByteSizeReady() - Method in class zmq.io.coder.Decoder
- oneByteSizeReady() - Method in class zmq.io.coder.v1.V1Decoder
- oneByteSizeReady() - Method in class zmq.io.coder.v2.V2Decoder
- OneByteSizeReady() - Constructor for class zmq.io.coder.Decoder.OneByteSizeReady
- open() - Method in class zmq.io.net.tcp.SocksConnecter
- open() - Method in class zmq.io.net.tcp.TcpConnecter
- open(byte[], byte[], int, byte[], byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- open(ByteBuffer, ByteBuffer, int, ByteBuffer, byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- openAfternm(byte[], byte[], int, byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- openAfternm(ByteBuffer, ByteBuffer, int, ByteBuffer, byte[]) - Method in class zmq.io.mechanism.curve.Curve
- ops - Variable in class zmq.poll.Poller.Handle
- ops() - Method in class org.zeromq.ZPoller.CompositePollItem
- options - Variable in class zmq.Ctx.Endpoint
- options - Variable in class zmq.io.mechanism.Mechanism
- options - Variable in class zmq.io.StreamEngine
- options - Variable in class zmq.Own
- Options - Class in zmq
- Options() - Constructor for class zmq.Options
- optSync - Variable in class zmq.Ctx
- org.zeromq - package org.zeromq
-
Provides high-level bindings for ØMQ.
- org.zeromq.proto - package org.zeromq.proto
-
Provides utility classes for ØMQ zproto.
- org.zeromq.timer - package org.zeromq.timer
-
Provides timing utility classes for ØMQ.
- org.zeromq.util - package org.zeromq.util
-
Provides high-level utility bindings for ØMQ.
- out - Variable in class zmq.Msg.Builder
- OUT - Static variable in class org.zeromq.ZPoller
- OUT_BATCH_SIZE - Enum constant in enum zmq.Config
- outActive - Variable in class zmq.pipe.Pipe
- outEvent() - Method in class zmq.io.IOObject
- outEvent() - Method in class zmq.io.net.tcp.SocksConnecter
- outEvent() - Method in class zmq.io.net.tcp.TcpConnecter
- outEvent() - Method in class zmq.io.StreamEngine
- outEvent() - Method in interface zmq.poll.IPollEvents
-
Called by I/O thread when file descriptor is ready for writing.
- outpipe - Variable in class zmq.pipe.Pipe
- Outpipe(Pipe, boolean) - Constructor for class zmq.socket.clientserver.Server.Outpipe
- Outpipe(Pipe, boolean) - Constructor for class zmq.socket.reqrep.Router.Outpipe
- Outpipe(Pipe, boolean) - Constructor for class zmq.socket.Stream.Outpipe
- outpipes - Variable in class zmq.socket.clientserver.Server
- outpipes - Variable in class zmq.socket.reqrep.Router
- outpipes - Variable in class zmq.socket.Stream
- outpos - Variable in class zmq.io.StreamEngine
- outputStopped - Variable in class zmq.io.StreamEngine
- outsize - Variable in class zmq.io.StreamEngine
- outSocket - Variable in class org.zeromq.ZMQQueue
- Own - Class in zmq
- Own(Ctx, int) - Constructor for class zmq.Own
- Own(IOThread, Options) - Constructor for class zmq.Own
- OWN - Enum constant in enum zmq.Command.Type
- owned - Variable in class zmq.Own
- owner - Variable in class zmq.Own
P
- pair(ZObject[], int[], boolean[]) - Static method in class zmq.pipe.Pipe
- Pair - Class in zmq.socket
- Pair(Ctx, int, int) - Constructor for class zmq.socket.Pair
- PAIR - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a exclusive pair of sockets.
- PAIR - Enum constant in enum zmq.socket.Sockets
- PAIR - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- parent - Variable in class org.zeromq.timer.ZTicket.Ticket
- parent - Variable in class zmq.pipe.Pipe
- parent - Variable in class zmq.util.Timers.Timer
- parseAddress(String, String, int) - Method in class zmq.io.net.tcp.SocksConnecter
- parseBoolean(int, Object) - Static method in class zmq.Options
- parseBytes(int, Object) - Static method in class zmq.Options
- parsed(String, byte[], String) - Method in interface zmq.io.Metadata.ParseListener
-
Called when a property has been parsed.
- parseErrorMessage(Msg) - Method in class zmq.io.mechanism.Mechanism
- parseMetadata(ByteBuffer, int, boolean) - Method in class zmq.io.mechanism.Mechanism
- parseMetadata(Msg, int, boolean) - Method in class zmq.io.mechanism.Mechanism
- parseString(int, Object) - Static method in class zmq.Options
- party(long, TimeUnit) - Static method in class org.zeromq.ZStar
- party(ZContext) - Method in class org.zeromq.ZActor.ActorFortune
- party(ZContext) - Method in interface org.zeromq.ZStar.TimeTaker
-
Called when the show is finished but no cleaning is still done.
- password - Variable in class org.zeromq.ZAuth.ZapRequest
- passwords - Variable in class org.zeromq.ZAuth.SimplePlainAuth
- passwordsFile - Variable in class org.zeromq.ZAuth.SimplePlainAuth
- passwordsModified - Variable in class org.zeromq.ZAuth.SimplePlainAuth
- pathExists(String) - Method in class org.zeromq.ZConfig
-
check if a value-path exists
- pause(boolean) - Method in class org.zeromq.ZProxy
-
Pauses the proxy.
- pause(ZPoller, boolean) - Method in class org.zeromq.ZProxy.ProxyActor
- PAUSE - Enum constant in enum org.zeromq.ZProxy.Command
- PAUSE - Static variable in class org.zeromq.ZProxy
- paused - Variable in class org.zeromq.ZProxy.ProxyActor.State
- PAUSED - Enum constant in enum org.zeromq.ZProxy.State
- PAUSED - Enum constant in enum zmq.Proxy.State
- PAUSED - Static variable in class org.zeromq.ZProxy
- peek() - Method in class org.zeromq.ZMsg
- peekFirst() - Method in class org.zeromq.ZMsg
- peekLast() - Method in class org.zeromq.ZMsg
- peer - Variable in class zmq.pipe.Pipe
- Peer - Class in zmq.socket
- Peer(Ctx, int, int) - Constructor for class zmq.socket.Peer
- PEER - Enum constant in enum org.zeromq.SocketType
-
Flag to specify PEER socket.
- PEER - Enum constant in enum zmq.socket.Sockets
- PEER_ADDRESS - Static variable in class zmq.io.Metadata
- peerAddress - Variable in class zmq.io.mechanism.Mechanism
- peerAddress - Variable in class zmq.io.StreamEngine
- peerIdentity() - Method in class zmq.io.mechanism.Mechanism
- peerLastRoutingId - Variable in class zmq.Options
- peersMsgsRead - Variable in class zmq.pipe.Pipe
- pendConnection(String, Ctx.Endpoint, Pipe[]) - Method in class zmq.Ctx
- pendConnection(String, Ctx.Endpoint, Pipe[]) - Method in class zmq.ZObject
- pending - Variable in class zmq.io.SessionBase
- pending - Variable in class zmq.socket.radiodish.Radio.RadioSession
- PendingConnection(Ctx.Endpoint, Pipe, Pipe) - Constructor for class zmq.Ctx.PendingConnection
- pendingConnections - Variable in class zmq.Ctx
- pendingData - Variable in class zmq.socket.pubsub.XPub
- pendingFlags - Variable in class zmq.socket.pubsub.XPub
- pendingMsg - Variable in class zmq.socket.radiodish.Dish
- pendingPipes - Variable in class zmq.socket.pubsub.XPub
- pgm - Enum constant in enum zmq.io.net.NetProtocol
- PGM_MAX_TPDU - Enum constant in enum zmq.Config
- PgmReceiver - Class in zmq.io.net.pgm
- PgmReceiver(IOThread, Options) - Constructor for class zmq.io.net.pgm.PgmReceiver
- PgmSender - Class in zmq.io.net.pgm
- PgmSender(IOThread, Options) - Constructor for class zmq.io.net.pgm.PgmSender
- pid - Variable in class zmq.Signaler
- pingContext - Variable in class zmq.io.StreamEngine.ProducePongMessage
- pipe - Variable in class org.zeromq.ZActor.Double
- pipe - Variable in class org.zeromq.ZAgent.SimpleAgent
- pipe - Variable in class org.zeromq.ZThread.ShimThread
- pipe - Variable in class zmq.io.SessionBase
- pipe - Variable in class zmq.socket.Channel
- pipe - Variable in class zmq.socket.clientserver.Server.Outpipe
- pipe - Variable in class zmq.socket.Pair
- pipe - Variable in class zmq.socket.reqrep.Router.Outpipe
- pipe - Variable in class zmq.socket.Stream.Outpipe
- pipe - Variable in class zmq.SocketBase.EndpointPipe
- pipe() - Method in interface org.zeromq.ZAgent
-
Returns the socket used for communication.
- pipe() - Method in class org.zeromq.ZAgent.SimpleAgent
- pipe() - Method in class org.zeromq.ZStar
- Pipe - Class in zmq.pipe
- Pipe(ZObject, YPipeBase<Msg>, YPipeBase<Msg>, int, int, boolean) - Constructor for class zmq.pipe.Pipe
- PIPE_TERM - Enum constant in enum zmq.Command.Type
- PIPE_TERM_ACK - Enum constant in enum zmq.Command.Type
- Pipe.IPipeEvents - Interface in zmq.pipe
- Pipe.State - Enum in zmq.pipe
- pipehwm - Variable in class org.zeromq.ZContext
-
Send/receive HWM for pipes
- pipes - Variable in class zmq.socket.FQ
- pipes - Variable in class zmq.socket.LB
- pipes - Variable in class zmq.socket.pubsub.Dist
- pipes - Variable in class zmq.socket.pubsub.Mtrie
- pipes - Variable in class zmq.SocketBase
- pipeTerminated(Pipe) - Method in class zmq.io.SessionBase
- pipeTerminated(Pipe) - Method in interface zmq.pipe.Pipe.IPipeEvents
- pipeTerminated(Pipe) - Method in class zmq.SocketBase
- PLAIN - Enum constant in enum org.zeromq.ZMQ.Socket.Mechanism
- PLAIN - Enum constant in enum zmq.io.mechanism.Mechanisms
- PlainClientMechanism - Class in zmq.io.mechanism.plain
- PlainClientMechanism(SessionBase, Options) - Constructor for class zmq.io.mechanism.plain.PlainClientMechanism
- PlainClientMechanism.State - Enum in zmq.io.mechanism.plain
- plainPassword - Variable in class zmq.Options
- PlainServerMechanism - Class in zmq.io.mechanism.plain
- PlainServerMechanism(SessionBase, Address, Options) - Constructor for class zmq.io.mechanism.plain.PlainServerMechanism
- PlainServerMechanism.State - Enum in zmq.io.mechanism.plain
- plainUsername - Variable in class zmq.Options
- plateau - Variable in class org.zeromq.ZStar
- Plateau() - Constructor for class org.zeromq.ZStar.Plateau
- plug() - Method in class zmq.io.IOObject
- plug(IOThread, SessionBase) - Method in class zmq.io.EngineNotImplemented
- plug(IOThread, SessionBase) - Method in interface zmq.io.IEngine
- plug(IOThread, SessionBase) - Method in class zmq.io.StreamEngine
- Plug() - Constructor for enum org.zeromq.ZProxy.Plug
- PLUG - Enum constant in enum zmq.Command.Type
- plugged - Variable in class zmq.io.StreamEngine
- poll() - Method in class org.zeromq.ZMQ.Poller
-
Issue a poll call.
- poll() - Method in class org.zeromq.ZMsg
- poll(int, int, AtomicBoolean) - Method in class zmq.SocketBase
- poll(long) - Method in class org.zeromq.ZMQ.Poller
-
Issue a poll call, using the specified timeout value.
- poll(long) - Method in class org.zeromq.ZPoller
-
Issue a poll call, using the specified timeout value.
- poll(long, boolean) - Method in class org.zeromq.ZPoller
-
Issue a poll call, using the specified timeout value.
- poll(Selector, long, Collection<PollItem>) - Method in class org.zeromq.ZPoller
- poll(Selector, ZMQ.PollItem[], int, long) - Static method in class org.zeromq.ZMQ
- poll(Selector, ZMQ.PollItem[], long) - Static method in class org.zeromq.ZMQ
- poll(Selector, PollItem[], int, long) - Static method in class zmq.ZMQ
-
Polling on items with given selector CAUTION: This could be affected by jdk epoll bug
- poll(Selector, PollItem[], long) - Static method in class zmq.ZMQ
-
Polling on items with given selector CAUTION: This could be affected by jdk epoll bug
- pollact - Variable in class org.zeromq.ZLoop
- poller - Variable in class org.zeromq.ZActor.Double
- poller - Variable in class zmq.io.IOObject
- poller - Variable in class zmq.io.IOThread
- poller - Variable in class zmq.Reaper
- poller - Variable in class zmq.SocketBase
- poller() - Method in class org.zeromq.ZMQ.Context
-
Create a new Poller within this context, with a default size.
- poller(int) - Method in class org.zeromq.ZMQ.Context
-
Create a new Poller within this context, with a specified initial size.
- Poller - Class in zmq.poll
- Poller(ZMQ.Context) - Constructor for class org.zeromq.ZMQ.Poller
-
Class constructor.
- Poller(ZMQ.Context, int) - Constructor for class org.zeromq.ZMQ.Poller
-
Class constructor.
- Poller(Ctx, String) - Constructor for class zmq.poll.Poller
- Poller.Handle - Class in zmq.poll
- PollerBase - Class in zmq.poll
- PollerBase(String) - Constructor for class zmq.poll.PollerBase
- PollerBase.TimerInfo - Class in zmq.poll
- pollerr(int) - Method in class org.zeromq.ZMQ.Poller
-
Check whether the specified element in the poll set was signaled for error.
- pollerr(SelectableChannel) - Method in class org.zeromq.ZPoller
- pollerr(ZMQ.Socket) - Method in class org.zeromq.ZPoller
- POLLERR - Static variable in class org.zeromq.ZMQ.Poller
-
For standard sockets, this flag is passed through
ZMQ.poll(Selector, zmq.poll.PollItem[], long)
to the underlying poll() system call and generally means that some sort of error condition is present on the socket specified by fd. - POLLERR - Static variable in class org.zeromq.ZPoller
- pollers - Variable in class org.zeromq.ZLoop
- pollFirst() - Method in class org.zeromq.ZMsg
- pollin(int) - Method in class org.zeromq.ZMQ.Poller
-
Check whether the specified element in the poll set was signaled for input.
- pollin(SelectableChannel) - Method in class org.zeromq.ZPoller
- pollin(ZMQ.Socket) - Method in class org.zeromq.ZPoller
- POLLIN - Static variable in class org.zeromq.ZMQ.Poller
-
For ØMQ sockets, at least one message may be received from the socket without blocking.
- POLLIN - Static variable in class org.zeromq.ZPoller
- PollItem - Class in zmq.poll
- PollItem(SelectableChannel, int) - Constructor for class org.zeromq.ZMQ.PollItem
- PollItem(SelectableChannel, int) - Constructor for class zmq.poll.PollItem
- PollItem(ZMQ.Socket, int) - Constructor for class org.zeromq.ZMQ.PollItem
- PollItem(SocketBase, int) - Constructor for class zmq.poll.PollItem
- PollItem(SocketBase, SelectableChannel, int) - Constructor for class zmq.poll.PollItem
- pollLast() - Method in class org.zeromq.ZMsg
- pollout(int) - Method in class org.zeromq.ZMQ.Poller
-
Check whether the specified element in the poll set was signaled for output.
- pollout(SelectableChannel) - Method in class org.zeromq.ZPoller
- pollout(ZMQ.Socket) - Method in class org.zeromq.ZPoller
- POLLOUT - Static variable in class org.zeromq.ZMQ.Poller
-
For ØMQ sockets, at least one message may be sent to the socket without blocking.
- POLLOUT - Static variable in class org.zeromq.ZPoller
- pollset - Variable in class org.zeromq.ZLoop
- pollSize - Variable in class org.zeromq.ZLoop
- pop() - Method in class org.zeromq.ZMsg
- pop() - Method in class zmq.pipe.YQueue
- popString() - Method in class org.zeromq.ZMsg
-
Pop a ZFrame and return the toString() representation of it.
- port - Variable in class org.zeromq.ZBeacon.Builder
- port(int) - Method in class org.zeromq.ZBeacon.Builder
- pos - Variable in class zmq.pipe.YQueue.Chunk
- PREFER_IPV6 - Static variable in class zmq.ZMQ
- prefetched - Variable in class zmq.socket.reqrep.Router
- prefetched - Variable in class zmq.socket.Stream
- prefetchedId - Variable in class zmq.socket.reqrep.Router
- prefetchedId - Variable in class zmq.socket.Stream
- prefetchedMsg - Variable in class zmq.socket.reqrep.Router
- prefetchedMsg - Variable in class zmq.socket.Stream
- prefix - Variable in class org.zeromq.ZBeacon.Builder
- prefix - Variable in class org.zeromq.ZBeacon
- prefix(byte[]) - Method in class org.zeromq.ZBeacon.Builder
- premiere(ZMQ.Socket) - Method in interface org.zeromq.ZActor.Actor
-
This is the grand premiere! Called before the creation of the first double and the sockets 2nd in the order call of the global acting.
- premiere(ZMQ.Socket) - Method in class org.zeromq.ZActor.Duo
- premiere(ZMQ.Socket) - Method in class org.zeromq.ZActor.SimpleActor
- premiere(ZMQ.Socket) - Method in class org.zeromq.ZAuth.AuthActor
- premiere(ZMQ.Socket) - Method in class org.zeromq.ZMonitor.MonitorActor
- premiere(ZMQ.Socket) - Method in class org.zeromq.ZProxy.ProxyActor
- premiere(ZMQ.Socket, Object...) - Method in class org.zeromq.ZActor.ActorFortune
- premiere(ZMQ.Socket, Object...) - Method in interface org.zeromq.ZStar.Fortune
-
This is the grand premiere! Called when the star enters the plateau.
- prepare() - Method in class org.zeromq.ZActor.Double
- prepare() - Method in interface org.zeromq.ZStar.Star
-
Called when the star is in the wings.
Hint: Can be used to initialize the service, or ...
Key point: no loop has started already. - prev - Variable in class zmq.pipe.YQueue.Chunk
- principal - Variable in class org.zeromq.ZAuth.ZapRequest
- print(File) - Method in interface org.zeromq.ZCertStore.Fingerprinter
- print(File) - Method in class org.zeromq.ZCertStore.Hasher
- print(File) - Method in class org.zeromq.ZCertStore.Timestamper
- print(PrintStream, String) - Method in class org.zeromq.util.ZData
- print(PrintStream, String, byte[], int) - Static method in class org.zeromq.util.ZData
- print(String) - Method in class org.zeromq.ZFrame
- probe() - Method in class zmq.pipe.DBuffer
- probe() - Method in class zmq.pipe.YPipe
- probe() - Method in interface zmq.pipe.YPipeBase
- probe() - Method in class zmq.pipe.YPipeConflate
- probeRouter - Variable in class zmq.socket.reqrep.Dealer
- probeRouter - Variable in class zmq.socket.reqrep.Router
- process() - Method in class zmq.Command
- process(PollItem, PollItem, SocketBase, SocketBase) - Method in class zmq.Proxy
- processActivateRead() - Method in class zmq.pipe.Pipe
- processActivateRead() - Method in class zmq.ZObject
- processActivateWrite(long) - Method in class zmq.pipe.Pipe
- processActivateWrite(long) - Method in class zmq.ZObject
- processAttach(IEngine) - Method in class zmq.io.SessionBase
- processAttach(IEngine) - Method in class zmq.ZObject
- processBind(Pipe) - Method in class zmq.SocketBase
- processBind(Pipe) - Method in class zmq.ZObject
- processCancel() - Method in class zmq.ZObject
- processCommand(Command) - Method in class zmq.ZObject
- processCommand(Msg) - Method in class zmq.io.StreamEngine
- processCommands(int, boolean, AtomicBoolean) - Method in class zmq.SocketBase
- processDelimiter() - Method in class zmq.pipe.Pipe
- processDestroy() - Method in class zmq.Own
- processDestroy() - Method in class zmq.SocketBase
- processedSeqnum - Variable in class zmq.Own
- processError(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- processError(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- processErrorCommand(Msg) - Method in class zmq.io.mechanism.NullMechanism
- processHandshakeCommand - Variable in class zmq.io.StreamEngine
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.gssapi.GssapiClientMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.gssapi.GssapiServerMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.Mechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.NullMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- processHandshakeCommand(Msg) - Method in class zmq.io.StreamEngine
- processHeartbeatMessage(Msg) - Method in class zmq.io.StreamEngine
- processHello(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- processHiccup(YPipeBase<Msg>) - Method in class zmq.pipe.Pipe
- processHiccup(YPipeBase<Msg>) - Method in class zmq.ZObject
- processIdentity - Variable in class zmq.io.StreamEngine
- processIdentityMsg(Msg) - Method in class zmq.io.StreamEngine
- processInitiate(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- processMsg - Variable in class zmq.io.StreamEngine
- processOwn(Own) - Method in class zmq.Own
- processOwn(Own) - Method in class zmq.ZObject
- processPipeTerm() - Method in class zmq.pipe.Pipe
- processPipeTerm() - Method in class zmq.ZObject
- processPipeTermAck() - Method in class zmq.pipe.Pipe
- processPipeTermAck() - Method in class zmq.ZObject
- processPlug() - Method in class zmq.io.net.tcp.SocksConnecter
- processPlug() - Method in class zmq.io.net.tcp.TcpConnecter
- processPlug() - Method in class zmq.io.net.tcp.TcpListener
- processPlug() - Method in class zmq.io.SessionBase
- processPlug() - Method in class zmq.ZObject
- processReady(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- processReady(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- processReadyCommand(Msg) - Method in class zmq.io.mechanism.NullMechanism
- processReap(SocketBase) - Method in class zmq.Reaper
- processReap(SocketBase) - Method in class zmq.ZObject
- processReapAck() - Method in class zmq.ZObject
- processReaped() - Method in class zmq.Reaper
- processReaped() - Method in class zmq.ZObject
- processSeqnum() - Method in class zmq.Own
- processSeqnum() - Method in class zmq.ZObject
- processServerResponse() - Method in class zmq.io.net.tcp.SocksConnecter
- processStop() - Method in class zmq.io.IOThread
- processStop() - Method in class zmq.Reaper
- processStop() - Method in class zmq.SocketBase
- processStop() - Method in class zmq.ZObject
- processTerm(int) - Method in class zmq.io.net.tcp.SocksConnecter
- processTerm(int) - Method in class zmq.io.net.tcp.TcpConnecter
- processTerm(int) - Method in class zmq.io.net.tcp.TcpListener
- processTerm(int) - Method in class zmq.io.SessionBase
- processTerm(int) - Method in class zmq.Own
- processTerm(int) - Method in class zmq.SocketBase
- processTerm(int) - Method in class zmq.ZObject
- processTermAck() - Method in class zmq.Own
- processTermAck() - Method in class zmq.ZObject
- processTermReq(Own) - Method in class zmq.Own
- processTermReq(Own) - Method in class zmq.ZObject
- processWelcome(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- processWelcome(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- produceError(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- produceError(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- produceHello(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- produceHello(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- produceHello(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- produceInitiate(Msg) - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- produceInitiate(Msg) - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- produceInitiate(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- producePingMessage - Variable in class zmq.io.StreamEngine
- producePingMessage() - Method in class zmq.io.StreamEngine
- producePongMessage(byte[]) - Method in class zmq.io.StreamEngine
- ProducePongMessage(byte[]) - Constructor for class zmq.io.StreamEngine.ProducePongMessage
- produceReady(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- produceReady(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- produceWelcome(Msg) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- produceWelcome(Msg) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- property(String, byte[]) - Method in class zmq.io.mechanism.Mechanism
- protocol - Variable in class zmq.io.net.Address
- protocol - Variable in class zmq.SocketBase.SimpleURI
- protocol() - Method in class zmq.io.net.Address
- Protocol(int) - Constructor for enum zmq.io.StreamEngine.Protocol
- PROTOCOL - Enum constant in enum zmq.io.StreamEngine.ErrorReason
- ProtocolCode(int) - Constructor for enum org.zeromq.ZMonitor.ProtocolCode
- ProtocolFamily - Interface in zmq.io.net
-
Replacement of ProtocolFamily from SDK so it can be used in Android environments.
- provider - Variable in class org.zeromq.ZProxy.ProxyActor
- Proxies - Search tag in class org.zeromq.ZMQ
- Section
- proxy(ZMQ.Socket, ZMQ.Socket, ZMQ.Socket) - Static method in class org.zeromq.ZMQ
-
Starts the built-in 0MQ proxy in the current application thread.
- proxy(ZMQ.Socket, ZMQ.Socket, ZMQ.Socket, ZMQ.Socket) - Static method in class org.zeromq.ZMQ
- proxy(SocketBase, SocketBase, SocketBase) - Static method in class zmq.Proxy
- proxy(SocketBase, SocketBase, SocketBase) - Static method in class zmq.ZMQ
- proxy(SocketBase, SocketBase, SocketBase, SocketBase) - Static method in class zmq.Proxy
- proxy(SocketBase, SocketBase, SocketBase, SocketBase) - Static method in class zmq.ZMQ
- Proxy - Class in zmq
- Proxy() - Constructor for class zmq.Proxy
- PROXY_PAUSE - Static variable in class org.zeromq.ZMQ
- PROXY_PAUSE - Static variable in class zmq.ZMQ
- PROXY_RESUME - Static variable in class org.zeromq.ZMQ
- PROXY_RESUME - Static variable in class zmq.ZMQ
- PROXY_TERMINATE - Static variable in class org.zeromq.ZMQ
- PROXY_TERMINATE - Static variable in class zmq.ZMQ
- Proxy.State - Enum in zmq
- ProxyActor(String, ZProxy.Pump, int) - Constructor for class org.zeromq.ZProxy.ProxyActor
- proxyAddress - Variable in class zmq.io.net.tcp.SocksConnecter
- PTRN_CONTAINER - Static variable in class org.zeromq.ZConfig
- PTRN_KEYVALUE - Static variable in class org.zeromq.ZConfig
- Pub - Class in zmq.socket.pubsub
- Pub(Ctx, int, int) - Constructor for class zmq.socket.pubsub.Pub
- PUB - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a PUB socket, receiving side must be a SUB or XSUB.
- PUB - Enum constant in enum zmq.socket.Sockets
- PUB - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- publicConfig() - Method in class org.zeromq.ZCert
- publicKey - Variable in class org.zeromq.ZCert
- publicKey - Variable in class org.zeromq.ZMQ.Curve.KeyPair
-
Z85-encoded public key.
- publicKey - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- PUBLICKEY - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- publicKeys - Variable in class org.zeromq.ZCertStore
- publicTxt - Variable in class org.zeromq.ZCert
- Pull - Class in zmq.socket.pipeline
- Pull(Ctx, int, int) - Constructor for class zmq.socket.pipeline.Pull
- PULL - Enum constant in enum org.zeromq.SocketType
-
Flag to specify the receiving part of a PUSH socket.
- PULL - Enum constant in enum zmq.socket.Sockets
- PULL - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- pullAndEncode - Variable in class zmq.io.StreamEngine
- pullAndEncode() - Method in class zmq.io.StreamEngine
- pullMsg() - Method in class zmq.io.HelloMsgSession
- pullMsg() - Method in class zmq.io.SessionBase
- pullMsg() - Method in class zmq.socket.radiodish.Dish.DishSession
- pullMsg() - Method in class zmq.socket.radiodish.Radio.RadioSession
- pullMsgFromSession - Variable in class zmq.io.StreamEngine
- pullMsgFromSession() - Method in class zmq.io.StreamEngine
- push(byte[]) - Method in class org.zeromq.ZMsg
- push(String) - Method in class org.zeromq.ZMsg
- push(ZFrame) - Method in class org.zeromq.ZMsg
- push(T) - Method in class zmq.pipe.YQueue
- Push - Class in zmq.socket.pipeline
- Push(Ctx, int, int) - Constructor for class zmq.socket.pipeline.Push
- PUSH - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a PUSH socket, receiving side must be a PULL.
- PUSH - Enum constant in enum zmq.socket.Sockets
- PUSH - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- pushMsg(Msg) - Method in class zmq.io.SessionBase
- pushMsg(Msg) - Method in class zmq.socket.radiodish.Dish.DishSession
- pushMsg(Msg) - Method in class zmq.socket.radiodish.Radio.RadioSession
- pushMsg(Msg) - Method in class zmq.socket.reqrep.Req.ReqSession
- pushMsgToSession - Variable in class zmq.io.StreamEngine
- pushMsgToSession(Msg) - Method in class zmq.io.StreamEngine
- pushOneThenDecodeAndPush - Variable in class zmq.io.StreamEngine
- pushOneThenDecodeAndPush(Msg) - Method in class zmq.io.StreamEngine
- pushRawMsgToSession - Variable in class zmq.io.StreamEngine
- pushRawMsgToSession(Msg) - Method in class zmq.io.StreamEngine
- put(byte) - Method in class zmq.Msg
- put(byte[]) - Method in class zmq.Msg
- put(byte[], int, int) - Method in class zmq.Msg.Builder
- put(byte[], int, int) - Method in class zmq.Msg
- put(int) - Method in class zmq.Msg
- put(int, byte) - Method in class zmq.Msg.Builder
- put(int, byte) - Method in class zmq.Msg
- put(ByteBuffer) - Method in class zmq.Msg
- put(ByteBuffer, int, int) - Method in class zmq.Msg.Builder
- put(ByteBuffer, int, int) - Method in class zmq.Msg
- putBlock(byte[], int) - Method in class org.zeromq.proto.ZNeedle
- putList(Collection<String>) - Method in class org.zeromq.proto.ZNeedle
- putLongString(String) - Method in class org.zeromq.proto.ZNeedle
- putLongString(ByteBuffer, String) - Static method in class zmq.util.Wire
- putLongString(Charset, ByteBuffer, String) - Static method in class zmq.util.Wire
- putMap(Map<String, String>) - Method in class org.zeromq.proto.ZNeedle
- putNumber1(int) - Method in class org.zeromq.proto.ZNeedle
- putNumber2(int) - Method in class org.zeromq.proto.ZNeedle
- putNumber4(int) - Method in class org.zeromq.proto.ZNeedle
- putNumber8(long) - Method in class org.zeromq.proto.ZNeedle
- putShortString(String) - Method in class org.zeromq.proto.ZNeedle
- putShortString(String) - Method in class zmq.Msg.Builder
- putShortString(String) - Method in class zmq.Msg
-
Puts a string into the message, prefixed with its length.
- putShortString(ByteBuffer, String) - Static method in class zmq.util.Wire
- putShortString(Charset, ByteBuffer, String) - Static method in class zmq.util.Wire
- putString(String) - Method in class org.zeromq.proto.ZNeedle
- putUInt16(int) - Static method in class zmq.util.Wire
- putUInt16(ByteBuffer, int) - Static method in class zmq.util.Wire
- putUInt16(Msg, int) - Static method in class zmq.util.Wire
- putUInt32(int) - Static method in class zmq.util.Wire
- putUInt32(ByteBuffer, int) - Static method in class zmq.util.Wire
- putUInt32(Msg, int) - Static method in class zmq.util.Wire
- putUInt64(ByteBuffer, long) - Static method in class zmq.util.Wire
- putUInt8(ByteBuffer, int) - Static method in class zmq.util.Wire
- putValue(String, String) - Method in class org.zeromq.ZConfig
- putValues(ZConfig) - Method in class org.zeromq.ZConfig
Q
- queue - Variable in class zmq.Ctx.ChannelForwardHolder
- queue - Variable in class zmq.pipe.YPipe
- QUEUE - Static variable in class org.zeromq.ZMQ
-
Deprecated.
R
- r - Variable in class zmq.pipe.YPipe
- r - Variable in class zmq.Signaler
- Radio - Class in zmq.socket.radiodish
- Radio(Ctx, int, int) - Constructor for class zmq.socket.radiodish.Radio
- RADIO - Enum constant in enum org.zeromq.SocketType
-
Flag to specify RADIO socket.
- RADIO - Enum constant in enum zmq.socket.Sockets
- Radio.RadioSession - Class in zmq.socket.radiodish
- Radio.RadioSession.State - Enum in zmq.socket.radiodish
- RadioSession(IOThread, boolean, SocketBase, Options, Address) - Constructor for class zmq.socket.radiodish.Radio.RadioSession
- random - Static variable in class zmq.util.Utils
- random(int) - Method in class zmq.io.mechanism.curve.Curve
- randomBytes(int) - Static method in class zmq.util.Utils
- randomBytes(int) - Static method in class zmq.Utils
-
Deprecated.
- randomInt() - Static method in class zmq.util.Utils
- randomInt() - Static method in class zmq.Utils
-
Deprecated.
- randomInt(int) - Static method in class zmq.util.Utils
- rate - Variable in class zmq.Options
- Raw - Class in zmq.socket
- Raw(Ctx, int, int) - Constructor for class zmq.socket.Raw
- RAW - Enum constant in enum org.zeromq.SocketType
-
Flag to specify RAW socket.
- RAW - Enum constant in enum zmq.socket.Sockets
- RawDecoder - Class in zmq.io.coder.raw
- RawDecoder(int) - Constructor for class zmq.io.coder.raw.RawDecoder
- RawEncoder - Class in zmq.io.coder.raw
- RawEncoder(Errno, int) - Constructor for class zmq.io.coder.raw.RawEncoder
- rawSocket - Variable in class zmq.Options
- rawSocket - Variable in class zmq.socket.reqrep.Router
- rcursor - Variable in class zmq.Signaler
- rcvbuf - Variable in class zmq.Options
- rcvhwm - Variable in class org.zeromq.ZContext
-
ZMQ_RCVHWM for normal sockets
- rcvmore - Variable in class zmq.SocketBase
- rdtsc() - Static method in class zmq.util.Clock
- rdummy - Variable in class zmq.Signaler
- read() - Method in class zmq.pipe.DBuffer
- read() - Method in class zmq.pipe.Pipe
- read() - Method in class zmq.pipe.YPipe
- read() - Method in interface zmq.pipe.YPipeBase
- read() - Method in class zmq.pipe.YPipeConflate
- read(String) - Static method in class org.zeromq.util.ZMetadata
- read(ByteBuffer) - Method in class zmq.io.StreamEngine
- read(ByteBuffer, int, Metadata.ParseListener) - Method in class zmq.io.Metadata
- read(ZConfig) - Static method in class org.zeromq.util.ZMetadata
- read(Msg, int, Metadata.ParseListener) - Method in class zmq.io.Metadata
- read(SocketBase) - Static method in class zmq.ZMQ.Event
- read(SocketBase, int) - Static method in class zmq.ZMQ.Event
- readable(Object) - Method in class org.zeromq.ZPoller
- readable(SelectableChannel) - Method in class org.zeromq.ZPoller
- readable(ZMQ.Socket) - Method in class org.zeromq.ZPoller
- READABLE - Static variable in class org.zeromq.ZPoller
- readActivated(Pipe) - Method in class zmq.io.SessionBase
- readActivated(Pipe) - Method in interface zmq.pipe.Pipe.IPipeEvents
- readActivated(Pipe) - Method in class zmq.SocketBase
- readerAwake - Variable in class zmq.pipe.YPipeConflate
- ReadException(String, String, AtomicInteger) - Constructor for exception class org.zeromq.ZConfig.ReadException
- readIndex - Variable in class zmq.Msg
- readPos - Variable in class zmq.io.coder.DecoderBase
- ready - Variable in class zmq.poll.PollItem
- READY - Enum constant in enum zmq.io.mechanism.Mechanism.Status
- READY - Enum constant in enum zmq.io.mechanism.plain.PlainClientMechanism.State
- READY - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- READY - Static variable in class zmq.io.mechanism.NullMechanism
- readyCommandReceived - Variable in class zmq.io.mechanism.NullMechanism
- readyCommandSent - Variable in class zmq.io.mechanism.NullMechanism
- readyOps() - Method in class org.zeromq.ZMQ.PollItem
- readyOps() - Method in class zmq.poll.PollItem
- readyOps(SelectionKey, int) - Method in class zmq.poll.PollItem
- readZapMsg() - Method in class zmq.io.SessionBase
- realloc(byte[], int) - Static method in class zmq.util.Utils
- realloc(byte[], int) - Static method in class zmq.Utils
-
Deprecated.
- realloc(Class<T>, T[], int, boolean) - Static method in class zmq.util.Utils
- realloc(Class<T>, T[], int, boolean) - Static method in class zmq.Utils
-
Deprecated.
- realloc(Mtrie[], int, boolean) - Method in class zmq.socket.pubsub.Mtrie
- realloc(Trie[], int, boolean) - Method in class zmq.socket.pubsub.Trie
- REAP - Enum constant in enum zmq.Command.Type
- REAP_ACK - Enum constant in enum zmq.Command.Type
- REAPED - Enum constant in enum zmq.Command.Type
- reaper - Variable in class zmq.Ctx
- Reaper - Class in zmq
- Reaper(Ctx, int) - Constructor for class zmq.Reaper
- REAPER_TID - Static variable in class zmq.Ctx
- reaperSignaler - Variable in class zmq.SocketBase
- rebuild() - Method in class org.zeromq.ZLoop
- rebuildSelector() - Method in class zmq.poll.Poller
- receive() - Method in class org.zeromq.ZSocket
- receive(int) - Method in class org.zeromq.ZSocket
- receiveAndProcessZapReply() - Method in class zmq.io.mechanism.Mechanism
- received(ZMsg) - Static method in class org.zeromq.ZAuth.ZapReply
- receiveStringUtf8() - Method in class org.zeromq.ZSocket
- receiveStringUtf8(int) - Method in class org.zeromq.ZSocket
- receivingReply - Variable in class zmq.socket.reqrep.Req
- reconnect() - Method in class zmq.io.SessionBase
- RECONNECT_TIMER_ID - Static variable in class zmq.io.net.tcp.TcpConnecter
- reconnectIvl - Variable in class zmq.Options
- reconnectIvlMax - Variable in class zmq.Options
- recoveryIvl - Variable in class zmq.Options
- recv() - Method in interface org.zeromq.ZAgent
-
Receives a control message sent from the Plateau in the Corbeille.
- recv() - Method in class org.zeromq.ZAgent.SimpleAgent
- recv() - Method in class org.zeromq.ZMQ.Socket
-
Receives a message.
- recv() - Method in class org.zeromq.ZStar
- recv() - Method in class zmq.Signaler
- recv(boolean) - Method in interface org.zeromq.ZAgent
-
Receives a control message sent from the Plateau in the Corbeille.
- recv(boolean) - Method in class org.zeromq.ZAgent.SimpleAgent
- recv(boolean) - Method in class org.zeromq.ZStar
- recv(byte[], int, int, int) - Method in class org.zeromq.ZMQ.Socket
-
Receives a message in to a specified buffer.
- recv(int) - Method in interface org.zeromq.ZAgent
-
Receives a control message sent from the Plateau in the Corbeille.
- recv(int) - Method in class org.zeromq.ZAgent.SimpleAgent
- recv(int) - Method in class org.zeromq.ZMQ.Socket
-
Receives a message.
- recv(int) - Method in class org.zeromq.ZStar
- recv(int) - Method in class zmq.SocketBase
- recv(int, AtomicBoolean) - Method in class zmq.SocketBase
- recv(int, ZMQ.CancellationToken) - Method in class org.zeromq.ZMQ.Socket
-
Receives a message, the call be canceled by calling cancellationToken
ZMQ.CancellationToken.cancel()
. - recv(long) - Method in interface zmq.IMailbox
- recv(long) - Method in class zmq.Mailbox
- recv(long) - Method in class zmq.MailboxSafe
- recv(ZAgent, boolean) - Static method in class org.zeromq.ZAuth.ZapReply
- recv(ZAgent, int) - Static method in class org.zeromq.ZAuth.ZapReply
- recv(ZMQ.Socket) - Static method in class org.zeromq.ZMQ.Event
-
Receive an event from a monitor socket.
- recv(ZMQ.Socket, int) - Static method in class org.zeromq.ZMQ.Event
-
Receive an event from a monitor socket.
- recv(SocketBase, int) - Static method in class zmq.ZMQ
- recv(Errno) - Method in class zmq.socket.FQ
- recvBinaryPicture(String) - Method in class org.zeromq.ZMQ.Socket
-
Receive a binary encoded 'picture' message from the socket (or actor).
- recvBinaryPicture(ZMQ.Socket, String) - Method in class org.zeromq.proto.ZPicture
-
Receive a binary encoded 'picture' message from the socket (or actor).
- recvByteBuffer(ByteBuffer, int) - Method in class org.zeromq.ZMQ.Socket
-
Receives a message into the specified ByteBuffer.
- recvFrame(ZMQ.Socket) - Static method in class org.zeromq.ZFrame
-
Receives single frame from socket, returns the received frame object, or null if the recv was interrupted.
- recvFrame(ZMQ.Socket, int) - Static method in class org.zeromq.ZFrame
-
Receive a new frame off the socket, Returns newly-allocated frame, or null if there was no input waiting, or if the read was interrupted.
- recvHwm - Variable in class zmq.Options
- recvIdentity - Variable in class zmq.Options
- recviov(SocketBase, byte[][], int, int) - Method in class zmq.ZMQ
- recvMsg(ZMQ.Socket) - Static method in class org.zeromq.ZMsg
-
Receives message from socket, returns ZMsg object or null if the recv was interrupted.
- recvMsg(ZMQ.Socket, boolean) - Static method in class org.zeromq.ZMsg
-
Receives message from socket, returns ZMsg object or null if the recv was interrupted.
- recvMsg(ZMQ.Socket, int) - Static method in class org.zeromq.ZMsg
-
Receives message from socket, returns ZMsg object or null if the recv was interrupted.
- recvMsg(ZMQ.Socket, int, Consumer<ZMsg>) - Static method in class org.zeromq.ZMsg
-
This API is in DRAFT state and is subject to change at ANY time until declared stable handle incoming message with a handler
- recvMsg(ZMQ.Socket, int, Consumer<ZMsg>, Consumer<ZMQException>) - Static method in class org.zeromq.ZMsg
-
This API is in DRAFT state and is subject to change at ANY time until declared stable handle incoming message with a handler
- recvMsg(SocketBase, int) - Static method in class zmq.ZMQ
- recvPicture(String) - Method in class org.zeromq.ZMQ.Socket
-
Receive a 'picture' message to the socket (or actor).
- recvPicture(ZMQ.Socket, String) - Method in class org.zeromq.proto.ZPicture
-
Receive a 'picture' message to the socket (or actor).
- recvpipe(ValueReference<Pipe>) - Method in class zmq.socket.reqrep.Dealer
- recvPipe(Errno, ValueReference<Pipe>) - Method in class zmq.socket.FQ
- recvReplyPipe() - Method in class zmq.socket.reqrep.Req
- recvRequest(ZMQ.Socket, boolean) - Static method in class org.zeromq.ZAuth.ZapRequest
- recvStatus() - Method in class org.zeromq.ZProxy
- recvStr() - Method in class org.zeromq.ZMQ.Socket
- recvStr(int) - Method in class org.zeromq.ZMQ.Socket
-
Receives a message as a string.
- recvTimeout - Variable in class zmq.Options
- refcnt - Variable in class zmq.socket.pubsub.Trie
- register(SelectableChannel) - Method in class org.zeromq.ZMQ.Poller
-
Register a Channel for polling on all events.
- register(SelectableChannel, int) - Method in class org.zeromq.ZMQ.Poller
-
Register a Socket for polling on the specified events.
- register(SelectableChannel, int) - Method in class org.zeromq.ZPoller
-
Registers a SelectableChannel for polling on specified events.
- register(SelectableChannel, ZPoller.EventsHandler) - Method in class org.zeromq.ZPoller
-
Registers a SelectableChannel for polling on all events.
- register(SelectableChannel, ZPoller.EventsHandler, int) - Method in class org.zeromq.ZPoller
-
Registers a SelectableChannel for polling on specified events.
- register(SelectableChannel, BiFunction<SelectableChannel, Integer, Boolean>, int) - Method in class org.zeromq.ZPoller
-
Registers a SelectableChannel for polling on specified events.
- register(ZMQ.PollItem) - Method in class org.zeromq.ZMQ.Poller
-
Register a Channel for polling on the specified events.
- register(ZMQ.Socket) - Method in class org.zeromq.ZMQ.Poller
-
Register a Socket for polling on all events.
- register(ZMQ.Socket, int) - Method in class org.zeromq.ZMQ.Poller
-
Register a Socket for polling on the specified events.
- register(ZMQ.Socket, int) - Method in class org.zeromq.ZPoller
- register(ZMQ.Socket, ZPoller.EventsHandler) - Method in class org.zeromq.ZPoller
- register(ZMQ.Socket, ZPoller.EventsHandler, int) - Method in class org.zeromq.ZPoller
-
Register a Socket for polling on specified events.
- register(ZMQ.Socket, BiFunction<ZMQ.Socket, Integer, Boolean>, int) - Method in class org.zeromq.ZPoller
-
Register a Socket for polling on specified events.
- register(ZPoller.ItemHolder) - Method in class org.zeromq.ZPoller
-
Register an ItemHolder for polling on specified events.
- register(Poller.Handle, int, boolean) - Method in class zmq.poll.Poller
- registerEndpoint(String, Ctx.Endpoint) - Method in class zmq.Ctx
- registerEndpoint(String, Ctx.Endpoint) - Method in class zmq.ZObject
- registerInternal(ZMQ.PollItem) - Method in class org.zeromq.ZMQ.Poller
-
Register a Socket for polling on the specified events.
- registerTermAcks(int) - Method in class zmq.Own
- reloadIfNecessary() - Method in class org.zeromq.ZCertStore
- remove() - Method in class org.zeromq.ZMsg
- remove(Object) - Method in class org.zeromq.ZMsg
- remove(String) - Method in class org.zeromq.util.ZMetadata
- remove(String) - Method in class zmq.io.Metadata
- remove(K) - Method in class zmq.util.MultiMap
- remove(K, V) - Method in class zmq.util.MultiMap
- remove(ZMonitor.Event...) - Method in class org.zeromq.ZMonitor
-
Removes event types from monitor.
- remove(V) - Method in class zmq.util.MultiMap
- REMOVE_EVENTS - Static variable in class org.zeromq.ZMonitor
- removeAll(Collection<?>) - Method in class org.zeromq.ZMsg
- removeData(K, V) - Method in class zmq.util.MultiMap
- removeEvents(ZMQ.Socket) - Method in class org.zeromq.ZMonitor.MonitorActor
- removeFirst() - Method in class org.zeromq.ZMsg
- removeFirstOccurrence(Object) - Method in class org.zeromq.ZMsg
- removeHandle(Poller.Handle) - Method in class zmq.io.IOObject
- removeHandle(Poller.Handle) - Method in class zmq.poll.Poller
- removeLast() - Method in class org.zeromq.ZMsg
- removeLastOccurrence(Object) - Method in class org.zeromq.ZMsg
- removePoller(ZMQ.PollItem) - Method in class org.zeromq.ZLoop
- removeSignaler(Signaler) - Method in class zmq.MailboxSafe
- removeTimer(Object) - Method in class org.zeromq.ZLoop
- renews() - Method in class org.zeromq.ZActor.Double
- renews() - Method in interface org.zeromq.ZStar.Star
-
Does the star want to renew for a new performance ? Hint: Can be used to perform decisions to continue looping or not, or to send computed data to outputs, or ...
Key point: the inner looping mechanism just ended
Decision: to exit or not - Rep - Class in zmq.socket.reqrep
- Rep(Ctx, int, int) - Constructor for class zmq.socket.reqrep.Rep
- REP - Enum constant in enum org.zeromq.SocketType
-
Flag to specify the receiving part of a REQ or DEALER socket.
- REP - Enum constant in enum zmq.socket.Sockets
- REP - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- replies - Variable in class org.zeromq.ZAuth.AuthActor
- replies - Variable in class org.zeromq.ZAuth
- replies(boolean) - Method in class org.zeromq.ZAuth
- REPLIES - Static variable in class org.zeromq.ZAuth
- repliesAddress - Variable in class org.zeromq.ZAuth.AuthActor
- repliesEnabled - Variable in class org.zeromq.ZAuth.AuthActor
- repliesEnabled - Variable in class org.zeromq.ZAuth
- reply(int, String, ZMQ.Socket) - Method in class org.zeromq.ZAuth.ZapRequest
-
Send a zap reply to the handler socket
- replyPipe - Variable in class zmq.socket.reqrep.Req
- Req - Class in zmq.socket.reqrep
- Req(Ctx, int, int) - Constructor for class zmq.socket.reqrep.Req
- REQ - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a REQ socket, receiving side must be a REP or ROUTER.
- REQ - Enum constant in enum zmq.socket.Sockets
- REQ - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- Req.ReqSession - Class in zmq.socket.reqrep
- Req.ReqSession.State - Enum in zmq.socket.reqrep
- ReqSession(IOThread, boolean, SocketBase, Options, Address) - Constructor for class zmq.socket.reqrep.Req.ReqSession
- REQUEST_ID - Enum constant in enum zmq.socket.reqrep.Req.ReqSession.State
- requestBegins - Variable in class zmq.socket.reqrep.Rep
- requestId - Variable in class zmq.socket.reqrep.Req
- requestIdFramesEnabled - Variable in class zmq.socket.reqrep.Req
- requireNonNull(T, String) - Static method in class zmq.util.Objects
- reset() - Method in class org.zeromq.timer.ZTicket.Ticket
-
Resets the ticket.
- reset() - Method in class org.zeromq.timer.ZTimer.Timer
-
Reset the timer.
- reset() - Method in class org.zeromq.ZMQ.CancellationToken
-
Reset the cancellation token in order to reuse the token with another send/receive call.
- reset() - Method in class zmq.io.HelloMsgSession
- reset() - Method in class zmq.io.SessionBase
- reset() - Method in class zmq.socket.radiodish.Dish.DishSession
- reset() - Method in class zmq.socket.radiodish.Radio.RadioSession
- reset() - Method in class zmq.socket.reqrep.Req.ReqSession
- reset() - Method in class zmq.util.Timers.Timer
-
Reset the timer.
- reset(byte[]) - Method in class org.zeromq.ZFrame
-
Sets new contents for frame
- reset(String) - Method in class org.zeromq.ZFrame
-
Sets new contents for frame
- reset(ZTimer.Timer) - Method in class org.zeromq.ZTimer
-
Deprecated.use
ZTimer.Timer.reset()
instead - reset(Timers.Timer) - Method in class zmq.util.Timers
-
Deprecated.use
Timers.Timer.reset()
instead - resetFlags(int) - Method in class zmq.Msg
- resetMetadata() - Method in class zmq.Msg
- resetPollIn(Poller.Handle) - Method in class zmq.io.IOObject
- resetPollIn(Poller.Handle) - Method in class zmq.poll.Poller
- resetPollOut(Poller.Handle) - Method in class zmq.io.IOObject
- resetPollOut(Poller.Handle) - Method in class zmq.poll.Poller
- resetRoutingId() - Method in class zmq.Msg
- resolve(boolean) - Method in class zmq.io.net.Address
- resolve(String, boolean, boolean) - Method in interface zmq.io.net.Address.IZAddress
- resolve(String, boolean, boolean) - Method in class zmq.io.net.ipc.IpcAddress
- resolve(String, boolean, boolean) - Method in class zmq.io.net.tcp.TcpAddress
- resolve(Address, boolean) - Method in enum zmq.io.net.NetProtocol
- resolved - Variable in class zmq.io.net.Address
- resolved() - Method in class zmq.io.net.Address
- resolvedValue - Variable in class org.zeromq.ZMQ.Event
- resolveValue() - Method in class org.zeromq.ZMQ.Event
-
Return the argument as an integer or a Enum of the appropriate type if available.
- restart - Variable in class org.zeromq.ZProxy.ProxyActor.State
- restart(ZMQ.Socket, boolean) - Method in class org.zeromq.ZProxy.ProxyActor
- restart(ZMsg) - Method in class org.zeromq.ZProxy
-
Restarts the proxy.
- restart(ZMsg, ZMQ.Socket, ZProxy.Plug, Object...) - Method in interface org.zeromq.ZProxy.Proxy
-
Performs a hot restart of the given socket.
- restart(ZMsg, ZMQ.Socket, ZProxy.Plug, Object...) - Method in class org.zeromq.ZProxy.Proxy.SimpleProxy
- RESTART - Enum constant in enum org.zeromq.ZProxy.Command
- RESTART - Static variable in class org.zeromq.ZProxy
- restartInput() - Method in class zmq.io.EngineNotImplemented
- restartInput() - Method in interface zmq.io.IEngine
- restartInput() - Method in class zmq.io.StreamEngine
- restartOutput() - Method in class zmq.io.EngineNotImplemented
- restartOutput() - Method in interface zmq.io.IEngine
- restartOutput() - Method in class zmq.io.StreamEngine
- Result(int) - Constructor for enum zmq.io.coder.IDecoder.Step.Result
- retainAll(Collection<?>) - Method in class org.zeromq.ZMsg
- retired - Variable in class zmq.poll.Poller
- REUSE - Static variable in class org.zeromq.ZFrame
- reversemap - Variable in class zmq.Ctx.ChannelForwardHolder
- revision - Variable in enum zmq.io.StreamEngine.Protocol
- rm(Msg, int, int) - Method in class zmq.socket.pubsub.Trie
- rm(Msg, Pipe) - Method in class zmq.socket.pubsub.Mtrie
- rm(Pipe, Mtrie.IMtrieHandler, XPub) - Method in class zmq.socket.pubsub.Mtrie
- rmHelper(Msg, int, int, Pipe) - Method in class zmq.socket.pubsub.Mtrie
- rmHelper(Pipe, byte[], int, int, Mtrie.IMtrieHandler, XPub) - Method in class zmq.socket.pubsub.Mtrie
- rollback() - Method in class zmq.pipe.Pipe
- rollback() - Method in class zmq.socket.reqrep.Router
- Router - Class in zmq.socket.reqrep
- Router(Ctx, int, int) - Constructor for class zmq.socket.reqrep.Router
- ROUTER - Enum constant in enum org.zeromq.SocketType
-
Flag to specify ROUTER socket (aka XREP).
- ROUTER - Enum constant in enum zmq.socket.Sockets
- ROUTER - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- Router.Outpipe - Class in zmq.socket.reqrep
- routingId - Variable in class org.zeromq.ZFrame
- routingId - Variable in class zmq.Msg
- routingId - Variable in class zmq.pipe.Pipe
- run() - Method in class org.zeromq.ZBeacon.BroadcastClient
- run() - Method in class org.zeromq.ZBeacon.BroadcastServer
- run() - Method in class org.zeromq.ZMQQueue
- run() - Method in class org.zeromq.ZThread.ShimThread
- run() - Method in class zmq.poll.Poller
- run(Object[]) - Method in interface org.zeromq.ZThread.IDetachedRunnable
- run(Object[], ZContext, ZMQ.Socket) - Method in class org.zeromq.ZStar.Plateau
- run(Object[], ZContext, ZMQ.Socket) - Method in interface org.zeromq.ZThread.IAttachedRunnable
S
- save(Writer) - Method in class org.zeromq.ZConfig
- save(String) - Method in class org.zeromq.ZConfig
-
Saves the configuration to a file.
- save(ZMsg, DataOutputStream) - Static method in class org.zeromq.ZMsg
-
Save message to an open data output stream.
- savedCredential - Variable in class zmq.socket.Channel
- savedCredential - Variable in class zmq.socket.FQ
- savedCredential - Variable in class zmq.socket.Pair
- savePublic(Writer) - Method in class org.zeromq.ZCert
-
Saves the public key to a writer.
- savePublic(String) - Method in class org.zeromq.ZCert
-
Saves the public key to a file.
- saveSecret(Writer) - Method in class org.zeromq.ZCert
-
Saves the public and secret keys to a writer.
- saveSecret(String) - Method in class org.zeromq.ZCert
-
Saves the public and secret keys to a file.
- Scatter - Class in zmq.socket.scattergather
- Scatter(Ctx, int, int) - Constructor for class zmq.socket.scattergather.Scatter
- SCATTER - Enum constant in enum org.zeromq.SocketType
-
Flag to specify SCATTER socket.
- SCATTER - Enum constant in enum zmq.socket.Sockets
- secretbox(byte[], byte[], int, byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- secretbox(ByteBuffer, ByteBuffer, int, ByteBuffer, byte[]) - Method in class zmq.io.mechanism.curve.Curve
- secretboxOpen(byte[], byte[], int, byte[], byte[]) - Method in class zmq.io.mechanism.curve.Curve
- secretboxOpen(ByteBuffer, ByteBuffer, int, ByteBuffer, byte[]) - Method in class zmq.io.mechanism.curve.Curve
- secretConfig() - Method in class org.zeromq.ZCert
- secretKey - Variable in class org.zeromq.ZCert
- secretKey - Variable in class org.zeromq.ZMQ.Curve.KeyPair
-
Z85-encoded secret key.
- secretKey - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- secretKey - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- SECRETKEY - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- secretTxt - Variable in class org.zeromq.ZCert
- Security - Search tag in class org.zeromq.ZMQ
- Section
- selector - Variable in class org.zeromq.ZMQ.Poller
- selector - Variable in class org.zeromq.ZPoller
- selector - Variable in class zmq.poll.Poller
- selector - Variable in class zmq.Signaler
- selector() - Method in class org.zeromq.ZContext
-
Creates a selector.
- selector() - Method in class org.zeromq.ZMQ.Context
-
Create a new Selector within this context.
- selectorChooser - Variable in class zmq.Options
- SelectorProviderChooser - Interface in zmq.io.net
-
By implementing this class, it's possible to change the kind of channel used in tcp connections.
- selectors - Variable in class org.zeromq.ZContext
-
List of selectors managed by this ZContext
- selectors - Variable in class zmq.Ctx
- selectorSync - Variable in class zmq.Ctx
- send() - Method in class zmq.Signaler
- send(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data, so it can be sent.
- send(byte[]) - Method in class org.zeromq.ZSocket
- send(byte[], int) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data, so it can be sent.
- send(byte[], int) - Method in class org.zeromq.ZSocket
- send(byte[], int, int, int) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data, so it can be sent.
- send(byte[], int, ZMQ.CancellationToken) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data, so it can be sent, the call be canceled by calling cancellationToken
ZMQ.CancellationToken.cancel()
. - send(String) - Method in interface org.zeromq.ZAgent
-
Sends a control message from the Corbeille to the Plateau side.
- send(String) - Method in class org.zeromq.ZAgent.SimpleAgent
- send(String) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data, so it can be sent.
- send(String) - Method in class org.zeromq.ZStar
- send(String, boolean) - Method in interface org.zeromq.ZAgent
-
Sends a control message from the Corbeille to the Plateau side.
- send(String, boolean) - Method in class org.zeromq.ZAgent.SimpleAgent
- send(String, boolean) - Method in class org.zeromq.ZStar
- send(String, int) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data.
- send(String, String...) - Method in class org.zeromq.ZAuth
- send(ZMQ.Socket) - Method in class org.zeromq.ZMsg
-
Send message to 0MQ socket.
- send(ZMQ.Socket, boolean) - Method in class org.zeromq.ZMsg
-
Send message to 0MQ socket, destroys contents after sending if destroy param is set to true.
- send(ZMQ.Socket, int) - Method in class org.zeromq.ZFrame
-
Internal method to call org.zeromq.Socket send() method.
- send(ZMsg) - Method in interface org.zeromq.ZAgent
-
Sends a control message from the Corbeille to the Plateau.
- send(ZMsg) - Method in class org.zeromq.ZAgent.SimpleAgent
- send(ZMsg) - Method in class org.zeromq.ZStar
- send(ZMsg, boolean) - Method in interface org.zeromq.ZAgent
-
Sends a control message from Corbeille side to the Plateau side.
- send(ZMsg, boolean) - Method in class org.zeromq.ZAgent.SimpleAgent
- send(ZMsg, boolean) - Method in class org.zeromq.ZStar
- send(Command) - Method in interface zmq.IMailbox
- send(Command) - Method in class zmq.Mailbox
- send(Command) - Method in class zmq.MailboxSafe
- send(Msg, int) - Method in class zmq.SocketBase
- send(Msg, int, AtomicBoolean) - Method in class zmq.SocketBase
- send(SocketBase, byte[], int) - Static method in class zmq.ZMQ
- send(SocketBase, byte[], int, int) - Static method in class zmq.ZMQ
- send(SocketBase, String, int) - Static method in class zmq.ZMQ
- send(SocketBase, Msg, int) - Static method in class zmq.ZMQ
- SEND_ERROR - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- SEND_HELLO - Enum constant in enum zmq.io.mechanism.curve.CurveClientMechanism.State
- SEND_INITIATE - Enum constant in enum zmq.io.mechanism.curve.CurveClientMechanism.State
- SEND_READY - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- SEND_WELCOME - Enum constant in enum zmq.io.mechanism.curve.CurveServerMechanism.State
- sendActivateRead(Pipe) - Method in class zmq.ZObject
- sendActivateWrite(Pipe, long) - Method in class zmq.ZObject
- sendAndDestroy(ZMQ.Socket) - Method in class org.zeromq.ZFrame
-
Sends frame to socket if it contains data.
- sendAndDestroy(ZMQ.Socket, int) - Method in class org.zeromq.ZFrame
-
Sends frame to socket if it contains data.
- sendAndKeep(ZMQ.Socket) - Method in class org.zeromq.ZFrame
-
Sends frame to socket if it contains any data.
- sendAndKeep(ZMQ.Socket, int) - Method in class org.zeromq.ZFrame
-
Sends frame to socket if it contains any data.
- sendAttach(SessionBase, IEngine) - Method in class zmq.ZObject
- sendAttach(SessionBase, IEngine, boolean) - Method in class zmq.ZObject
- sendBinaryPicture(String, Object...) - Method in class org.zeromq.ZMQ.Socket
-
Queues a binary encoded 'picture' message to the socket (or actor), so it can be sent.
- sendBinaryPicture(ZMQ.Socket, String, Object...) - Method in class org.zeromq.proto.ZPicture
- sendBind(Own, Pipe) - Method in class zmq.ZObject
- sendBind(Own, Pipe, boolean) - Method in class zmq.ZObject
- sendByteBuffer(ByteBuffer, int) - Method in class org.zeromq.ZMQ.Socket
-
Queues a message created from data, so it can be sent.
- sendCancel() - Method in class zmq.ZObject
- sendCommand(int, Command) - Method in class zmq.Ctx
- sendCommand(Command) - Method in class zmq.ZObject
- sendDisconnectMsg() - Method in class zmq.pipe.Pipe
- sendDone() - Method in class zmq.ZObject
- sendFrame(ZFrame, int) - Method in class org.zeromq.ZSocket
-
Send a frame
- sendHiccup(Pipe, YPipeBase<Msg>) - Method in class zmq.ZObject
- sendHiccupMsg(Msg) - Method in class zmq.pipe.Pipe
- sendHwm - Variable in class zmq.Options
- SENDING_ERROR - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- SENDING_GREETING - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- SENDING_HELLO - Enum constant in enum zmq.io.mechanism.plain.PlainClientMechanism.State
- SENDING_INITIATE - Enum constant in enum zmq.io.mechanism.plain.PlainClientMechanism.State
- SENDING_READY - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- SENDING_REQUEST - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- SENDING_WELCOME - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- sendingReply - Variable in class zmq.socket.reqrep.Rep
- sendInprocConnected(SocketBase) - Method in class zmq.ZObject
- sendiov(SocketBase, byte[][], int, int) - Method in class zmq.ZMQ
- sendMessage(ZMsg) - Method in class org.zeromq.ZSocket
- sendMore(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Queues a multi-part message created from data, so it can be sent.
- sendMore(String) - Method in class org.zeromq.ZMQ.Socket
-
Queues a multi-part message created from data, so it can be sent.
- sendMsg(SocketBase, byte[]...) - Static method in class zmq.ZMQ
- sendMsg(SocketBase, Msg, int) - Static method in class zmq.ZMQ
- sendOwn(Own, Own) - Method in class zmq.ZObject
- sendPicture(String, Object...) - Method in class org.zeromq.ZMQ.Socket
-
Queues a 'picture' message to the socket (or actor), so it can be sent.
- sendPicture(ZMQ.Socket, String, Object...) - Method in class org.zeromq.proto.ZPicture
-
Queues a 'picture' message to the socket (or actor), so it can be sent.
- sendpipe(Msg, Errno, ValueReference<Pipe>) - Method in class zmq.socket.LB
- sendpipe(Msg, ValueReference<Pipe>) - Method in class zmq.socket.reqrep.Dealer
- sendPipeTerm(Pipe) - Method in class zmq.ZObject
- sendPipeTermAck(Pipe) - Method in class zmq.ZObject
- sendPlug(Own) - Method in class zmq.ZObject
- sendPlug(Own, boolean) - Method in class zmq.ZObject
- sendReap(SocketBase) - Method in class zmq.ZObject
- sendReapAck() - Method in class zmq.ZObject
- sendReaped() - Method in class zmq.ZObject
- sendSeqnum - Variable in class zmq.Own
- sendStop() - Method in class zmq.ZObject
- sendStringUtf8(String) - Method in class org.zeromq.ZSocket
- sendStringUtf8(String, int) - Method in class org.zeromq.ZSocket
- sendSubscription - Variable in class zmq.socket.pubsub.XSub
- sendSubscription(byte[], int, Pipe) - Method in class zmq.socket.pubsub.XSub
- SendSubscription() - Constructor for class zmq.socket.pubsub.XSub.SendSubscription
- sendSubscriptions(Pipe) - Method in class zmq.socket.radiodish.Dish
- sendTerm(Own, int) - Method in class zmq.ZObject
- sendTermAck(Own) - Method in class zmq.ZObject
- sendTermReq(Own, Own) - Method in class zmq.ZObject
- sendTimeout - Variable in class zmq.Options
- sendToAll(Msg) - Method in class zmq.socket.pubsub.Dist
- sendToMatching(Msg) - Method in class zmq.socket.pubsub.Dist
- sendUnsubscription - Static variable in class zmq.socket.pubsub.XPub
- sendUnsubscription(byte[], int) - Method in class zmq.socket.pubsub.XPub
- SendUnsubscription() - Constructor for class zmq.socket.pubsub.XPub.SendUnsubscription
- sendZapRequest(byte[]) - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- sendZapRequest(byte[], byte[]) - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- sendZapRequest(Mechanisms, boolean) - Method in class zmq.io.mechanism.Mechanism
- sequence - Variable in class org.zeromq.ZAuth.ZapReply
- sequence - Variable in class org.zeromq.ZAuth.ZapRequest
- serialVersionUID - Static variable in exception class org.zeromq.UncheckedZMQException
- serialVersionUID - Static variable in exception class org.zeromq.ZConfig.ReadException
- serialVersionUID - Static variable in exception class org.zeromq.ZMQException
- serialVersionUID - Static variable in exception class zmq.ZError.CtxTerminatedException
- serialVersionUID - Static variable in exception class zmq.ZError.InstantiationException
- serialVersionUID - Static variable in exception class zmq.ZError.IOException
- server(byte[]) - Method in class org.zeromq.ZBeacon.Builder
-
Deprecated.
- server(InetAddress) - Method in class org.zeromq.ZBeacon.Builder
- Server - Class in zmq.socket.clientserver
- Server(Ctx, int, int) - Constructor for class zmq.socket.clientserver.Server
- SERVER - Enum constant in enum org.zeromq.SocketType
-
Flag to specify SERVER socket.
- SERVER - Enum constant in enum zmq.socket.Sockets
- Server.Outpipe - Class in zmq.socket.clientserver
- serverAddr - Variable in class org.zeromq.ZBeacon.Builder
- serverExHandler - Variable in class org.zeromq.ZBeacon.Builder
- serverExHandler - Variable in class org.zeromq.ZBeacon
- serverKey - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- session - Variable in class zmq.io.mechanism.Mechanism
- session - Variable in class zmq.io.net.tcp.TcpConnecter
- session - Variable in class zmq.io.StreamEngine
- SessionBase - Class in zmq.io
- SessionBase(IOThread, boolean, SocketBase, Options, Address) - Constructor for class zmq.io.SessionBase
- set(int) - Method in class zmq.util.Errno
- set(int, int) - Method in class zmq.Ctx
- set(String, String) - Method in class org.zeromq.util.ZMetadata
- set(String, String) - Method in class zmq.io.Metadata
- set(V) - Method in class zmq.util.ValueReference
- set(Metadata) - Method in class zmq.io.Metadata
- setAddress() - Method in class zmq.io.net.tcp.TcpListener
- setAddress(String) - Method in class zmq.io.net.ipc.IpcListener
- setAddress(String) - Method in class zmq.io.net.Listener
- setAddress(String) - Method in class zmq.io.net.tcp.TcpListener
- setAddress(InetSocketAddress) - Method in class zmq.io.net.tcp.TcpListener
- setAffinity(long) - Method in class org.zeromq.ZMQ.Socket
-
Get the Affinity.
- setAsServerCurve(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the naming is inconsistent with jzmq, please use
ZMQ.Socket.setCurveServer(boolean)
instead - setAsServerPlain(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the naming is inconsistent with jzmq, please use
ZMQ.Socket.setPlainServer(boolean)
instead - setBacklog(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_BACKLOG option shall set the maximum length of the queue of outstanding peer connections for the specified socket; this only applies to connection-oriented transports.
- setBacklog(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setBacklog(int)
instead. - setBeacon(byte[]) - Method in class org.zeromq.ZBeacon
-
Deprecated.use the builder
- setBlocky(boolean) - Method in class org.zeromq.ZMQ.Context
- setBroadcastInterval(long) - Method in class org.zeromq.ZBeacon
- setClientUncaughtExceptionHandlers(Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZBeacon.Builder
- setConflate(boolean) - Method in class org.zeromq.ZMQ.Socket
-
If set, a socket shall keep only one message in its inbound/outbound queue, this message being the last message received/the last message to be sent.
- setConnectRid(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_CONNECT_RID option sets the peer id of the next host connected via the connect() call, and immediately readies that connection for data transfer with the named id.
- setConnectRid(String) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_CONNECT_RID option sets the peer id of the next host connected via the connect() call, and immediately readies that connection for data transfer with the named id.
- setContext(ZMQ.Context) - Method in class org.zeromq.ZContext
-
Deprecated.This value should not be changed after the ZContext is initialized.
- setContextOption(Ctx, int, int) - Static method in class zmq.ZMQ
- setCurveKey(int, Object, ValueReference<Boolean>) - Method in class zmq.Options
- setCurvePublicKey(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the socket's long term public key.
- setCurveSecretKey(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the socket's long term secret key.
- setCurveServer(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Defines whether the socket will act as server for CURVE security, see zmq_curve(7).
- setCurveServerKey(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the socket's long term server key.
- setDecoder(Class<? extends IDecoder>) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- setDelay(long) - Method in class org.zeromq.timer.ZTicket.Ticket
-
Changes the delay of the ticket.
- setDelayAttachOnConnect(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.use
ZMQ.Socket.setImmediate(boolean)
instead (warning, the boolean is inverted) - setDisconnectMsg(Msg) - Method in class zmq.pipe.Pipe
- setEncoder(Class<? extends IEncoder>) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- setEventSink(Pipe.IPipeEvents) - Method in class zmq.pipe.Pipe
- setFd(SocketChannel) - Method in class zmq.Msg
- setFlags(int) - Method in class zmq.Msg.Builder
- setFlags(int) - Method in class zmq.Msg
- setGlobalHandler(ZPoller.EventsHandler) - Method in class org.zeromq.ZPoller
-
Sets the global events handler for all registered sockets.
- setGroup(String) - Method in class org.zeromq.ZFrame
-
Sets the group used for RADIO/DISH sockets.
- setGroup(String) - Method in class zmq.Msg
-
Set the group for RADIO/DISH sockets
- setHandshakeIvl(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HANDSHAKE_IVL option shall set the maximum handshake interval for the specified socket.
- setHandshakeTimer() - Method in class zmq.io.StreamEngine
- setHeartbeatContext(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_CONTEXT option shall set the ping context of the peer for ZMTP heartbeats.
- setHeartbeatIvl(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_IVL option shall set the interval between sending ZMTP heartbeats for the specified socket.
- setHeartbeatTimeout(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_TIMEOUT option shall set how long to wait before timing-out a connection after sending a PING ZMTP command and not receiving any traffic.
- setHeartbeatTtl(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_HEARTBEAT_TTL option shall set the timeout on the remote peer for ZMTP heartbeats.
- setHelloMsg(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
When set, the socket will automatically send a hello message when a new connection is made or accepted.
- setHWM(int) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_HWM' option shall set the high water mark for the specified 'socket'.
- setHWM(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setHWM(int)
instead - setHwms(int, int) - Method in class zmq.pipe.Pipe
- setIdentity(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_IDENTITY' option shall set the identity of the specified 'socket'.
- setIdentity(Blob) - Method in class zmq.pipe.Pipe
- setImmediate(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Accept messages immediately or only when connections are made
- setInterval(long) - Method in class org.zeromq.timer.ZTimer.Timer
-
Changes the interval of the timer.
- setInterval(long) - Method in class zmq.util.Timers.Timer
-
Changes the interval of the timer.
- setInterval(ZTimer.Timer, long) - Method in class org.zeromq.ZTimer
-
Deprecated.use
ZTimer.Timer.setInterval(long)
instead - setInterval(Timers.Timer, long) - Method in class zmq.util.Timers
-
Deprecated.use
Timers.Timer.setInterval(long)
instead - setIoThreads(int) - Method in class org.zeromq.ZContext
-
Deprecated.This value should not be changed after the context is initialized.
- setIOThreads(int) - Method in class org.zeromq.ZMQ.Context
-
Set the size of the 0MQ thread pool to handle I/O operations.
- setIpTypeOfService(Channel, int) - Static method in class zmq.io.net.tcp.TcpUtils
- setIPv4Only(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.use
ZMQ.Socket.setIPv6(boolean)
instead (inverted logic: ipv4 = true <==> ipv6 = false) - setIPv6(boolean) - Method in class org.zeromq.ZMQ.Context
- setIPv6(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Set the IPv6 option for the socket.
- setLinger(int) - Method in class org.zeromq.ZContext
- setLinger(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_LINGER option shall set the linger period for the specified socket.
- setLinger(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.the linger option has only integer range, use
ZMQ.Socket.setLinger(int)
instead - setListener(ZBeacon.Listener) - Method in class org.zeromq.ZBeacon
-
Deprecated.use the builder
- setMain(boolean) - Method in class org.zeromq.ZContext
-
Deprecated.This value should not be changed after the context is initialized.
- setMaxMsgSize(long) - Method in class org.zeromq.ZMQ.Socket
-
Limits the size of the inbound message.
- setMaxSockets(int) - Method in class org.zeromq.ZMQ.Context
-
Sets the maximum number of sockets allowed on the context
- setMessageGroup(Msg, String) - Method in class zmq.ZMQ
- setMessageRoutingId(Msg, int) - Method in class zmq.ZMQ
- setMeta(String, String) - Method in class org.zeromq.ZCert
- setMetadata(Metadata) - Method in class zmq.Msg
- setMsgAllocationHeapThreshold(int) - Method in class org.zeromq.ZMQ.Socket
-
Sets the limit threshold where messages of a given size will be allocated using Direct ByteBuffer.
- setMsgAllocator(MsgAllocator) - Method in class org.zeromq.ZMQ.Socket
-
Sets a custom message allocator.
- setMulticastHops(long) - Method in class org.zeromq.ZMQ.Socket
-
Sets the time-to-live field in every multicast packet sent from this socket.
- setMulticastLoop(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- setNoDelay() - Method in class zmq.pipe.Pipe
- setNotificationExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZContext
-
In
Poller.run()
, some non-fatal exceptions can be thrown. - setNotificationExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZMQ.Context
-
In
Poller.run()
, some non-fatal exceptions can be thrown. - setNotificationExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class zmq.Ctx
-
In
Poller.run()
, some non-fatal exceptions can be thrown. - setOption(int, Object) - Method in class org.zeromq.ZSocket
- setOption(Channel, TcpUtils.OptionSetter<Socket>) - Static method in class zmq.io.net.tcp.TcpUtils
-
A single setter method, used when the option doesn't apply to a
ServerSocket
- setOption(Channel, TcpUtils.OptionSetter<Socket>, TcpUtils.OptionSetter<ServerSocket>) - Static method in class zmq.io.net.tcp.TcpUtils
- setOption(S) - Method in interface zmq.io.net.tcp.TcpUtils.OptionSetter
- setOwner(Own) - Method in class zmq.Own
- setPeer(Pipe) - Method in class zmq.pipe.Pipe
- setPeerIdentity(byte[]) - Method in class zmq.io.mechanism.Mechanism
- setPlainPassword(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the password for outgoing connections over TCP or IPC.
- setPlainPassword(String) - Method in class org.zeromq.ZMQ.Socket
-
Sets the password for outgoing connections over TCP or IPC.
- setPlainServer(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Defines whether the socket will act as server for PLAIN security, see zmq_plain(7).
- setPlainUsername(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the username for outgoing connections over TCP or IPC.
- setPlainUsername(String) - Method in class org.zeromq.ZMQ.Socket
-
Sets the username for outgoing connections over TCP or IPC.
- setPollAccept(Poller.Handle) - Method in class zmq.io.IOObject
- setPollAccept(Poller.Handle) - Method in class zmq.poll.Poller
- setPollConnect(Poller.Handle) - Method in class zmq.io.IOObject
- setPollConnect(Poller.Handle) - Method in class zmq.poll.Poller
- setPollIn(Poller.Handle) - Method in class zmq.io.IOObject
- setPollIn(Poller.Handle) - Method in class zmq.poll.Poller
- setPollOut(Poller.Handle) - Method in class zmq.io.IOObject
- setPollOut(Poller.Handle) - Method in class zmq.poll.Poller
- setPrefix(byte[]) - Method in class org.zeromq.ZBeacon
-
Deprecated.use the builder
- setProbeRouter(boolean) - Method in class org.zeromq.ZMQ.Socket
-
When set to true, the socket will automatically send an empty message when a new connection is made or accepted.
- setRate(long) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_RATE' option shall set the maximum send or receive data rate for multicast transports such as in the man page of zmq_pgm[7] using the specified 'socket'.
- setRcvHWM(int) - Method in class org.zeromq.ZContext
-
Set initial receive HWM for all new normal sockets created in context.
- setRcvHWM(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RCVHWM option shall set the high water mark for inbound messages on the specified socket.
- setRcvHWM(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setRcvHWM(int)
instead - setReceiveBufferSize(int) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_RCVBUF' option shall set the underlying kernel receive buffer size for the 'socket' to the specified size in bytes.
- setReceiveBufferSize(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setReceiveBufferSize(int)
instead - setReceiveTimeOut(int) - Method in class org.zeromq.ZMQ.Socket
-
Sets the timeout for receive operation on the socket.
- setReconnectIVL(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RECONNECT_IVL option shall set the initial reconnection interval for the specified socket.
- setReconnectIVL(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.reconnect interval option uses integer range, use
ZMQ.Socket.setReconnectIVL(int)
instead - setReconnectIVLMax(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_RECONNECT_IVL_MAX option shall set the maximum reconnection interval for the specified socket.
- setReconnectIVLMax(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setReconnectIVLMax(int)
instead - setRecoveryInterval(long) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_RECOVERY_IVL' option shall set the recovery interval for multicast transports using the specified 'socket'.
- setReqCorrelate(boolean) - Method in class org.zeromq.ZMQ.Socket
-
The default behavior of REQ sockets is to rely on the ordering of messages to match requests and responses and that is usually sufficient.
- setReqRelaxed(boolean) - Method in class org.zeromq.ZMQ.Socket
-
By default, a REQ socket does not allow initiating a new request with zmq_send(3) until the reply to the previous one has been received.
- setReuseAddress(Channel, boolean) - Static method in class zmq.io.net.tcp.TcpUtils
- setRouterHandover(boolean) - Method in class org.zeromq.ZMQ.Socket
-
If two clients use the same identity when connecting to a ROUTER, the results shall depend on the ZMQ_ROUTER_HANDOVER option setting.
- setRouterMandatory(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Sets the ROUTER socket behavior when an unroutable message is encountered.
- setRouterRaw(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Sets the raw mode on the ROUTER, when set to true.
- setRoutingId(int) - Method in class org.zeromq.ZFrame
-
Set routing ID on frame.
- setRoutingId(int) - Method in class zmq.Msg
-
Set the routing id on a message.
- setRoutingId(int) - Method in class zmq.pipe.Pipe
- setSelectorChooser(SelectorProviderChooser) - Method in class org.zeromq.ZMQ.Socket
-
Set a custom
SelectorProvider
chooser. - setSendBufferSize(int) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_SNDBUF' option shall set the underlying kernel transmit buffer size for the 'socket' to the specified size in bytes.
- setSendBufferSize(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setSendBufferSize(int)
instead - setSendTimeOut(int) - Method in class org.zeromq.ZMQ.Socket
-
Sets the timeout for send operation on the socket.
- setServerUncaughtExceptionHandlers(Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZBeacon.Builder
- setSndHWM(int) - Method in class org.zeromq.ZContext
-
Set initial receive HWM for all new normal sockets created in context.
- setSndHWM(int) - Method in class org.zeromq.ZMQ.Socket
-
The ZMQ_SNDHWM option shall set the high water mark for outbound messages on the specified socket.
- setSndHWM(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.this option uses integer range, use
ZMQ.Socket.setSndHWM(int)
instead - setSocketOpt(int, Object) - Method in class org.zeromq.ZMQ.Socket
- setSocketOpt(int, Object) - Method in class zmq.Options
- setSocketOpt(int, Object) - Method in class zmq.SocketBase
- setSocketOption(SocketBase, int, Object) - Static method in class zmq.ZMQ
- setSocksProxy(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the SOCKS5 proxy address that shall be used by the socket for the TCP connection(s).
- setSocksProxy(String) - Method in class org.zeromq.ZMQ.Socket
-
Sets the SOCKS5 proxy address that shall be used by the socket for the TCP connection(s).
- setSwap(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- setTCPKeepAlive(int) - Method in class org.zeromq.ZMQ.Socket
-
Override SO_KEEPALIVE socket option (where supported by OS) to enable keep-alive packets for a socket connection.
- setTCPKeepAlive(long) - Method in class org.zeromq.ZMQ.Socket
-
Deprecated.
- setTCPKeepAliveCount(long) - Method in class org.zeromq.ZMQ.Socket
-
Override TCP_KEEPCNT socket option (where supported by OS).
- setTCPKeepAliveIdle(long) - Method in class org.zeromq.ZMQ.Socket
-
Override TCP_KEEPCNT (or TCP_KEEPALIVE on some OS) socket option (where supported by OS).
- setTCPKeepAliveInterval(long) - Method in class org.zeromq.ZMQ.Socket
-
Override TCP_KEEPINTVL socket option (where supported by OS).
- setTcpReceiveBuffer(Channel, int) - Static method in class zmq.io.net.tcp.TcpUtils
- setTcpSendBuffer(Channel, int) - Static method in class zmq.io.net.tcp.TcpUtils
- setTid(int) - Method in class zmq.ZObject
- setTimeout(long) - Method in class org.zeromq.ZMQ.Poller
-
Deprecated.Timeout handling has been moved to the poll() methods.
- setTos(int) - Method in class org.zeromq.ZMQ.Socket
-
Sets the ToS fields (Differentiated services (DS) and Explicit Congestion Notification (ECN) field of the IP header.
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZContext
-
Set the handler invoked when a
Poller
abruptly terminates due to an uncaught exception. - setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZMQ.Context
-
Set the handler invoked when a
Poller
abruptly terminates due to an uncaught exception. - setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class zmq.Ctx
-
Set the handler invoked when a
Poller
abruptly terminates due to an uncaught exception. - setUncaughtExceptionHandlers(Thread.UncaughtExceptionHandler, Thread.UncaughtExceptionHandler) - Method in class org.zeromq.ZBeacon
-
Deprecated.use the builder
- setUserId(byte[]) - Method in class zmq.io.mechanism.Mechanism
- setVerbose(boolean) - Method in class org.zeromq.ZAuth
-
Enable verbose tracing of commands and activity
- setWriteIndex(int) - Method in class zmq.Msg
- setXpubManual(boolean) - Method in class org.zeromq.ZMQ.Socket
- setXpubNoDrop(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Sets the XPUB socket behaviour to return error EAGAIN if SENDHWM is reached and the message could not be send.
- setXpubVerbose(boolean) - Method in class org.zeromq.ZMQ.Socket
-
Sets the XPUB socket behavior on new subscriptions and unsubscriptions.
- setXpubVerboser(boolean) - Method in class org.zeromq.ZMQ.Socket
- setZapDomain(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the domain for ZAP (ZMQ RFC 27) authentication.
- setZapDomain(String) - Method in class org.zeromq.ZMQ.Socket
-
Sets the domain for ZAP (ZMQ RFC 27) authentication.
- setZAPDomain(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
Sets the domain for ZAP (ZMQ RFC 27) authentication.
- setZAPDomain(String) - Method in class org.zeromq.ZMQ.Socket
-
Sets the domain for ZAP (ZMQ RFC 27) authentication.
- sha1 - Variable in class org.zeromq.util.ZDigest
- shadow - Variable in class org.zeromq.ZActor.Duo
- shadow() - Method in class org.zeromq.ZContext
-
Creates new shadow context.
- shadow(ZContext) - Static method in class org.zeromq.ZContext
-
Deprecated.use the instance method directly
- shadows - Variable in class org.zeromq.ZContext
-
List of ZContext in the shadows
- SHARED - Static variable in class zmq.Msg
- ShimThread(ZContext, ZThread.IAttachedRunnable, Object[], ZMQ.Socket) - Constructor for class org.zeromq.ZThread.ShimThread
- ShimThread(ZThread.IDetachedRunnable, Object[]) - Constructor for class org.zeromq.ZThread.ShimThread
- showMustGoOn(ZContext, ZStar.Set, ZMQ.Socket, ZStar.Fortune, Object...) - Method in class org.zeromq.ZStar.Plateau
- shows - Static variable in class org.zeromq.ZStar.Plateau
- shutdown() - Method in class zmq.Ctx
- Side() - Constructor for enum zmq.Ctx.Side
- sign() - Method in interface org.zeromq.ZAgent
-
Gives a sign if the distant Star is here.
- sign() - Method in class org.zeromq.ZAgent.SimpleAgent
- sign() - Method in class org.zeromq.ZStar
- signaler - Variable in class zmq.Mailbox
- Signaler - Class in zmq
- Signaler(Ctx, int, Errno) - Constructor for class zmq.Signaler
- SIGNALER_PORT - Enum constant in enum zmq.Config
- Signaler.IoOperation<O> - Interface in zmq
- signalers - Variable in class zmq.MailboxSafe
- SIGNATURE_SIZE - Static variable in class zmq.io.StreamEngine
- SimpleActor() - Constructor for class org.zeromq.ZActor.SimpleActor
- SimpleAgent(ZMQ.Socket, String) - Constructor for class org.zeromq.ZAgent.SimpleAgent
-
Creates a new simple agent.
- SimpleCreator() - Constructor for class org.zeromq.ZPoller.SimpleCreator
- SimpleCurveAuth() - Constructor for class org.zeromq.ZAuth.SimpleCurveAuth
- SimpleCurveAuth(ZCertStore.Fingerprinter) - Constructor for class org.zeromq.ZAuth.SimpleCurveAuth
- SimpleNullAuth() - Constructor for class org.zeromq.ZAuth.SimpleNullAuth
- SimplePlainAuth() - Constructor for class org.zeromq.ZAuth.SimplePlainAuth
- SimpleProxy() - Constructor for class org.zeromq.ZProxy.Proxy.SimpleProxy
- SimpleSet() - Constructor for class org.zeromq.ZStar.SimpleSet
- SimpleURI(String, String) - Constructor for class zmq.SocketBase.SimpleURI
- sink - Variable in class zmq.pipe.Pipe
- sink - Variable in class zmq.poll.PollerBase.TimerInfo
- size - Variable in class zmq.Msg
- size - Variable in class zmq.pipe.YQueue
- size() - Method in class org.zeromq.util.ZDigest
- size() - Method in class org.zeromq.ZFrame
-
Returns byte size of frame, if set, else 0
- size() - Method in class org.zeromq.ZMsg
- size() - Method in class zmq.io.Metadata
- size() - Method in class zmq.Msg.Builder
- size() - Method in class zmq.Msg
- size() - Method in class zmq.util.Blob
- Size() - Constructor for enum zmq.io.mechanism.curve.Curve.Size
- SIZE_DEFAULT - Static variable in class org.zeromq.ZMQ.Poller
- SIZE_INCREMENT - Static variable in class org.zeromq.ZMQ.Poller
- sizeReady - Variable in class zmq.io.coder.Encoder
- sizeReady() - Method in class zmq.io.coder.Encoder
- sizeReady() - Method in class zmq.io.coder.raw.RawEncoder
- sizeReady() - Method in class zmq.io.coder.v1.V1Encoder
- sizeReady() - Method in class zmq.io.coder.v2.V2Encoder
- sizeReady(long) - Method in class zmq.io.coder.Decoder
- sleep(long) - Static method in class org.zeromq.ZMQ
- sleep(long) - Static method in class zmq.ZMQ
- sleep(long, TimeUnit) - Static method in class org.zeromq.ZMQ
- sleep(long, TimeUnit) - Static method in class zmq.ZMQ
- sleepAndExecute() - Method in class org.zeromq.timer.ZTimer
-
Sleeps until at least one timer can be executed and execute the timers.
- sleepAndExecute() - Method in class org.zeromq.ZTimer
-
Deprecated.Sleeps until at least one timer can be executed and execute the timers.
- sleepAndExecute() - Method in class zmq.util.Timers
- slotCount - Variable in class zmq.Ctx
- slots - Variable in class zmq.Ctx
- slotSync - Variable in class zmq.Ctx
- sndbuf - Variable in class zmq.Options
- sndhwm - Variable in class org.zeromq.ZContext
-
ZMQ_SNDHWM for normal sockets
- SNDMORE - Static variable in class org.zeromq.ZMQ
-
Socket flag to indicate that more message parts are coming.
- socket - Variable in class org.zeromq.ZMQ.CancellationToken
- socket - Variable in class org.zeromq.ZMQ.PollItem
- socket - Variable in class org.zeromq.ZPoller.CompositePollItem
- socket - Variable in class zmq.Ctx.Endpoint
- socket - Variable in class zmq.io.net.Listener
- socket - Variable in class zmq.io.net.tcp.TcpConnecter
- socket - Variable in class zmq.io.SessionBase
- socket - Variable in class zmq.io.StreamEngine
- socket - Variable in class zmq.poll.PollItem
- socket() - Method in class org.zeromq.ZPoller.CompositePollItem
- socket() - Method in interface org.zeromq.ZPoller.ItemHolder
- socket() - Method in class org.zeromq.ZPoller.ZPollItem
- socket(int) - Method in class org.zeromq.ZMQ.Context
-
Deprecated.
- socket(SocketType) - Method in class org.zeromq.ZMQ.Context
-
Creates a ØMQ socket within the specified context and return an opaque handle to the newly created socket.
- socket(Ctx, int) - Static method in class zmq.ZMQ
- Socket(ZContext, SocketType) - Constructor for class org.zeromq.ZMQ.Socket
-
Class constructor.
- Socket(ZMQ.Context, int) - Constructor for class org.zeromq.ZMQ.Socket
-
Deprecated.
- Socket(ZMQ.Context, SocketType) - Constructor for class org.zeromq.ZMQ.Socket
-
Class constructor.
- Socket(ZMQ.Context, ZContext, int) - Constructor for class org.zeromq.ZMQ.Socket
- Socket(SocketBase) - Constructor for class org.zeromq.ZMQ.Socket
- SOCKET_TYPE - Static variable in class zmq.io.Metadata
- socketBase - Variable in class org.zeromq.ZSocket
- SocketBase - Class in zmq
- SocketBase(Ctx, int, int) - Constructor for class zmq.SocketBase
- SocketBase(Ctx, int, int, boolean) - Constructor for class zmq.SocketBase
- SocketBase.EndpointPipe - Class in zmq
- SocketBase.SimpleURI - Class in zmq
- socketId - Variable in class zmq.Options
- sockets - Variable in class org.zeromq.ManagedContext
- sockets - Variable in class org.zeromq.ZActor.Double
- sockets - Variable in class org.zeromq.ZContext
-
List of sockets managed by this ZContext
- sockets - Variable in class org.zeromq.ZPoller.ComposeEventsHandler
- sockets - Variable in class zmq.Ctx
- Sockets - Search tag in class org.zeromq.ZMQ
- Section
- Sockets - Enum in zmq.socket
- Sockets(String...) - Constructor for enum zmq.socket.Sockets
- socketsReaping - Variable in class zmq.Reaper
- socketType() - Method in class zmq.io.mechanism.Mechanism
- SocketType - Enum in org.zeromq
-
Socket Type enumeration
- SocketType(int) - Constructor for enum org.zeromq.SocketType
- SocksConnecter - Class in zmq.io.net.tcp
- SocksConnecter(IOThread, SessionBase, Options, Address, Address, boolean) - Constructor for class zmq.io.net.tcp.SocksConnecter
- SocksConnecter.Status - Enum in zmq.io.net.tcp
- socksProxyAddress - Variable in class zmq.Options
- sort - Variable in class org.zeromq.timer.ZTicket
- sortIfNeeded() - Method in class org.zeromq.timer.ZTicket
- sourceAddress - Variable in class zmq.io.net.ipc.IpcAddress
- sourceAddress - Variable in class zmq.io.net.tcp.TcpAddress
- sourceAddress() - Method in interface zmq.io.net.Address.IZAddress
- sourceAddress() - Method in class zmq.io.net.ipc.IpcAddress
- sourceAddress() - Method in class zmq.io.net.tcp.TcpAddress
- spareChunk - Variable in class zmq.pipe.YQueue
- SPoller(ZMQ.PollItem, ZLoop.IZLoopHandler, Object) - Constructor for class org.zeromq.ZLoop.SPoller
- stage(ZMQ.Socket, ZMQ.Socket, ZPoller, int) - Method in interface org.zeromq.ZActor.Actor
-
The actor received a message from the created sockets during a loop.
- stage(ZMQ.Socket, ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZActor.Duo
- stage(ZMQ.Socket, ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZActor.SimpleActor
- stage(ZMQ.Socket, ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZAuth.AuthActor
- stage(ZMQ.Socket, ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZMonitor.MonitorActor
- stage(ZMQ.Socket, ZMQ.Socket, ZPoller, int) - Method in class org.zeromq.ZProxy.ProxyActor
- StandardProtocolFamily - Enum in zmq.io.net
-
Replacement of StandardProtocolFamily from SDK so it can be used in Android environments.
- StandardProtocolFamily() - Constructor for enum zmq.io.net.StandardProtocolFamily
- start - Variable in class org.zeromq.timer.ZTicket.Ticket
- start() - Method in class org.zeromq.ZBeacon
- start() - Method in class org.zeromq.ZLoop
- start() - Method in class org.zeromq.ZMonitor
-
Starts the monitoring.
- start() - Method in class zmq.io.IOThread
- start() - Method in class zmq.poll.Poller
- start() - Method in class zmq.Reaper
- start(boolean) - Method in class org.zeromq.ZProxy
-
Starts the proxy.
- start(ZMQ.Socket, List<ZMQ.Socket>, ZPoller) - Method in interface org.zeromq.ZActor.Actor
-
Called when the double is started, before the first loop.
- start(ZMQ.Socket, List<ZMQ.Socket>, ZPoller) - Method in class org.zeromq.ZActor.Duo
- start(ZMQ.Socket, List<ZMQ.Socket>, ZPoller) - Method in class org.zeromq.ZActor.SimpleActor
- start(ZMQ.Socket, List<ZMQ.Socket>, ZPoller) - Method in class org.zeromq.ZAuth.AuthActor
- start(ZMQ.Socket, List<ZMQ.Socket>, ZPoller) - Method in class org.zeromq.ZMonitor.MonitorActor
- start(ZMQ.Socket, List<ZMQ.Socket>, ZPoller) - Method in class org.zeromq.ZProxy.ProxyActor
- start(ZPoller) - Method in class org.zeromq.ZProxy.ProxyActor
- start(ZPoller, ZMQ.Socket) - Method in class org.zeromq.ZMonitor.MonitorActor
- start(ZThread.IDetachedRunnable, Object...) - Static method in class org.zeromq.ZThread
- start(SocketBase, SocketBase, SocketBase, SocketBase) - Method in class zmq.Proxy
- START - Enum constant in enum org.zeromq.ZProxy.Command
- START - Static variable in class org.zeromq.ZMonitor
- START - Static variable in class org.zeromq.ZProxy
- startClient() - Method in class org.zeromq.ZBeacon
- startConnecting() - Method in class zmq.io.net.tcp.TcpConnecter
- startConnecting(boolean) - Method in class zmq.io.SessionBase
- started - Variable in class org.zeromq.ZMonitor
- started - Variable in class org.zeromq.ZProxy.ProxyActor.State
- started() - Method in class org.zeromq.ZProxy
-
Binary inquiry for the status of the proxy.
- STARTED - Enum constant in enum org.zeromq.ZProxy.State
- STARTED - Static variable in class org.zeromq.ZProxy
- starting - Variable in class zmq.Ctx
- startReaping(Poller) - Method in class zmq.SocketBase
- startServer() - Method in class org.zeromq.ZBeacon
- startStopwatch() - Static method in class zmq.ZMQ
- startsWith(Msg, String, boolean) - Static method in class zmq.io.Msgs
-
Checks if the message starts with the given string.
- startTimer() - Method in class zmq.io.net.tcp.SocksConnecter
- state - Variable in class org.zeromq.ZProxy.ProxyActor
- state - Variable in class zmq.io.mechanism.curve.CurveClientMechanism
- state - Variable in class zmq.io.mechanism.curve.CurveServerMechanism
- state - Variable in class zmq.io.mechanism.plain.PlainClientMechanism
- state - Variable in class zmq.io.mechanism.plain.PlainServerMechanism
- state - Variable in class zmq.pipe.Pipe
- state - Variable in class zmq.Proxy
- state - Variable in class zmq.socket.radiodish.Dish.DishSession
- state - Variable in class zmq.socket.radiodish.Radio.RadioSession
- state - Variable in class zmq.socket.reqrep.Req.ReqSession
- State() - Constructor for class org.zeromq.ZProxy.ProxyActor.State
- State() - Constructor for enum org.zeromq.ZProxy.State
- State() - Constructor for enum zmq.io.mechanism.curve.CurveClientMechanism.State
- State() - Constructor for enum zmq.io.mechanism.curve.CurveServerMechanism.State
- State() - Constructor for enum zmq.io.mechanism.plain.PlainClientMechanism.State
- State() - Constructor for enum zmq.io.mechanism.plain.PlainServerMechanism.State
- State() - Constructor for enum zmq.pipe.Pipe.State
- State() - Constructor for enum zmq.Proxy.State
- State() - Constructor for enum zmq.socket.radiodish.Dish.DishSession.State
- State() - Constructor for enum zmq.socket.radiodish.Radio.RadioSession.State
- State() - Constructor for enum zmq.socket.reqrep.Req.ReqSession.State
- status - Variable in class zmq.io.net.tcp.SocksConnecter
- status() - Method in class org.zeromq.ZProxy.ProxyActor
- status() - Method in class org.zeromq.ZProxy
-
Inquires for the status of the proxy.
- status() - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- status() - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- status() - Method in class zmq.io.mechanism.gssapi.GssapiClientMechanism
- status() - Method in class zmq.io.mechanism.gssapi.GssapiServerMechanism
- status() - Method in class zmq.io.mechanism.Mechanism
- status() - Method in class zmq.io.mechanism.NullMechanism
- status() - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- status() - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- status(boolean) - Method in class org.zeromq.ZProxy
-
Inquires for the status of the proxy.
- Status() - Constructor for enum zmq.io.mechanism.Mechanism.Status
- Status() - Constructor for enum zmq.io.net.tcp.SocksConnecter.Status
- STATUS - Enum constant in enum org.zeromq.ZProxy.Command
- STATUS - Static variable in class org.zeromq.ZProxy
- statusCode - Variable in class org.zeromq.ZAuth.ZapReply
- statusCode - Variable in class zmq.io.mechanism.Mechanism
- statusText - Variable in class org.zeromq.ZAuth.ZapReply
- STimer(int, int, ZLoop.IZLoopHandler, Object) - Constructor for class org.zeromq.ZLoop.STimer
- stop() - Method in class org.zeromq.ZBeacon
- stop() - Method in class org.zeromq.ZProxy.ProxyActor
- stop() - Method in class zmq.io.IOThread
- stop() - Method in class zmq.poll.Poller
- stop() - Method in class zmq.Reaper
- stop() - Method in class zmq.SocketBase
- stop(boolean) - Method in class org.zeromq.ZProxy
-
Stops the proxy.
- STOP - Enum constant in enum org.zeromq.ZProxy.Command
- STOP - Enum constant in enum zmq.Command.Type
- STOP - Static variable in class org.zeromq.ZProxy
- stopMonitor() - Method in class zmq.SocketBase
- stopped - Variable in class zmq.poll.Poller
- STOPPED - Enum constant in enum org.zeromq.ZProxy.State
- STOPPED - Static variable in class org.zeromq.ZProxy
- stopping - Variable in class zmq.poll.Poller
- stopStopwatch(long) - Static method in class zmq.ZMQ
- stream(File) - Method in class org.zeromq.ZCertStore.Hasher
- Stream - Class in zmq.socket
- Stream(Ctx, int, int) - Constructor for class zmq.socket.Stream
- STREAM - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a STREAM socket.
- STREAM - Enum constant in enum zmq.socket.Sockets
- STREAM - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- Stream.Outpipe - Class in zmq.socket
- StreamEngine - Class in zmq.io
- StreamEngine(SocketChannel, Options, String) - Constructor for class zmq.io.StreamEngine
- StreamEngine.ErrorReason - Enum in zmq.io
- StreamEngine.ProducePongMessage - Class in zmq.io
- StreamEngine.Protocol - Enum in zmq.io
- STREAMER - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- streq(byte[], String) - Static method in class org.zeromq.util.ZData
-
String equals.
- streq(String) - Method in class org.zeromq.util.ZData
-
String equals.
- streq(String) - Method in class org.zeromq.ZFrame
-
String equals.
- strerror(int) - Static method in class zmq.ZMQ
- strhex() - Method in class org.zeromq.util.ZData
- strhex() - Method in class org.zeromq.ZFrame
- strhex(byte[]) - Static method in class org.zeromq.util.ZData
- strict - Variable in class zmq.socket.reqrep.Req
- string() - Method in class org.zeromq.util.ZDigest
- Sub - Class in zmq.socket.pubsub
- Sub(Ctx, int, int) - Constructor for class zmq.socket.pubsub.Sub
- SUB - Enum constant in enum org.zeromq.SocketType
-
Flag to specify the receiving part of the PUB or XPUB socket.
- SUB - Enum constant in enum zmq.socket.Sockets
- SUB - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- subscribe(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_SUBSCRIBE' option shall establish a new message filter on a 'ZMQ_SUB' socket.
- subscribe(byte[]) - Method in class org.zeromq.ZSocket
- subscribe(String) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_SUBSCRIBE' option shall establish a new message filter on a 'ZMQ_SUB' socket.
- subscribe(String) - Method in class org.zeromq.ZSocket
- subscribe2all - Variable in enum zmq.io.net.NetProtocol
- SUBSCRIPTION_ALL - Static variable in class org.zeromq.ZMQ
- SUBSCRIPTION_ALL - Static variable in class zmq.ZMQ
- subscriptionRequired - Variable in class zmq.io.StreamEngine
- subscriptions - Variable in class zmq.socket.pubsub.XPub
- subscriptions - Variable in class zmq.socket.pubsub.XSub
- subscriptions - Variable in class zmq.socket.radiodish.Dish
- subscriptions - Variable in class zmq.socket.radiodish.Radio
- Supplier<T> - Interface in zmq.util.function
-
Represents a supplier of results.
- sync - Variable in class zmq.Mailbox
- sync - Variable in class zmq.MailboxSafe
- sync - Variable in class zmq.pipe.DBuffer
T
- tcp - Enum constant in enum zmq.io.net.NetProtocol
- tcpAcceptFilters - Variable in class zmq.Options
- TcpAddress - Class in zmq.io.net.tcp
- TcpAddress(String, boolean) - Constructor for class zmq.io.net.tcp.TcpAddress
- TcpAddress(InetSocketAddress) - Constructor for class zmq.io.net.tcp.TcpAddress
- TcpAddress.TcpAddressMask - Class in zmq.io.net.tcp
- TcpAddressMask(String, boolean) - Constructor for class zmq.io.net.tcp.TcpAddress.TcpAddressMask
- TcpConnecter - Class in zmq.io.net.tcp
- TcpConnecter(IOThread, SessionBase, Options, Address, boolean) - Constructor for class zmq.io.net.tcp.TcpConnecter
- tcpKeepAlive - Variable in class zmq.Options
- tcpKeepAliveCnt - Variable in class zmq.Options
- tcpKeepAliveIdle - Variable in class zmq.Options
- tcpKeepAliveIntvl - Variable in class zmq.Options
- TcpListener - Class in zmq.io.net.tcp
- TcpListener(IOThread, SocketBase, Options) - Constructor for class zmq.io.net.tcp.TcpListener
- TcpUtils - Class in zmq.io.net.tcp
- TcpUtils() - Constructor for class zmq.io.net.tcp.TcpUtils
- TcpUtils.OptionSetter<S> - Interface in zmq.io.net.tcp
- term() - Method in class org.zeromq.ZMQ.Context
-
This is an explicit "destructor".
- term(Ctx) - Static method in class zmq.ZMQ
- TERM - Enum constant in enum zmq.Command.Type
- TERM_ACK - Enum constant in enum zmq.Command.Type
- TERM_ACK_SENT - Enum constant in enum zmq.pipe.Pipe.State
- TERM_REQ - Enum constant in enum zmq.Command.Type
- TERM_REQ_SENT_1 - Enum constant in enum zmq.pipe.Pipe.State
- TERM_REQ_SENT_2 - Enum constant in enum zmq.pipe.Pipe.State
- TERM_TID - Static variable in class zmq.Ctx
- termAcks - Variable in class zmq.Own
- termChild(Own) - Method in class zmq.Own
- termEndpoint(String) - Method in class zmq.SocketBase
- terminate() - Method in class zmq.Ctx
- terminate() - Method in class zmq.io.EngineNotImplemented
- terminate() - Method in interface zmq.io.IEngine
- terminate() - Method in class zmq.io.StreamEngine
- terminate() - Method in class zmq.Own
- terminate(boolean) - Method in class zmq.pipe.Pipe
- TERMINATE - Static variable in class org.zeromq.ZAuth
- terminated(Pipe) - Method in class zmq.socket.FQ
- terminated(Pipe) - Method in class zmq.socket.LB
- terminated(Pipe) - Method in class zmq.socket.pubsub.Dist
- TERMINATED - Enum constant in enum zmq.Proxy.State
- terminating - Variable in class zmq.Ctx
- terminating - Variable in class zmq.Own
- terminating - Variable in class zmq.Reaper
- terminatingPipes - Variable in class zmq.io.SessionBase
- termMailbox - Variable in class zmq.Ctx
- Test key values - Search tag in class org.zeromq.ZMQ.Curve
- Section
- thread - Variable in class org.zeromq.ZBeacon.BroadcastClient
- thread - Variable in class org.zeromq.ZBeacon.BroadcastServer
- threadSafe - Variable in class zmq.SocketBase
- threadSafeSync - Variable in class zmq.SocketBase
- Thread safety - Search tag in class org.zeromq.ZMQ
- Section
- Thread safety - Search tag in class org.zeromq.ZMQ.Socket
- Section
- threshold - Variable in class zmq.msg.MsgAllocatorThreshold
- ticket - Variable in class org.zeromq.timer.ZTicker
- Ticket(ZTicket, long, long, TimerHandler, Object...) - Constructor for class org.zeromq.timer.ZTicket.Ticket
- tickets - Variable in class org.zeromq.timer.ZTicket
- ticklessTimer() - Method in class org.zeromq.ZLoop
- ticks - Variable in class zmq.SocketBase
- tid - Variable in class zmq.ZObject
- time(Object...) - Method in interface org.zeromq.timer.TimerHandler
- time(Object...) - Method in interface zmq.util.Timers.Handler
- timeout - Variable in class org.zeromq.ZMQ.Poller
- timeout() - Method in class org.zeromq.timer.ZTicker
- timeout() - Method in class org.zeromq.timer.ZTicket
-
Returns the time in millisecond until the next ticket.
- timeout() - Method in class org.zeromq.timer.ZTimer
-
Returns the time in millisecond until the next timer.
- timeout() - Method in class org.zeromq.ZTimer
-
Deprecated.Returns the time in millisecond until the next timer.
- timeout() - Method in class zmq.util.Timers
-
Returns the time in millisecond until the next timer.
- TIMEOUT - Enum constant in enum zmq.io.StreamEngine.ErrorReason
- timer - Variable in class org.zeromq.timer.ZTicker
- timer - Variable in class org.zeromq.timer.ZTimer
- timer - Variable in class org.zeromq.ZTimer
-
Deprecated.
- Timer(ZTimer.Timer) - Constructor for class org.zeromq.ZTimer.Timer
-
Deprecated.
- Timer(Timers.Timer) - Constructor for class org.zeromq.timer.ZTimer.Timer
- Timer(Timers, long, Timers.Handler, Object...) - Constructor for class zmq.util.Timers.Timer
- timerEvent(int) - Method in class zmq.io.IOObject
- timerEvent(int) - Method in class zmq.io.net.tcp.SocksConnecter
- timerEvent(int) - Method in class zmq.io.net.tcp.TcpConnecter
- timerEvent(int) - Method in class zmq.io.SessionBase
- timerEvent(int) - Method in class zmq.io.StreamEngine
- timerEvent(int) - Method in interface zmq.poll.IPollEvents
-
Called when timer expires.
- TimerHandler - Interface in org.zeromq.timer
-
Called when the time has come to perform some action.
- TimerInfo(IPollEvents, int) - Constructor for class zmq.poll.PollerBase.TimerInfo
- timers - Variable in class org.zeromq.ZLoop
- timers - Variable in class zmq.poll.PollerBase
- timers - Variable in class zmq.util.Timers
- Timers - Class in zmq.util
-
Manages set of timers.
- Timers() - Constructor for class zmq.util.Timers
- Timers(Supplier<Long>) - Constructor for class zmq.util.Timers
-
Builds a new timer.
- Timers.Handler - Interface in zmq.util
- Timers.Timer - Class in zmq.util
- timerStarted - Variable in class zmq.io.net.tcp.TcpConnecter
- times - Variable in class org.zeromq.ZLoop.STimer
- Timestamper() - Constructor for class org.zeromq.ZCertStore.Timestamper
- tipc - Enum constant in enum zmq.io.net.NetProtocol
- TipcConnecter - Class in zmq.io.net.tipc
- TipcConnecter(IOThread, SessionBase, Options, Address, boolean) - Constructor for class zmq.io.net.tipc.TipcConnecter
- TipcListener - Class in zmq.io.net.tipc
- TipcListener(IOThread, SocketBase, Options) - Constructor for class zmq.io.net.tipc.TipcListener
- tmpbuf - Variable in class zmq.io.coder.v1.V1Decoder
- tmpbuf - Variable in class zmq.io.coder.v2.V2Decoder
- tmpbufWrap - Variable in class zmq.io.coder.v1.V1Encoder
- tmpbufWrap - Variable in class zmq.io.coder.v2.V2Encoder
- toArray() - Method in class org.zeromq.ZMsg
- toArray(T[]) - Method in class org.zeromq.ZMsg
- toRead - Variable in class zmq.io.coder.DecoderBase
- tos - Variable in class zmq.Options
- toString() - Method in class org.zeromq.proto.ZNeedle
- toString() - Method in class org.zeromq.util.ZData
-
Returns a human - readable representation of data
- toString() - Method in class org.zeromq.util.ZMetadata
- toString() - Method in class org.zeromq.ZAuth.ZapReply
- toString() - Method in class org.zeromq.ZFrame
-
Returns a human - readable representation of frame's data
- toString() - Method in class org.zeromq.ZMonitor.ZEvent
- toString() - Method in class org.zeromq.ZMQ.Socket
- toString() - Method in exception class org.zeromq.ZMQException
- toString() - Method in class org.zeromq.ZMsg
-
Returns pretty string representation of multipart message: [ frame0, frame1, ..., frameN ]
- toString() - Method in class org.zeromq.ZProxy.ProxyActor.State
- toString() - Method in class zmq.Command
- toString() - Method in interface zmq.io.coder.v1.V1Protocol
- toString() - Method in interface zmq.io.coder.v2.V2Protocol
- toString() - Method in class zmq.io.IOObject
- toString() - Method in class zmq.io.Metadata
- toString() - Method in class zmq.io.net.Address
- toString() - Method in class zmq.io.net.ipc.IpcAddress
- toString() - Method in class zmq.io.net.tcp.TcpAddress
- toString() - Method in class zmq.io.net.tcp.TcpConnecter
- toString() - Method in class zmq.io.net.tcp.TcpListener
- toString() - Method in class zmq.io.SessionBase
- toString() - Method in class zmq.io.StreamEngine
- toString() - Method in class zmq.Mailbox
- toString() - Method in class zmq.MailboxSafe
- toString() - Method in class zmq.Msg
- toString() - Method in class zmq.pipe.Pipe
- toString() - Method in class zmq.poll.Poller.Handle
- toString() - Method in class zmq.poll.PollerBase.TimerInfo
- toString() - Method in class zmq.Signaler
- toString() - Method in class zmq.SocketBase.EndpointPipe
- toString() - Method in class zmq.SocketBase
- toString() - Method in class zmq.util.Errno
- toString() - Method in class zmq.util.MultiMap
- toString() - Method in class zmq.util.ValueReference
- toString(byte[]) - Static method in class org.zeromq.util.ZData
- toString(int) - Method in interface zmq.io.net.Address.IZAddress
- toString(int) - Method in class zmq.io.net.ipc.IpcAddress
- toString(int) - Method in class zmq.io.net.tcp.TcpAddress
- toString(int) - Static method in class zmq.ZError
- toWrite - Variable in class zmq.io.coder.EncoderBase
- transfer(ByteBuffer, int, int) - Method in class zmq.Msg
- transform(ZMsg, ZProxy.Plug, ZProxy.Plug) - Method in class org.zeromq.ZProxy.ZPump.Identity
- transform(ZMsg, ZProxy.Plug, ZProxy.Plug) - Method in interface org.zeromq.ZProxy.ZPump.Transformer
-
Transforms a ZMsg into another ZMsg.
- transformer - Variable in class org.zeromq.ZProxy.ZPump
- transport - Variable in class org.zeromq.ZProxy.ProxyActor
- Transports - Search tag in class org.zeromq.ZMQ
- Section
- traverseDirectory(File, ZCertStore.IFileVisitor) - Method in class org.zeromq.ZCertStore
- Trie - Class in zmq.socket.pubsub
- Trie() - Constructor for class zmq.socket.pubsub.Trie
- Trie.ITrieHandler - Interface in zmq.socket.pubsub
- tuneTcpKeepalives(SocketChannel, int, int, int, int) - Static method in class zmq.io.net.tcp.TcpUtils
- tuneTcpSocket(SocketChannel) - Static method in class zmq.io.net.tcp.TcpUtils
- type - Variable in enum org.zeromq.SocketType
- type - Variable in class org.zeromq.ZMonitor.ZEvent
-
The type of the event.
- type - Variable in class zmq.Command
- type - Variable in class zmq.Msg
- type - Variable in class zmq.Options
- type() - Method in enum org.zeromq.SocketType
- type(int) - Static method in enum org.zeromq.SocketType
- Type() - Constructor for enum zmq.Command.Type
- Type() - Constructor for enum zmq.Msg.Type
- typeString() - Method in class zmq.SocketBase
U
- unbind(String) - Method in class org.zeromq.ZMQ.Socket
-
Stop accepting connections on a socket.
- unbind(String) - Method in class org.zeromq.ZSocket
-
Stop accepting connections on a socket.
- unbind(SocketBase, String) - Static method in class zmq.ZMQ
- unblockSocket(SelectableChannel...) - Static method in class zmq.io.net.tcp.TcpUtils
- unblockSocket(SelectableChannel...) - Static method in class zmq.util.Utils
- unblockSocket(SelectableChannel...) - Static method in class zmq.Utils
-
Deprecated.
- UncheckedZMQException - Exception Class in org.zeromq
- UncheckedZMQException() - Constructor for exception class org.zeromq.UncheckedZMQException
- UncheckedZMQException(String) - Constructor for exception class org.zeromq.UncheckedZMQException
- UncheckedZMQException(String, Throwable) - Constructor for exception class org.zeromq.UncheckedZMQException
- UncheckedZMQException(Throwable) - Constructor for exception class org.zeromq.UncheckedZMQException
- unhash(int) - Static method in class zmq.util.Utils
-
Finds a string whose hashcode is the number in input.
- unhash(StringBuilder, int, char) - Static method in class zmq.util.Utils
- unlock() - Method in class zmq.SocketBase
- unmatch() - Method in class zmq.socket.pubsub.Dist
- unplug() - Method in class zmq.io.IOObject
- unplug() - Method in class zmq.io.StreamEngine
- UNPLUGGED - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- unpush() - Method in class zmq.pipe.YQueue
- unregister(Object) - Method in class org.zeromq.ZPoller
-
Unregister a Socket or SelectableChannel for polling on the specified events.
- unregister(SelectableChannel) - Method in class org.zeromq.ZMQ.Poller
-
Unregister a Socket for polling on the specified events.
- unregister(ZMQ.Socket) - Method in class org.zeromq.ZMQ.Poller
-
Unregister a Socket for polling on the specified events.
- unregisterEndpoint(String, SocketBase) - Method in class zmq.Ctx
- unregisterEndpoint(String, SocketBase) - Method in class zmq.ZObject
- unregisterEndpoints(SocketBase) - Method in class zmq.Ctx
- unregisterEndpoints(SocketBase) - Method in class zmq.ZObject
- unregisterInternal(Object) - Method in class org.zeromq.ZMQ.Poller
-
Unregister a Socket for polling on the specified events.
- unregisterTermAck() - Method in class zmq.Own
- unsetMeta(String) - Method in class org.zeromq.ZCert
- unsubscribe(byte[]) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_UNSUBSCRIBE' option shall remove an existing message filter on a 'ZMQ_SUB' socket.
- unsubscribe(byte[]) - Method in class org.zeromq.ZSocket
- unsubscribe(String) - Method in class org.zeromq.ZMQ.Socket
-
The 'ZMQ_UNSUBSCRIBE' option shall remove an existing message filter on a 'ZMQ_SUB' socket.
- unsubscribe(String) - Method in class org.zeromq.ZSocket
- unwrap() - Method in class org.zeromq.ZMsg
-
Pop frame off front of message, caller now owns frame.
- unwrite() - Method in class zmq.pipe.YPipe
- unwrite() - Method in interface zmq.pipe.YPipeBase
- unwrite() - Method in class zmq.pipe.YPipeConflate
- update(byte[]) - Method in class org.zeromq.util.ZDigest
- update(byte[], int, int) - Method in class org.zeromq.util.ZDigest
- update(InputStream) - Method in class org.zeromq.util.ZDigest
- UPSTREAM - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- USER_ID - Static variable in class zmq.io.Metadata
- userId - Variable in class org.zeromq.ZAuth.ZapReply
- userId - Variable in class org.zeromq.ZAuth.ZapRequest
- userId - Variable in class zmq.io.mechanism.Mechanism
- username - Variable in class org.zeromq.ZAuth.ZapRequest
- Utils - Class in org.zeromq
- Utils - Class in zmq.util
- Utils - Class in zmq
-
Deprecated.
- Utils() - Constructor for class org.zeromq.Utils
- Utils() - Constructor for class zmq.util.Utils
- Utils() - Constructor for class zmq.Utils
-
Deprecated.
V
- V0 - Enum constant in enum zmq.io.StreamEngine.Protocol
- V1 - Enum constant in enum zmq.io.StreamEngine.Protocol
- V1Decoder - Class in zmq.io.coder.v1
- V1Decoder(Errno, int, long, MsgAllocator) - Constructor for class zmq.io.coder.v1.V1Decoder
- V1Encoder - Class in zmq.io.coder.v1
- V1Encoder(Errno, int) - Constructor for class zmq.io.coder.v1.V1Encoder
- V1Protocol - Interface in zmq.io.coder.v1
- V2 - Enum constant in enum zmq.io.StreamEngine.Protocol
- V2_GREETING_SIZE - Static variable in class zmq.io.StreamEngine
- V2Decoder - Class in zmq.io.coder.v2
- V2Decoder(Errno, int, long, MsgAllocator) - Constructor for class zmq.io.coder.v2.V2Decoder
- V2Encoder - Class in zmq.io.coder.v2
- V2Encoder(Errno, int) - Constructor for class zmq.io.coder.v2.V2Encoder
- V2Protocol - Interface in zmq.io.coder.v2
- V3 - Enum constant in enum zmq.io.StreamEngine.Protocol
- V3_GREETING_SIZE - Static variable in class zmq.io.StreamEngine
- valid - Variable in enum zmq.io.net.NetProtocol
- value - Variable in class org.zeromq.ZConfig
- value - Variable in class org.zeromq.ZMonitor.ZEvent
-
String representation of the event value.
- value - Variable in class org.zeromq.ZMQ.Event
- value - Variable in enum zmq.Config
- value - Variable in class zmq.util.ValueReference
- VALUE_CHANNEL - Static variable in class zmq.ZMQ.Event
- VALUE_INTEGER - Static variable in class zmq.ZMQ.Event
- valueOf(String) - Static method in enum org.zeromq.SocketType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZMonitor.Event
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZMonitor.ProtocolCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZMQ.Error
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZMQ.Socket.Mechanism
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZProxy.Command
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZProxy.Plug
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.zeromq.ZProxy.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.Command.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.Config
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.Ctx.Side
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.coder.IDecoder.Step.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.curve.Curve.Size
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.curve.CurveClientMechanism.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.curve.CurveServerMechanism.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.Mechanism.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.Mechanisms
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.plain.PlainClientMechanism.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.mechanism.plain.PlainServerMechanism.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.net.NetProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.net.StandardProtocolFamily
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.net.tcp.SocksConnecter.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.StreamEngine.ErrorReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.io.StreamEngine.Protocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.Msg.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.pipe.Pipe.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.Proxy.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.socket.radiodish.Dish.DishSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.socket.radiodish.Radio.RadioSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.socket.reqrep.Req.ReqSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum zmq.socket.Sockets
-
Returns the enum constant of this type with the specified name.
- ValueReference<V> - Class in zmq.util
- ValueReference() - Constructor for class zmq.util.ValueReference
- ValueReference(V) - Constructor for class zmq.util.ValueReference
- values - Variable in class zmq.pipe.YQueue.Chunk
- values() - Static method in enum org.zeromq.SocketType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZMonitor.Event
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZMonitor.ProtocolCode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZMQ.Error
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZMQ.Socket.Mechanism
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZProxy.Command
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZProxy.Plug
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.zeromq.ZProxy.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.Command.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.Config
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.Ctx.Side
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.coder.IDecoder.Step.Result
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.curve.Curve.Size
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.curve.CurveClientMechanism.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.curve.CurveServerMechanism.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.Mechanism.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.Mechanisms
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.plain.PlainClientMechanism.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.mechanism.plain.PlainServerMechanism.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.net.NetProtocol
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.net.StandardProtocolFamily
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.net.tcp.SocksConnecter.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.StreamEngine.ErrorReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.io.StreamEngine.Protocol
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.Msg.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.pipe.Pipe.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.Proxy.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.socket.radiodish.Dish.DishSession.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.socket.radiodish.Radio.RadioSession.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.socket.reqrep.Req.ReqSession.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum zmq.socket.Sockets
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class zmq.util.MultiMap
-
Deprecated.
- verbose - Variable in class org.zeromq.ZAuth.AuthActor
- verbose - Variable in class org.zeromq.ZLoop
- verbose - Variable in class org.zeromq.ZMonitor.MonitorActor
- verbose(boolean) - Method in class org.zeromq.ZAuth
- verbose(boolean) - Method in class org.zeromq.ZLoop
- verbose(boolean) - Method in class org.zeromq.ZMonitor
-
Sets verbosity of the monitor.
- VERBOSE - Static variable in class org.zeromq.ZAuth
- VERBOSE - Static variable in class org.zeromq.ZMonitor
- verboseSubs - Variable in class zmq.socket.pubsub.XPub
- verboseUnsubs - Variable in class zmq.socket.pubsub.XPub
- version - Variable in class org.zeromq.ZAuth.ZapReply
- version - Variable in class org.zeromq.ZAuth.ZapRequest
- VERSION - Static variable in interface zmq.io.coder.v1.V1Protocol
- VERSION - Static variable in interface zmq.io.coder.v2.V2Protocol
- visit(ZConfig, ZConfig.IVisitor, int) - Method in class org.zeromq.ZConfig
- visitDir(File) - Method in interface org.zeromq.ZCertStore.IFileVisitor
-
Visits a directory.
- visitFile(File) - Method in interface org.zeromq.ZCertStore.IFileVisitor
-
Visits a file.
W
- w - Variable in class zmq.pipe.YPipe
- w - Variable in class zmq.Signaler
- WAIT_FOREVER - Static variable in class zmq.Ctx
- waitEvent(long) - Method in class zmq.Signaler
- WAITING_FOR_CHOICE - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- WAITING_FOR_DELIMITER - Enum constant in enum zmq.pipe.Pipe.State
- WAITING_FOR_HELLO - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- WAITING_FOR_INITIATE - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- WAITING_FOR_PROXY_CONNECTION - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- WAITING_FOR_READY - Enum constant in enum zmq.io.mechanism.plain.PlainClientMechanism.State
- WAITING_FOR_RECONNECT_TIME - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- WAITING_FOR_RESPONSE - Enum constant in enum zmq.io.net.tcp.SocksConnecter.Status
- WAITING_FOR_WELCOME - Enum constant in enum zmq.io.mechanism.plain.PlainClientMechanism.State
- WAITING_FOR_ZAP_REPLY - Enum constant in enum zmq.io.mechanism.plain.PlainServerMechanism.State
- wcursor - Variable in class zmq.Signaler
- wdummy - Variable in class zmq.Signaler
- when - Variable in class org.zeromq.ZLoop.STimer
- whitelist - Variable in class org.zeromq.ZAuth.AuthActor
- Wire - Class in zmq.util
- Wire() - Constructor for class zmq.util.Wire
- worker - Variable in class zmq.poll.PollerBase
- wrap(ZFrame) - Method in class org.zeromq.ZMsg
-
Push frame plus empty frame to front of message, before 1st frame.
- writable(Object) - Method in class org.zeromq.ZPoller
- writable(SelectableChannel) - Method in class org.zeromq.ZPoller
- writable(ZMQ.Socket) - Method in class org.zeromq.ZPoller
- WRITABLE - Static variable in class org.zeromq.ZPoller
- write(OutputStream) - Method in class zmq.io.Metadata
- write(ByteBuffer) - Method in class zmq.io.StreamEngine
- write(T) - Method in class zmq.pipe.DBuffer
- write(T, boolean) - Method in class zmq.pipe.YPipe
- write(T, boolean) - Method in interface zmq.pipe.YPipeBase
- write(T, boolean) - Method in class zmq.pipe.YPipeConflate
- write(Msg) - Method in class zmq.pipe.Pipe
- write(Pipe, Msg) - Method in class zmq.socket.pubsub.Dist
- write(SocketBase) - Method in class zmq.ZMQ.Event
- writeActivated(Pipe) - Method in class zmq.io.SessionBase
- writeActivated(Pipe) - Method in interface zmq.pipe.Pipe.IPipeEvents
- writeActivated(Pipe) - Method in class zmq.SocketBase
- writeBuf - Variable in class zmq.io.coder.EncoderBase
- writeCredential - Variable in class zmq.io.StreamEngine
- writeCredential(Msg) - Method in class zmq.io.StreamEngine
- writeIndex - Variable in class zmq.Msg
- writeZapMsg(Msg) - Method in class zmq.io.SessionBase
X
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.Channel
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.clientserver.Client
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.clientserver.Server
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.Pair
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.Peer
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.pipeline.Pull
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.pipeline.Push
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.pubsub.Pub
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.pubsub.XPub
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.pubsub.XSub
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.radiodish.Dish
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.radiodish.Radio
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.reqrep.Dealer
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.reqrep.Router
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.scattergather.Gather
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.scattergather.Scatter
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.socket.Stream
- xattachPipe(Pipe, boolean, boolean) - Method in class zmq.SocketBase
- xdisconnectPeer(int) - Method in class zmq.socket.clientserver.Server
- xdisconnectPeer(int) - Method in class zmq.SocketBase
- xhasIn() - Method in class zmq.socket.Channel
- xhasIn() - Method in class zmq.socket.clientserver.Client
- xhasIn() - Method in class zmq.socket.clientserver.Server
- xhasIn() - Method in class zmq.socket.Pair
- xhasIn() - Method in class zmq.socket.pipeline.Pull
- xhasIn() - Method in class zmq.socket.pubsub.Pub
- xhasIn() - Method in class zmq.socket.pubsub.XPub
- xhasIn() - Method in class zmq.socket.pubsub.XSub
- xhasIn() - Method in class zmq.socket.radiodish.Dish
- xhasIn() - Method in class zmq.socket.radiodish.Radio
- xhasIn() - Method in class zmq.socket.reqrep.Dealer
- xhasIn() - Method in class zmq.socket.reqrep.Rep
- xhasIn() - Method in class zmq.socket.reqrep.Req
- xhasIn() - Method in class zmq.socket.reqrep.Router
- xhasIn() - Method in class zmq.socket.scattergather.Gather
- xhasIn() - Method in class zmq.socket.Stream
- xhasIn() - Method in class zmq.SocketBase
- xhasOut() - Method in class zmq.socket.Channel
- xhasOut() - Method in class zmq.socket.clientserver.Client
- xhasOut() - Method in class zmq.socket.clientserver.Server
- xhasOut() - Method in class zmq.socket.Pair
- xhasOut() - Method in class zmq.socket.pipeline.Push
- xhasOut() - Method in class zmq.socket.pubsub.Sub
- xhasOut() - Method in class zmq.socket.pubsub.XPub
- xhasOut() - Method in class zmq.socket.pubsub.XSub
- xhasOut() - Method in class zmq.socket.radiodish.Dish
- xhasOut() - Method in class zmq.socket.radiodish.Radio
- xhasOut() - Method in class zmq.socket.reqrep.Dealer
- xhasOut() - Method in class zmq.socket.reqrep.Rep
- xhasOut() - Method in class zmq.socket.reqrep.Req
- xhasOut() - Method in class zmq.socket.reqrep.Router
- xhasOut() - Method in class zmq.socket.scattergather.Scatter
- xhasOut() - Method in class zmq.socket.Stream
- xhasOut() - Method in class zmq.SocketBase
- xhiccuped(Pipe) - Method in class zmq.socket.pubsub.XSub
- xhiccuped(Pipe) - Method in class zmq.socket.radiodish.Dish
- xhiccuped(Pipe) - Method in class zmq.SocketBase
- xjoin(String) - Method in class zmq.socket.radiodish.Dish
- xjoin(String) - Method in class zmq.SocketBase
- xleave(String) - Method in class zmq.socket.radiodish.Dish
- xleave(String) - Method in class zmq.SocketBase
- xpipeTerminated(Pipe) - Method in class zmq.socket.Channel
- xpipeTerminated(Pipe) - Method in class zmq.socket.clientserver.Client
- xpipeTerminated(Pipe) - Method in class zmq.socket.clientserver.Server
- xpipeTerminated(Pipe) - Method in class zmq.socket.Pair
- xpipeTerminated(Pipe) - Method in class zmq.socket.pipeline.Pull
- xpipeTerminated(Pipe) - Method in class zmq.socket.pipeline.Push
- xpipeTerminated(Pipe) - Method in class zmq.socket.pubsub.XPub
- xpipeTerminated(Pipe) - Method in class zmq.socket.pubsub.XSub
- xpipeTerminated(Pipe) - Method in class zmq.socket.radiodish.Dish
- xpipeTerminated(Pipe) - Method in class zmq.socket.radiodish.Radio
- xpipeTerminated(Pipe) - Method in class zmq.socket.reqrep.Dealer
- xpipeTerminated(Pipe) - Method in class zmq.socket.reqrep.Req
- xpipeTerminated(Pipe) - Method in class zmq.socket.reqrep.Router
- xpipeTerminated(Pipe) - Method in class zmq.socket.scattergather.Gather
- xpipeTerminated(Pipe) - Method in class zmq.socket.scattergather.Scatter
- xpipeTerminated(Pipe) - Method in class zmq.socket.Stream
- xpipeTerminated(Pipe) - Method in class zmq.SocketBase
- XPub - Class in zmq.socket.pubsub
- XPub(Ctx, int, int) - Constructor for class zmq.socket.pubsub.XPub
- XPUB - Enum constant in enum org.zeromq.SocketType
-
Flag to specify a XPUB socket, receiving side must be a SUB or XSUB.
- XPUB - Enum constant in enum zmq.socket.Sockets
- XPUB - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- XPub.MarkAsMatching - Class in zmq.socket.pubsub
- XPub.SendUnsubscription - Class in zmq.socket.pubsub
- xreadActivated(Pipe) - Method in class zmq.socket.Channel
- xreadActivated(Pipe) - Method in class zmq.socket.clientserver.Client
- xreadActivated(Pipe) - Method in class zmq.socket.clientserver.Server
- xreadActivated(Pipe) - Method in class zmq.socket.Pair
- xreadActivated(Pipe) - Method in class zmq.socket.pipeline.Pull
- xreadActivated(Pipe) - Method in class zmq.socket.pubsub.XPub
- xreadActivated(Pipe) - Method in class zmq.socket.pubsub.XSub
- xreadActivated(Pipe) - Method in class zmq.socket.radiodish.Dish
- xreadActivated(Pipe) - Method in class zmq.socket.radiodish.Radio
- xreadActivated(Pipe) - Method in class zmq.socket.reqrep.Dealer
- xreadActivated(Pipe) - Method in class zmq.socket.reqrep.Router
- xreadActivated(Pipe) - Method in class zmq.socket.scattergather.Gather
- xreadActivated(Pipe) - Method in class zmq.socket.Stream
- xreadActivated(Pipe) - Method in class zmq.SocketBase
- xrecv() - Method in class zmq.socket.Channel
- xrecv() - Method in class zmq.socket.clientserver.Client
- xrecv() - Method in class zmq.socket.clientserver.Server
- xrecv() - Method in class zmq.socket.Pair
- xrecv() - Method in class zmq.socket.pipeline.Pull
- xrecv() - Method in class zmq.socket.pubsub.Pub
- xrecv() - Method in class zmq.socket.pubsub.XPub
- xrecv() - Method in class zmq.socket.pubsub.XSub
- xrecv() - Method in class zmq.socket.radiodish.Dish
- xrecv() - Method in class zmq.socket.radiodish.Radio
- xrecv() - Method in class zmq.socket.reqrep.Dealer
- xrecv() - Method in class zmq.socket.reqrep.Rep
- xrecv() - Method in class zmq.socket.reqrep.Req
- xrecv() - Method in class zmq.socket.reqrep.Router
- xrecv() - Method in class zmq.socket.scattergather.Gather
- xrecv() - Method in class zmq.socket.Stream
- xrecv() - Method in class zmq.SocketBase
- XREP - Static variable in class org.zeromq.ZMQ
-
Deprecated.As of release 3.0 of zeromq, replaced by
ZMQ.ROUTER
- XREQ - Static variable in class org.zeromq.ZMQ
-
Deprecated.As of release 3.0 of zeromq, replaced by
ZMQ.DEALER
- xsend(Msg) - Method in class zmq.socket.Channel
- xsend(Msg) - Method in class zmq.socket.clientserver.Client
- xsend(Msg) - Method in class zmq.socket.clientserver.Server
- xsend(Msg) - Method in class zmq.socket.Pair
- xsend(Msg) - Method in class zmq.socket.pipeline.Push
- xsend(Msg) - Method in class zmq.socket.pubsub.Sub
- xsend(Msg) - Method in class zmq.socket.pubsub.XPub
- xsend(Msg) - Method in class zmq.socket.pubsub.XSub
- xsend(Msg) - Method in class zmq.socket.radiodish.Dish
- xsend(Msg) - Method in class zmq.socket.radiodish.Radio
- xsend(Msg) - Method in class zmq.socket.reqrep.Dealer
- xsend(Msg) - Method in class zmq.socket.reqrep.Rep
- xsend(Msg) - Method in class zmq.socket.reqrep.Req
- xsend(Msg) - Method in class zmq.socket.reqrep.Router
- xsend(Msg) - Method in class zmq.socket.scattergather.Scatter
- xsend(Msg) - Method in class zmq.socket.Stream
- xsend(Msg) - Method in class zmq.SocketBase
- xsetsockopt(int, Object) - Method in class zmq.socket.pubsub.Sub
- xsetsockopt(int, Object) - Method in class zmq.socket.pubsub.XPub
- xsetsockopt(int, Object) - Method in class zmq.socket.reqrep.Dealer
- xsetsockopt(int, Object) - Method in class zmq.socket.reqrep.Req
- xsetsockopt(int, Object) - Method in class zmq.socket.reqrep.Router
- xsetsockopt(int, Object) - Method in class zmq.socket.Stream
- xsetsockopt(int, Object) - Method in class zmq.SocketBase
- XSub - Class in zmq.socket.pubsub
- XSub(Ctx, int, int) - Constructor for class zmq.socket.pubsub.XSub
- XSUB - Enum constant in enum org.zeromq.SocketType
-
Flag to specify the receiving part of the PUB or XPUB socket.
- XSUB - Enum constant in enum zmq.socket.Sockets
- XSUB - Static variable in class org.zeromq.ZMQ
-
Deprecated.
- XSub.SendSubscription - Class in zmq.socket.pubsub
- xwriteActivated(Pipe) - Method in class zmq.socket.Channel
- xwriteActivated(Pipe) - Method in class zmq.socket.clientserver.Client
- xwriteActivated(Pipe) - Method in class zmq.socket.clientserver.Server
- xwriteActivated(Pipe) - Method in class zmq.socket.Pair
- xwriteActivated(Pipe) - Method in class zmq.socket.pipeline.Push
- xwriteActivated(Pipe) - Method in class zmq.socket.pubsub.XPub
- xwriteActivated(Pipe) - Method in class zmq.socket.pubsub.XSub
- xwriteActivated(Pipe) - Method in class zmq.socket.radiodish.Dish
- xwriteActivated(Pipe) - Method in class zmq.socket.radiodish.Radio
- xwriteActivated(Pipe) - Method in class zmq.socket.reqrep.Dealer
- xwriteActivated(Pipe) - Method in class zmq.socket.reqrep.Router
- xwriteActivated(Pipe) - Method in class zmq.socket.scattergather.Scatter
- xwriteActivated(Pipe) - Method in class zmq.socket.Stream
- xwriteActivated(Pipe) - Method in class zmq.SocketBase
- xxrecv() - Method in class zmq.socket.radiodish.Dish
Y
- YPipe<T> - Class in zmq.pipe
- YPipe(int) - Constructor for class zmq.pipe.YPipe
- YPipeBase<T> - Interface in zmq.pipe
- YPipeConflate<T> - Class in zmq.pipe
- YPipeConflate() - Constructor for class zmq.pipe.YPipeConflate
- YQueue<T> - Class in zmq.pipe
- YQueue(int) - Constructor for class zmq.pipe.YQueue
- YQueue.Chunk<T> - Class in zmq.pipe
Z
- Z85 - Class in zmq.util
- Z85() - Constructor for class zmq.util.Z85
- z85Decode(String) - Static method in class org.zeromq.ZMQ.Curve
-
The function shall decode given key encoded as Z85 string into byte array.
- z85Encode(byte[]) - Static method in class org.zeromq.ZMQ.Curve
-
Encodes the binary block specified by data into a string.
- z85EncodePublic(byte[]) - Static method in class zmq.io.mechanism.curve.Curve
- ZActor - Class in org.zeromq
-
First implementation of a background actor remotely controlled for ØMQ.
- ZActor(ZActor.Actor, String, Object...) - Constructor for class org.zeromq.ZActor
-
Creates a new ZActor.
- ZActor(ZAgent.SelectorCreator, ZActor.Actor, String, Object...) - Constructor for class org.zeromq.ZActor
-
Deprecated.
- ZActor(ZContext, ZActor.Actor, String, Object...) - Constructor for class org.zeromq.ZActor
-
Creates a new ZActor.
- ZActor(ZContext, ZAgent.SelectorCreator, ZActor.Actor, String, Object...) - Constructor for class org.zeromq.ZActor
-
Deprecated.
- ZActor.Actor - Interface in org.zeromq
-
Defines the contract for the acting instance.
- ZActor.ActorFortune - Class in org.zeromq
- ZActor.Double - Class in org.zeromq
- ZActor.Duo - Class in org.zeromq
-
Another actor will be called just before the main one, without participating to the decisions.
- ZActor.SimpleActor - Class in org.zeromq
-
Simple adapter for an actor, with no sockets, blocking calls and immediate termination.
- ZAgent - Interface in org.zeromq
-
First implementation of an agent for a remotely controlled background service for ØMQ.
- ZAgent.Creator - Class in org.zeromq
- ZAgent.SelectorCreator - Interface in org.zeromq
-
Deprecated.
- ZAgent.SimpleAgent - Class in org.zeromq
-
Creates a very simple agent with an easy lock mechanism.
- ZAP_VERSION - Static variable in class org.zeromq.ZAuth
- zapConnect() - Method in class zmq.io.SessionBase
- zapConnected - Variable in class zmq.io.mechanism.NullMechanism
- zapDomain - Variable in class zmq.Options
- zapEnabled() - Method in class zmq.io.SessionBase
- zapMsgAvailable() - Method in class zmq.io.EngineNotImplemented
- zapMsgAvailable() - Method in interface zmq.io.IEngine
- zapMsgAvailable() - Method in class zmq.io.mechanism.curve.CurveClientMechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.curve.CurveServerMechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.gssapi.GssapiClientMechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.gssapi.GssapiServerMechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.Mechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.NullMechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.plain.PlainClientMechanism
- zapMsgAvailable() - Method in class zmq.io.mechanism.plain.PlainServerMechanism
- zapMsgAvailable() - Method in class zmq.io.StreamEngine
- zapPipe - Variable in class zmq.io.SessionBase
- zapProperties - Variable in class zmq.io.mechanism.Mechanism
- ZapReply(String, String, int, String, String, ZMetadata) - Constructor for class org.zeromq.ZAuth.ZapReply
- ZapReply(String, String, int, String, String, ZMetadata, String, String) - Constructor for class org.zeromq.ZAuth.ZapReply
- zapReplyReceived - Variable in class zmq.io.mechanism.NullMechanism
- ZapRequest(ZMQ.Socket, ZMsg) - Constructor for class org.zeromq.ZAuth.ZapRequest
- zapRequestSent - Variable in class zmq.io.mechanism.NullMechanism
- ZAuth - Class in org.zeromq
-
A ZAuth actor takes over authentication for all incoming connections in its context.
- ZAuth(ZContext) - Constructor for class org.zeromq.ZAuth
-
Install authentication for the specified context.
- ZAuth(ZContext, String) - Constructor for class org.zeromq.ZAuth
- ZAuth(ZContext, String, Map<String, ZAuth.Auth>) - Constructor for class org.zeromq.ZAuth
- ZAuth(ZContext, ZCertStore.Fingerprinter) - Constructor for class org.zeromq.ZAuth
- ZAuth.Auth - Interface in org.zeromq
- ZAuth.AuthActor - Class in org.zeromq
-
AuthActor is the backend actor which we talk to over a pipe.
- ZAuth.SimpleCurveAuth - Class in org.zeromq
- ZAuth.SimpleNullAuth - Class in org.zeromq
- ZAuth.SimplePlainAuth - Class in org.zeromq
- ZAuth.ZapReply - Class in org.zeromq
- ZAuth.ZapRequest - Class in org.zeromq
-
A small class for working with ZAP requests and replies.
- ZBeacon - Class in org.zeromq
-
This class implements a peer-to-peer discovery service for local networks.
- ZBeacon(int, byte[]) - Constructor for class org.zeromq.ZBeacon
- ZBeacon(String, byte[], int, byte[], long, boolean, boolean) - Constructor for class org.zeromq.ZBeacon
-
Deprecated.
- ZBeacon(String, int, byte[]) - Constructor for class org.zeromq.ZBeacon
- ZBeacon(String, int, byte[], boolean) - Constructor for class org.zeromq.ZBeacon
- ZBeacon(String, int, byte[], boolean, boolean) - Constructor for class org.zeromq.ZBeacon
- ZBeacon(InetAddress, InetAddress, int, byte[], long, boolean, boolean) - Constructor for class org.zeromq.ZBeacon
- ZBeacon.BroadcastClient - Class in org.zeromq
-
The broadcast client periodically sends beacons via UDP to the network.
- ZBeacon.BroadcastServer - Class in org.zeromq
-
The broadcast server receives beacons.
- ZBeacon.Builder - Class in org.zeromq
- ZBeacon.Listener - Interface in org.zeromq
-
All beacons with matching prefix are passed to a listener.
- ZCert - Class in org.zeromq
-
The ZCert class provides a way to create and work with security certificates for the ZMQ CURVE mechanism.
- ZCert() - Constructor for class org.zeromq.ZCert
- ZCert(byte[], byte[]) - Constructor for class org.zeromq.ZCert
- ZCert(String) - Constructor for class org.zeromq.ZCert
- ZCert(String, String) - Constructor for class org.zeromq.ZCert
- ZCert(ZMQ.Curve.KeyPair) - Constructor for class org.zeromq.ZCert
- ZCertStore - Class in org.zeromq
-
To authenticate new clients using the ZeroMQ CURVE security mechanism, we have to check that the client's public key matches a key we know and accept.
- ZCertStore(String) - Constructor for class org.zeromq.ZCertStore
-
Create a Certificate Store at that file system folder location
- ZCertStore(String, ZCertStore.Fingerprinter) - Constructor for class org.zeromq.ZCertStore
- ZCertStore.Fingerprinter - Interface in org.zeromq
- ZCertStore.Hasher - Class in org.zeromq
- ZCertStore.IFileVisitor - Interface in org.zeromq
- ZCertStore.Timestamper - Class in org.zeromq
- ZConfig - Class in org.zeromq
-
Lets applications load, work with, and save configuration files.
- ZConfig(String, ZConfig) - Constructor for class org.zeromq.ZConfig
- ZConfig.IVisitor - Interface in org.zeromq
- ZConfig.ReadException - Exception Class in org.zeromq
- ZContext - Class in org.zeromq
-
ZContext provides a high-level ZeroMQ context management class It manages open sockets in the context and automatically closes these before terminating the context.
- ZContext() - Constructor for class org.zeromq.ZContext
-
Class Constructor
- ZContext(int) - Constructor for class org.zeromq.ZContext
- ZContext(ZContext, int) - Constructor for class org.zeromq.ZContext
- zctx - Variable in class org.zeromq.ZMQ.Socket
- ZData - Class in org.zeromq.util
- ZData(byte[]) - Constructor for class org.zeromq.util.ZData
- ZDigest - Class in org.zeromq.util
-
The ZDigest class generates a hash from chunks of data.
- ZDigest() - Constructor for class org.zeromq.util.ZDigest
-
Creates a new digester.
- ZDigest(byte[]) - Constructor for class org.zeromq.util.ZDigest
-
Creates a new digester.
- ZERO - Enum constant in enum zmq.io.mechanism.curve.Curve.Size
- zeroCopy - Variable in class zmq.io.coder.DecoderBase
- ZError - Class in zmq
- ZError() - Constructor for class zmq.ZError
- ZError.CtxTerminatedException - Exception Class in zmq
- ZError.InstantiationException - Exception Class in zmq
- ZError.IOException - Exception Class in zmq
- ZEvent(ZMQ.Event) - Constructor for class org.zeromq.ZMonitor.ZEvent
- ZEvent(ZMsg) - Constructor for class org.zeromq.ZMonitor.ZEvent
- ZFrame - Class in org.zeromq
-
ZFrame The ZFrame class provides methods to send and receive single message frames across 0MQ sockets.
- ZFrame() - Constructor for class org.zeromq.ZFrame
-
Class Constructor Creates an empty frame.
- ZFrame(byte[]) - Constructor for class org.zeromq.ZFrame
-
Class Constructor Copies message data into ZFrame object
- ZFrame(String) - Constructor for class org.zeromq.ZFrame
-
Class Constructor Copies String into frame data
- ZFrame(Msg) - Constructor for class org.zeromq.ZFrame
-
Class Constructor Uses internal Msg class to access routingId
- zinterest - Variable in class zmq.poll.PollItem
- zinterestOps() - Method in class zmq.poll.PollItem
- ZLoop - Class in org.zeromq
-
The ZLoop class provides an event-driven reactor pattern.
- ZLoop(ZContext) - Constructor for class org.zeromq.ZLoop
- ZLoop(ZMQ.Context) - Constructor for class org.zeromq.ZLoop
- ZLoop.IZLoopHandler - Interface in org.zeromq
- ZLoop.SPoller - Class in org.zeromq
- ZLoop.STimer - Class in org.zeromq
- ZMetadata - Class in org.zeromq.util
- ZMetadata() - Constructor for class org.zeromq.util.ZMetadata
- ZMetadata(Metadata) - Constructor for class org.zeromq.util.ZMetadata
- ZMonitor - Class in org.zeromq
-
The ZMonitor actor provides an API for obtaining socket events such as connected, listen, disconnected, etc.
- ZMonitor(ZContext, ZMQ.Socket) - Constructor for class org.zeromq.ZMonitor
-
Creates a monitoring actor for the given socket.
- ZMonitor.Event - Enum in org.zeromq
-
Enumerates types of monitoring events.
- ZMonitor.MonitorActor - Class in org.zeromq
- ZMonitor.ProtocolCode - Enum in org.zeromq
-
The code returned by handshake events, as generated by
eventHandshakeXXX
. - ZMonitor.ZEvent - Class in org.zeromq
-
High-level representation of an event.
- zmq - package zmq
-
Provides low-level bindings for ØMQ.
- ZMQ - Class in org.zeromq
-
The ØMQ lightweight messaging kernel is a library which extends the standard socket interfaces with features traditionally provided by specialised messaging middleware products.
- ZMQ - Class in zmq
- ZMQ() - Constructor for class org.zeromq.ZMQ
- ZMQ() - Constructor for class zmq.ZMQ
- ZMQ_AFFINITY - Static variable in class zmq.ZMQ
- ZMQ_AS_TYPE - Static variable in class zmq.ZMQ
- ZMQ_BACKLOG - Static variable in class zmq.ZMQ
- ZMQ_BLOCKY - Static variable in class zmq.ZMQ
- ZMQ_CHANNEL - Static variable in class zmq.ZMQ
- ZMQ_CLIENT - Static variable in class zmq.ZMQ
- ZMQ_CONFLATE - Static variable in class zmq.ZMQ
- ZMQ_CONNECT_RID - Static variable in class zmq.ZMQ
- ZMQ_CURVE_PUBLICKEY - Static variable in class zmq.ZMQ
- ZMQ_CURVE_SECRETKEY - Static variable in class zmq.ZMQ
- ZMQ_CURVE_SERVER - Static variable in class zmq.ZMQ
- ZMQ_CURVE_SERVERKEY - Static variable in class zmq.ZMQ
- ZMQ_CUSTOM_OPTION - Static variable in class zmq.ZMQ
- ZMQ_DEALER - Static variable in class zmq.ZMQ
- ZMQ_DECODER - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_DELAY_ATTACH_ON_CONNECT - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_DISCONNECT_MSG - Static variable in class zmq.ZMQ
- ZMQ_DISH - Static variable in class zmq.ZMQ
- ZMQ_DONTWAIT - Static variable in class zmq.ZMQ
- ZMQ_ENCODER - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_EVENT_ACCEPT_FAILED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_ACCEPTED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_ALL - Static variable in class zmq.ZMQ
- ZMQ_EVENT_BIND_FAILED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_CLOSE_FAILED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_CLOSED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_CONNECT_DELAYED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_CONNECT_RETRIED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_CONNECTED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_DISCONNECTED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_HANDSHAKE_FAILED_AUTH - Static variable in class zmq.ZMQ
- ZMQ_EVENT_HANDSHAKE_FAILED_NO_DETAIL - Static variable in class zmq.ZMQ
- ZMQ_EVENT_HANDSHAKE_FAILED_PROTOCOL - Static variable in class zmq.ZMQ
- ZMQ_EVENT_HANDSHAKE_PROTOCOL - Static variable in class zmq.ZMQ
- ZMQ_EVENT_HANDSHAKE_SUCCEEDED - Static variable in class zmq.ZMQ
- ZMQ_EVENT_LISTENING - Static variable in class zmq.ZMQ
- ZMQ_EVENT_MONITOR_STOPPED - Static variable in class zmq.ZMQ
- ZMQ_EVENTS - Static variable in class zmq.ZMQ
- ZMQ_FAIL_UNROUTABLE - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_FD - Static variable in class zmq.ZMQ
- ZMQ_FORWARDER - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_GATHER - Static variable in class zmq.ZMQ
- ZMQ_GSSAPI_PLAINTEXT - Static variable in class zmq.ZMQ
- ZMQ_GSSAPI_PRINCIPAL - Static variable in class zmq.ZMQ
- ZMQ_GSSAPI_SERVER - Static variable in class zmq.ZMQ
- ZMQ_GSSAPI_SERVICE_PRINCIPAL - Static variable in class zmq.ZMQ
- ZMQ_HANDSHAKE_IVL - Static variable in class zmq.ZMQ
- ZMQ_HAUSNUMERO - Static variable in class zmq.ZError
- ZMQ_HEARTBEAT_CONTEXT - Static variable in class zmq.ZMQ
- ZMQ_HEARTBEAT_IVL - Static variable in class zmq.ZMQ
- ZMQ_HEARTBEAT_TIMEOUT - Static variable in class zmq.ZMQ
- ZMQ_HEARTBEAT_TTL - Static variable in class zmq.ZMQ
- ZMQ_HELLO_MSG - Static variable in class zmq.ZMQ
- ZMQ_HICCUP_MSG - Static variable in class zmq.ZMQ
- ZMQ_IDENTITY - Static variable in class zmq.ZMQ
- ZMQ_IMMEDIATE - Static variable in class zmq.ZMQ
- ZMQ_IO_THREADS - Static variable in class zmq.ZMQ
- ZMQ_IO_THREADS_DFLT - Static variable in class zmq.ZMQ
- ZMQ_IPV4ONLY - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_IPV6 - Static variable in class zmq.ZMQ
- ZMQ_LAST_ENDPOINT - Static variable in class zmq.ZMQ
- ZMQ_LINGER - Static variable in class zmq.ZMQ
- ZMQ_MAX_SOCKETS - Static variable in class zmq.ZMQ
- ZMQ_MAX_SOCKETS_DFLT - Static variable in class zmq.ZMQ
- ZMQ_MAXMSGSIZE - Static variable in class zmq.ZMQ
- ZMQ_MECHANISM - Static variable in class zmq.ZMQ
- ZMQ_MORE - Static variable in class zmq.ZMQ
- ZMQ_MSG_ALLOCATION_HEAP_THRESHOLD - Static variable in class zmq.ZMQ
- ZMQ_MSG_ALLOCATOR - Static variable in class zmq.ZMQ
- ZMQ_MULTICAST_HOPS - Static variable in class zmq.ZMQ
- ZMQ_NOBLOCK - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_PAIR - Static variable in class zmq.ZMQ
- ZMQ_PEER - Static variable in class zmq.ZMQ
- ZMQ_PLAIN_PASSWORD - Static variable in class zmq.ZMQ
- ZMQ_PLAIN_SERVER - Static variable in class zmq.ZMQ
- ZMQ_PLAIN_USERNAME - Static variable in class zmq.ZMQ
- ZMQ_POLLERR - Static variable in class zmq.ZMQ
- ZMQ_POLLIN - Static variable in class zmq.ZMQ
- ZMQ_POLLOUT - Static variable in class zmq.ZMQ
- ZMQ_PROBE_ROUTER - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_WS_UNSPECIFIED - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_WS_UNSPECIFIED - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZAP_BAD_REQUEST_ID - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZAP_BAD_REQUEST_ID - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZAP_BAD_VERSION - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZAP_BAD_VERSION - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZAP_INVALID_METADATA - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZAP_INVALID_METADATA - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZAP_INVALID_STATUS_CODE - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZAP_INVALID_STATUS_CODE - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZAP_MALFORMED_REPLY - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZAP_MALFORMED_REPLY - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZAP_UNSPECIFIED - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZAP_UNSPECIFIED - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_CRYPTOGRAPHIC - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_CRYPTOGRAPHIC - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_INVALID_METADATA - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_INVALID_METADATA - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_INVALID_SEQUENCE - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_INVALID_SEQUENCE - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_KEY_EXCHANGE - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_KEY_EXCHANGE - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_ERROR - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_ERROR - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_HELLO - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_HELLO - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_INITIATE - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_INITIATE - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_MESSAGE - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_MESSAGE - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_READY - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_READY - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_UNSPECIFIED - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_UNSPECIFIED - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_WELCOME - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MALFORMED_COMMAND_WELCOME - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_MECHANISM_MISMATCH - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_MECHANISM_MISMATCH - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_UNEXPECTED_COMMAND - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_UNEXPECTED_COMMAND - Static variable in class zmq.ZMQ
- ZMQ_PROTOCOL_ERROR_ZMTP_UNSPECIFIED - Enum constant in enum org.zeromq.ZMonitor.ProtocolCode
- ZMQ_PROTOCOL_ERROR_ZMTP_UNSPECIFIED - Static variable in class zmq.ZMQ
- ZMQ_PUB - Static variable in class zmq.ZMQ
- ZMQ_PULL - Static variable in class zmq.ZMQ
- ZMQ_PUSH - Static variable in class zmq.ZMQ
- ZMQ_QUEUE - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_RADIO - Static variable in class zmq.ZMQ
- ZMQ_RATE - Static variable in class zmq.ZMQ
- ZMQ_RAW - Static variable in class zmq.ZMQ
- ZMQ_RCVBUF - Static variable in class zmq.ZMQ
- ZMQ_RCVHWM - Static variable in class zmq.ZMQ
- ZMQ_RCVMORE - Static variable in class zmq.ZMQ
- ZMQ_RCVTIMEO - Static variable in class zmq.ZMQ
- ZMQ_RECONNECT_IVL - Static variable in class zmq.ZMQ
- ZMQ_RECONNECT_IVL_MAX - Static variable in class zmq.ZMQ
- ZMQ_RECOVERY_IVL - Static variable in class zmq.ZMQ
- ZMQ_REP - Static variable in class zmq.ZMQ
- ZMQ_REQ - Static variable in class zmq.ZMQ
- ZMQ_REQ_CORRELATE - Static variable in class zmq.ZMQ
- ZMQ_REQ_RELAXED - Static variable in class zmq.ZMQ
- ZMQ_ROUTER - Static variable in class zmq.ZMQ
- ZMQ_ROUTER_BEHAVIOR - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_ROUTER_HANDOVER - Static variable in class zmq.ZMQ
- ZMQ_ROUTER_MANDATORY - Static variable in class zmq.ZMQ
- ZMQ_ROUTER_RAW - Static variable in class zmq.ZMQ
- ZMQ_SCATTER - Static variable in class zmq.ZMQ
- ZMQ_SELECTOR_PROVIDERCHOOSER - Static variable in class zmq.ZMQ
- ZMQ_SERVER - Static variable in class zmq.ZMQ
- ZMQ_SNDBUF - Static variable in class zmq.ZMQ
- ZMQ_SNDHWM - Static variable in class zmq.ZMQ
- ZMQ_SNDMORE - Static variable in class zmq.ZMQ
- ZMQ_SNDTIMEO - Static variable in class zmq.ZMQ
- ZMQ_SOCKS_PROXY - Static variable in class zmq.ZMQ
- ZMQ_STREAM - Static variable in class zmq.ZMQ
- ZMQ_STREAMER - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_SUB - Static variable in class zmq.ZMQ
- ZMQ_SUBSCRIBE - Static variable in class zmq.ZMQ
- ZMQ_TCP_ACCEPT_FILTER - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_TCP_KEEPALIVE - Static variable in class zmq.ZMQ
- ZMQ_TCP_KEEPALIVE_CNT - Static variable in class zmq.ZMQ
- ZMQ_TCP_KEEPALIVE_IDLE - Static variable in class zmq.ZMQ
- ZMQ_TCP_KEEPALIVE_INTVL - Static variable in class zmq.ZMQ
- ZMQ_TOS - Static variable in class zmq.ZMQ
- ZMQ_TYPE - Static variable in class zmq.ZMQ
- ZMQ_UNSUBSCRIBE - Static variable in class zmq.ZMQ
- ZMQ_VERSION_MAJOR - Static variable in class zmq.ZMQ
- ZMQ_VERSION_MINOR - Static variable in class zmq.ZMQ
- ZMQ_VERSION_PATCH - Static variable in class zmq.ZMQ
- ZMQ_XPUB - Static variable in class zmq.ZMQ
- ZMQ_XPUB_MANUAL - Static variable in class zmq.ZMQ
- ZMQ_XPUB_NODROP - Static variable in class zmq.ZMQ
- ZMQ_XPUB_VERBOSE - Static variable in class zmq.ZMQ
- ZMQ_XPUB_VERBOSE_UNSUBSCRIBE - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_XPUB_VERBOSER - Static variable in class zmq.ZMQ
- ZMQ_XREP - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_XREQ - Static variable in class zmq.ZMQ
-
Deprecated.
- ZMQ_XSUB - Static variable in class zmq.ZMQ
- ZMQ_ZAP_DOMAIN - Static variable in class zmq.ZMQ
- ZMQ.CancellationToken - Class in org.zeromq
-
A cancellation token that allows canceling ongoing Socket send/receive operations.
- ZMQ.Context - Class in org.zeromq
-
Container for all sockets in a single process, acting as the transport for inproc sockets, which are the fastest way to connect threads in one process.
- ZMQ.Curve - Class in org.zeromq
-
Class that interfaces the generation of CURVE key pairs.
- ZMQ.Curve.KeyPair - Class in org.zeromq
-
A container for a public and a corresponding secret key.
- ZMQ.Error - Enum in org.zeromq
-
Resolve code from errornumber.
- ZMQ.Event - Class in org.zeromq
-
Inner class: Event.
- ZMQ.Event - Class in zmq
- zmq.io - package zmq.io
- zmq.io.coder - package zmq.io.coder
- zmq.io.coder.raw - package zmq.io.coder.raw
- zmq.io.coder.v1 - package zmq.io.coder.v1
- zmq.io.coder.v2 - package zmq.io.coder.v2
- zmq.io.mechanism - package zmq.io.mechanism
- zmq.io.mechanism.curve - package zmq.io.mechanism.curve
- zmq.io.mechanism.gssapi - package zmq.io.mechanism.gssapi
- zmq.io.mechanism.plain - package zmq.io.mechanism.plain
- zmq.io.net - package zmq.io.net
- zmq.io.net.ipc - package zmq.io.net.ipc
- zmq.io.net.norm - package zmq.io.net.norm
- zmq.io.net.pgm - package zmq.io.net.pgm
- zmq.io.net.tcp - package zmq.io.net.tcp
- zmq.io.net.tipc - package zmq.io.net.tipc
- zmq.msg - package zmq.msg
-
Provides utility for message allocation within ØMQ.
- zmq.pipe - package zmq.pipe
- zmq.poll - package zmq.poll
- ZMQ.Poller - Class in org.zeromq
-
Provides a mechanism for applications to multiplex input/output events in a level-triggered fashion over a set of sockets
- ZMQ.PollItem - Class in org.zeromq
- zmq.socket - package zmq.socket
- ZMQ.Socket - Class in org.zeromq
-
Abstracts an asynchronous message queue, with the exact queuing semantics depending on the socket type in use.
- zmq.socket.clientserver - package zmq.socket.clientserver
- ZMQ.Socket.Mechanism - Enum in org.zeromq
- zmq.socket.pipeline - package zmq.socket.pipeline
- zmq.socket.pubsub - package zmq.socket.pubsub
- zmq.socket.radiodish - package zmq.socket.radiodish
- zmq.socket.reqrep - package zmq.socket.reqrep
- zmq.socket.scattergather - package zmq.socket.scattergather
- zmq.util - package zmq.util
- zmq.util.function - package zmq.util.function
- ZMQException - Exception Class in org.zeromq
- ZMQException(int) - Constructor for exception class org.zeromq.ZMQException
- ZMQException(String, int) - Constructor for exception class org.zeromq.ZMQException
- ZMQException(String, int, Throwable) - Constructor for exception class org.zeromq.ZMQException
- ZmqPump() - Constructor for class org.zeromq.ZProxy.ZmqPump
- ZMQQueue - Class in org.zeromq
- ZMQQueue(ZMQ.Context, ZMQ.Socket, ZMQ.Socket) - Constructor for class org.zeromq.ZMQQueue
-
Class constructor.
- ZMsg - Class in org.zeromq
-
The ZMsg class provides methods to send and receive multipart messages across 0MQ sockets.
- ZMsg() - Constructor for class org.zeromq.ZMsg
-
Class Constructor
- zmtpProperties - Variable in class zmq.io.mechanism.Mechanism
- zmtpVersion - Variable in class zmq.io.StreamEngine
- ZNeedle - Class in org.zeromq.proto
-
Needle for de/serialization of data within a frame.
- ZNeedle(byte[]) - Constructor for class org.zeromq.proto.ZNeedle
- ZNeedle(ZFrame) - Constructor for class org.zeromq.proto.ZNeedle
- ZObject - Class in zmq
- ZObject(Ctx, int) - Constructor for class zmq.ZObject
- ZObject(ZObject) - Constructor for class zmq.ZObject
- zombies - Variable in class org.zeromq.ZLoop
- ZPicture - Class in org.zeromq.proto
-
De/serialization of data within a message.
- ZPicture() - Constructor for class org.zeromq.proto.ZPicture
- ZPoller - Class in org.zeromq
-
Rewritten poller for ØMQ.
- ZPoller(Selector) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller with a given selector for operational polling.
- ZPoller(ZContext) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller attached to a given context that will provide selector for operational polling.
- ZPoller(ZPoller) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller based on the current one.
- ZPoller(ZPoller.ItemCreator, Selector) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller.
- ZPoller(ZPoller.ItemCreator, ZContext) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller attached to a given context that will provide selector for operational polling.
- ZPoller(ZPoller.ItemCreator, ZContext, Selector) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller.
- ZPoller(ZPoller.ItemCreator, ZPoller) - Constructor for class org.zeromq.ZPoller
-
Creates a new poller based on the current one.
- ZPoller.ComposeEventsHandler - Class in org.zeromq
- ZPoller.CompositePollItem - Class in org.zeromq
- ZPoller.EventsHandler - Interface in org.zeromq
- ZPoller.ItemCreator - Interface in org.zeromq
- ZPoller.ItemHolder - Interface in org.zeromq
- ZPoller.SimpleCreator - Class in org.zeromq
- ZPoller.ZPollItem - Class in org.zeromq
- ZPollItem(SelectableChannel, ZPoller.EventsHandler, int) - Constructor for class org.zeromq.ZPoller.ZPollItem
- ZPollItem(ZMQ.Socket, ZPoller.EventsHandler, int) - Constructor for class org.zeromq.ZPoller.ZPollItem
- ZProxy - Class in org.zeromq
-
Implementation of a remotely controlled proxy for 0MQ, using
ZActor
. - ZProxy(String, ZAgent.SelectorCreator, ZProxy.Proxy, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Deprecated.use
ZProxy(String, Proxy, String, Object...)
instead. - ZProxy(String, ZProxy.Proxy, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Creates a new named proxy.
- ZProxy(String, ZProxy.Proxy, ZProxy.Pump, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Creates a new named proxy.
- ZProxy(ZAgent.SelectorCreator, ZProxy.Proxy, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Deprecated.use
ZProxy(Proxy, String, Object...)
instead. - ZProxy(ZContext, String, ZAgent.SelectorCreator, ZProxy.Proxy, ZProxy.Pump, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Deprecated.
- ZProxy(ZContext, String, ZProxy.Proxy, ZProxy.Pump, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Creates a new named proxy.
- ZProxy(ZProxy.Proxy, String, Object...) - Constructor for class org.zeromq.ZProxy
-
Creates a new unnamed proxy.
- ZProxy.Command - Enum in org.zeromq
- ZProxy.Plug - Enum in org.zeromq
-
Possible places for sockets in the proxy.
- ZProxy.Proxy - Interface in org.zeromq
- ZProxy.Proxy.SimpleProxy - Class in org.zeromq
- ZProxy.ProxyActor - Class in org.zeromq
- ZProxy.ProxyActor.State - Class in org.zeromq
- ZProxy.Pump - Interface in org.zeromq
- ZProxy.State - Enum in org.zeromq
- ZProxy.ZmqPump - Class in org.zeromq
-
A specialized transport for better transmission purposes that will send each packets individually instead of the whole message.
- ZProxy.ZPump - Class in org.zeromq
-
A pump that reads a message as a whole before transmitting it.
- ZProxy.ZPump.Identity - Class in org.zeromq
- ZProxy.ZPump.Transformer - Interface in org.zeromq
- ZPump() - Constructor for class org.zeromq.ZProxy.ZPump
- ZPump(ZProxy.ZPump.Transformer) - Constructor for class org.zeromq.ZProxy.ZPump
- zresolve(String, boolean) - Method in enum zmq.io.net.NetProtocol
- ZSocket - Class in org.zeromq
-
ZeroMQ sockets present an abstraction of an asynchronous message queue, with the exact queuing semantics depending on the socket type in use.
- ZSocket(int) - Constructor for class org.zeromq.ZSocket
-
Create a ZeroMQ socket
- ZSocket(SocketType) - Constructor for class org.zeromq.ZSocket
-
Create a ZeroMQ socket
- ZStar - Class in org.zeromq
-
First implementation for the base of a remotely controlled background service for 0MQ.
- ZStar(ZAgent.SelectorCreator, ZStar.Fortune, String, Object...) - Constructor for class org.zeromq.ZStar
-
Deprecated.use
ZStar(Fortune, String, Object...)
instead. - ZStar(ZContext, ZAgent.SelectorCreator, ZStar.Fortune, String, Object...) - Constructor for class org.zeromq.ZStar
-
Deprecated.use
ZStar(ZContext, Fortune, String, Object...)
instead. - ZStar(ZContext, ZAgent.SelectorCreator, ZStar.Fortune, BiFunction<ZMQ.Socket, String, ZAgent>, String, Object...) - Constructor for class org.zeromq.ZStar
-
Deprecated.
- ZStar(ZContext, ZStar.Fortune, String, Object...) - Constructor for class org.zeromq.ZStar
-
Creates a new ZStar.
- ZStar(ZContext, ZStar.Fortune, BiFunction<ZMQ.Socket, String, ZAgent>, String, Object...) - Constructor for class org.zeromq.ZStar
-
Creates a new ZStar.
- ZStar(ZStar.Fortune, String, Object...) - Constructor for class org.zeromq.ZStar
-
Creates a new ZStar.
- ZStar.Entourage - Interface in org.zeromq
-
Utility class with calls surrounding the execution of the Star.
- ZStar.Exit - Interface in org.zeromq
-
Control for the end of the remote operations.
- ZStar.Fortune - Interface in org.zeromq
- ZStar.Plateau - Class in org.zeromq
- ZStar.Set - Interface in org.zeromq
- ZStar.SimpleSet - Class in org.zeromq
- ZStar.Star - Interface in org.zeromq
-
Contract interface when acting in plain sight.
- ZStar.TimeTaker - Interface in org.zeromq
-
Utility class with callback for when the Star has finished its performances.
- ZThread - Class in org.zeromq
- ZThread() - Constructor for class org.zeromq.ZThread
- ZThread.IAttachedRunnable - Interface in org.zeromq
- ZThread.IDetachedRunnable - Interface in org.zeromq
- ZThread.ShimThread - Class in org.zeromq
- ZTicker - Class in org.zeromq.timer
-
Manages set of tickets and timers.
- ZTicker() - Constructor for class org.zeromq.timer.ZTicker
- ZTicker(Supplier<Long>) - Constructor for class org.zeromq.timer.ZTicker
- ZTicket - Class in org.zeromq.timer
-
Manages set of tickets.
- ZTicket() - Constructor for class org.zeromq.timer.ZTicket
- ZTicket(Supplier<Long>) - Constructor for class org.zeromq.timer.ZTicket
- ZTicket(Supplier<Long>, List<ZTicket.Ticket>) - Constructor for class org.zeromq.timer.ZTicket
- ZTicket.Ticket - Class in org.zeromq.timer
-
Opaque representation of a ticket.
- ZTimer - Class in org.zeromq.timer
-
Manages set of timers.
- ZTimer - Class in org.zeromq
-
Deprecated.scheduled for removal in future release. Please use
ZTimer
instead - ZTimer() - Constructor for class org.zeromq.timer.ZTimer
- ZTimer() - Constructor for class org.zeromq.ZTimer
-
Deprecated.
- ZTimer(Supplier<Long>) - Constructor for class org.zeromq.timer.ZTimer
- ZTimer.Handler - Interface in org.zeromq
-
Deprecated.use
TimerHandler
instead - ZTimer.Timer - Class in org.zeromq.timer
-
Opaque representation of a timer.
- ZTimer.Timer - Class in org.zeromq
-
Deprecated.use
ZTimer.Timer
instead
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form