- get() - Method in class org.apache.thrift.TByteArrayOutputStream
-
- getAcceptPolicy() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- getAcceptQueueSizePerThread() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- getArray() - Method in class org.apache.thrift.transport.TMemoryBuffer
-
- getAsyncClient(TNonblockingTransport) - Method in interface org.apache.thrift.async.TAsyncClientFactory
-
- getBuf() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
-
- getBuf() - Method in class org.apache.thrift.transport.TFileTransport.Event
-
- getBuffer() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
-
- getBuffer() - Method in class org.apache.thrift.transport.TFastFramedTransport
-
- getBuffer() - Method in class org.apache.thrift.transport.TFramedTransport
-
- getBuffer() - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- getBuffer() - Method in class org.apache.thrift.transport.TTransport
-
Access the protocol's underlying buffer directly.
- getBufferPosition() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
-
- getBufferPosition() - Method in class org.apache.thrift.transport.TFastFramedTransport
-
- getBufferPosition() - Method in class org.apache.thrift.transport.TFramedTransport
-
- getBufferPosition() - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- getBufferPosition() - Method in class org.apache.thrift.transport.TTransport
-
Return the index within the underlying buffer that specifies the next spot
that should be read from.
- getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
-
- getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.TFastFramedTransport
-
- getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.TFramedTransport
-
- getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.TTransport
-
Get the number of bytes remaining in the underlying buffer.
- getByValue(Class<? extends TEnum>, int) - Static method in class org.apache.thrift.TEnumHelper
-
Given a TEnum class and integer value, this method will return
the associated constant from the given TEnum class.
- getChunkNum() - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
-
- getChunkSize() - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
-
- getClient() - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- getClient(TProtocol) - Method in interface org.apache.thrift.TServiceClientFactory
-
Get a brand-new T using prot as both the input and output protocol.
- getClient(TProtocol, TProtocol) - Method in interface org.apache.thrift.TServiceClientFactory
-
Get a brand new T using the specified input and output protocols.
- getClientSocket(String, int, int) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a default SSL wrapped TSocket connected to the specified host and port.
- getClientSocket(String, int) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a default SSL wrapped TSocket connected to the specified host and port.
- getClientSocket(String, int, int, TSSLTransportFactory.TSSLTransportParameters) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a custom configured SSL wrapped TSocket.
- getCurChunk() - Method in class org.apache.thrift.transport.TFileTransport
-
- getEmptyArgsInstance() - Method in class org.apache.thrift.AsyncProcessFunction
-
- getEmptyArgsInstance() - Method in class org.apache.thrift.ProcessFunction
-
- getError() - Method in class org.apache.thrift.async.TAsyncClient
-
Get the client's error - returns null if no error
- getEventHandler() - Method in class org.apache.thrift.server.TServer
-
- getExecutorService() - Method in class org.apache.thrift.server.THsHaServer.Args
-
- getExecutorService() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- getFetchStats() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
-
- getFetchTimeoutSeconds() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
-
- getFieldDesc(F) - Method in class org.apache.thrift.TUnion
-
- getFieldName() - Method in interface org.apache.thrift.TFieldIdEnum
-
Get the field's name, exactly as in the IDL.
- getFieldValue(F) - Method in interface org.apache.thrift.TBase
-
Get a field's value by field variable.
- getFieldValue() - Method in class org.apache.thrift.TUnion
-
- getFieldValue(F) - Method in class org.apache.thrift.TUnion
-
- getFieldValue(int) - Method in class org.apache.thrift.TUnion
-
- getFilePointer() - Method in class org.apache.thrift.transport.TSimpleFileTransport
-
Return current file pointer position in bytes from beginning of file
- getFrameBuffer() - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- getInProtocolFactory() - Method in class org.apache.thrift.server.TExtensibleServlet
-
- getInputProtocol() - Method in class org.apache.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer
-
- getInputProtocol() - Method in class org.apache.thrift.TServiceClient
-
Get the TProtocol being used as the input (read) protocol.
- getInputStream() - Method in interface org.apache.thrift.transport.TSeekableFile
-
- getInputStream() - Method in class org.apache.thrift.transport.TStandardFile
-
- getMaxRecvBufBytesPerServer() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
-
- getMaxResponseBytes() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getMethodName() - Method in class org.apache.thrift.AsyncProcessFunction
-
- getMethodName() - Method in class org.apache.thrift.ProcessFunction
-
- getNumChunks() - Method in class org.apache.thrift.transport.TFileTransport
-
- getNumConnectErrorServers() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getNumInvalidFrameSize() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getNumOverflowedRecvBuf() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getNumReadCompletedServers() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getNumTotalServers() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getOffset() - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
-
- getOutProtocolFactory() - Method in class org.apache.thrift.server.TExtensibleServlet
-
- getOutputProtocol() - Method in class org.apache.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer
-
- getOutputProtocol() - Method in class org.apache.thrift.TServiceClient
-
Get the TProtocol being used as the output (write) protocol.
- getOutputStream() - Method in interface org.apache.thrift.transport.TSeekableFile
-
- getOutputStream() - Method in class org.apache.thrift.transport.TStandardFile
-
- getPort() - Method in class org.apache.thrift.transport.TNonblockingServerSocket
-
- getPos() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
-
- getProcessMapView() - Method in class org.apache.thrift.TBaseAsyncProcessor
-
- getProcessMapView() - Method in class org.apache.thrift.TBaseProcessor
-
- getProcessor() - Method in class org.apache.thrift.server.TExtensibleServlet
-
- getProcessor(TTransport) - Method in class org.apache.thrift.TProcessorFactory
-
- getProtocol(TTransport) - Method in class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- getProtocol(TTransport) - Method in class org.apache.thrift.protocol.TCompactProtocol.Factory
-
- getProtocol(TTransport) - Method in class org.apache.thrift.protocol.TJSONProtocol.Factory
-
- getProtocol(TTransport) - Method in interface org.apache.thrift.protocol.TProtocolFactory
-
- getProtocol(TTransport) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.Factory
-
- getProtocol(TTransport) - Method in class org.apache.thrift.protocol.TTupleProtocol.Factory
-
- getProtocolFactory() - Method in class org.apache.thrift.async.TAsyncClient
-
- getReadTime() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getRemaining() - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
-
- getRemaining() - Method in class org.apache.thrift.transport.TFileTransport.Event
-
- getRequestBuf() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
-
return a duplication of requestBuf, so that requestBuf will not
be modified by others.
- getResult(I, T) - Method in class org.apache.thrift.ProcessFunction
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.thrift.AsyncProcessFunction
-
- getRole() - Method in class org.apache.thrift.transport.TSaslClientTransport
-
- getRole() - Method in class org.apache.thrift.transport.TSaslServerTransport
-
- getRunnable(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.THsHaServer
-
- getRunnable(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.TThreadedSelectorServer
-
- getScheme() - Method in class org.apache.thrift.protocol.TProtocol
-
Scheme accessor
- getScheme() - Method in class org.apache.thrift.protocol.TTupleProtocol
-
- getScheme() - Method in interface org.apache.thrift.scheme.SchemeFactory
-
- getSelectorThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- getSequenceId() - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- getServerList() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
-
- getServerSocket() - Method in class org.apache.thrift.transport.TServerSocket
-
- getServerSocket(int) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a SSL wrapped TServerSocket bound to the specified port.
- getServerSocket(int, int) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a default SSL wrapped TServerSocket bound to the specified port
- getServerSocket(int, int, boolean, InetAddress) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a default SSL wrapped TServerSocket bound to the specified port and interface
- getServerSocket(int, int, InetAddress, TSSLTransportFactory.TSSLTransportParameters) - Static method in class org.apache.thrift.transport.TSSLTransportFactory
-
Get a configured SSL wrapped TServerSocket bound to the specified port and interface.
- getSetField() - Method in class org.apache.thrift.TUnion
-
- getSize() - Method in class org.apache.thrift.transport.TFileTransport.Event
-
- getSocket() - Method in class org.apache.thrift.transport.TSocket
-
Returns a reference to the underlying socket.
- getSocketChannel() - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Returns a reference to the underlying SocketChannel.
- getStartTime() - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- getState() - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- getStopTimeoutUnit() - Method in class org.apache.thrift.server.THsHaServer.Args
-
- getStopTimeoutUnit() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- getStopTimeoutVal() - Method in class org.apache.thrift.server.THsHaServer.Args
-
- getStopTimeoutVal() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- getStructDesc() - Method in class org.apache.thrift.TUnion
-
- getStructMetaDataMap(Class<? extends TBase>) - Static method in class org.apache.thrift.meta_data.FieldMetaData
-
Returns a map with metadata (i.e.
- getTailPolicy() - Method in class org.apache.thrift.transport.TFileTransport
-
Get File Tailing Policy
- getThriftFieldId() - Method in interface org.apache.thrift.TFieldIdEnum
-
Get the Thrift field id for the named field.
- getTimeout() - Method in class org.apache.thrift.async.TAsyncClient
-
- getTimeoutTimestamp() - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- getTotalRecvBufBytes() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- getTransport() - Method in class org.apache.thrift.protocol.TProtocol
-
Transport accessor
- getTransport(TTransport) - Method in class org.apache.thrift.transport.TFastFramedTransport.Factory
-
- getTransport(TTransport) - Method in class org.apache.thrift.transport.TFramedTransport.Factory
-
- getTransport(TTransport) - Method in class org.apache.thrift.transport.THttpClient.Factory
-
- getTransport(TTransport) - Method in class org.apache.thrift.transport.TSaslServerTransport.Factory
-
Get a new TSaslServerTransport
instance, or reuse the
existing one if a TSaslServerTransport
has already been
created before using the given TTransport
as an underlying
transport.
- getTransport(TTransport) - Method in class org.apache.thrift.transport.TTransportFactory
-
Return a wrapped instance of the base Transport.
- getType() - Method in exception org.apache.thrift.protocol.TProtocolException
-
- getType() - Method in exception org.apache.thrift.TApplicationException
-
- getType() - Method in exception org.apache.thrift.transport.TTransportException
-
- getTypedefName() - Method in class org.apache.thrift.meta_data.FieldValueMetaData
-
- getValue() - Method in interface org.apache.thrift.TEnum
-
- getWorkerThreads() - Method in class org.apache.thrift.server.THsHaServer.Args
-
- getWorkerThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- gracefullyShutdownInvokerPool() - Method in class org.apache.thrift.server.THsHaServer
-
- gracefullyShutdownInvokerPool() - Method in class org.apache.thrift.server.TThreadedSelectorServer
-
- guessProtocolFactory(byte[], TProtocolFactory) - Static method in class org.apache.thrift.protocol.TProtocolUtil
-
Attempt to determine the protocol used to serialize some data.
- read() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONBaseContext
-
- read() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONListContext
-
- read() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONPairContext
-
- read() - Method in class org.apache.thrift.protocol.TJSONProtocol.LookaheadReader
-
- read(TProtocol, T) - Method in interface org.apache.thrift.scheme.IScheme
-
- read() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
Give this FrameBuffer a chance to read.
- read(TProtocol) - Static method in exception org.apache.thrift.TApplicationException
-
- read(TProtocol) - Method in interface org.apache.thrift.TBase
-
Reads the TObject from the given input protocol.
- read(byte[], int, int) - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TFastFramedTransport
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TFileTransport
-
Reads up to len bytes into buffer buf, starting at offset off.
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TFramedTransport
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.THttpClient
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TIOStreamTransport
-
Reads from the underlying input stream if not null.
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryBuffer
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- read(ByteBuffer) - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Perform a nonblocking read into buffer.
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Reads from the underlying input stream if not null.
- read(ByteBuffer) - Method in class org.apache.thrift.transport.TNonblockingTransport
-
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TSimpleFileTransport
-
Read up to len many bytes into buf at offset
- read(byte[], int, int) - Method in class org.apache.thrift.transport.TTransport
-
Reads up to len bytes into buffer buf, starting at offset off.
- read(TProtocol) - Method in class org.apache.thrift.TUnion
-
- readAll(byte[], int, int) - Method in class org.apache.thrift.transport.TFileTransport
-
Cloned from TTransport.java:readAll().
- readAll(byte[], int, int) - Method in class org.apache.thrift.transport.TTransport
-
Guarantees that all of len bytes are actually read off the transport.
- readBinary() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readBinary() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a byte[] from the wire.
- readBinary() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readBinary() - Method in class org.apache.thrift.protocol.TProtocol
-
- readBinary() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readBinary() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readBitSet(int) - Method in class org.apache.thrift.protocol.TTupleProtocol
-
- readBool() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readBool() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a boolean off the wire.
- readBool() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readBool() - Method in class org.apache.thrift.protocol.TProtocol
-
- readBool() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readBool() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readByte() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readByte() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a single byte off the wire.
- readByte() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readByte() - Method in class org.apache.thrift.protocol.TProtocol
-
- readByte() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readByte() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readDouble() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readDouble() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
No magic here - just read a double off the wire.
- readDouble() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readDouble() - Method in class org.apache.thrift.protocol.TProtocol
-
- readDouble() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readDouble() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readFieldBegin() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readFieldBegin() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a field header off the wire.
- readFieldBegin() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readFieldBegin() - Method in class org.apache.thrift.protocol.TProtocol
-
- readFieldBegin() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readFieldBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readFieldEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readFieldEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- readFieldEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readFieldEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- readFieldEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readFieldEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readI16() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readI16() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read an i16 from the wire as a zigzag varint.
- readI16() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readI16() - Method in class org.apache.thrift.protocol.TProtocol
-
- readI16() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readI16() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readI32() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readI32() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read an i32 from the wire as a zigzag varint.
- readI32() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readI32() - Method in class org.apache.thrift.protocol.TProtocol
-
- readI32() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readI32() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readI64() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readI64() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read an i64 from the wire as a zigzag varint.
- readI64() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readI64() - Method in class org.apache.thrift.protocol.TProtocol
-
- readI64() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readI64() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readJSONSyntaxChar(byte[]) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readListBegin() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readListBegin() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a list header off the wire.
- readListBegin() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readListBegin() - Method in class org.apache.thrift.protocol.TProtocol
-
- readListBegin() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readListBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readListEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readListEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- readListEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readListEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- readListEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readListEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readMapBegin() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readMapBegin() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a map header off the wire.
- readMapBegin() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readMapBegin() - Method in class org.apache.thrift.protocol.TProtocol
-
- readMapBegin() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readMapBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readMapEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readMapEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- readMapEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readMapEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- readMapEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readMapEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readMessageBegin() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
Reading methods.
- readMessageBegin() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a message header.
- readMessageBegin() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readMessageBegin() - Method in class org.apache.thrift.protocol.TProtocol
-
Reading methods.
- readMessageBegin() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readMessageBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
Reading methods.
- readMessageEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readMessageEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- readMessageEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readMessageEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- readMessageEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readMessageEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readSetBegin() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readSetBegin() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a set header off the wire.
- readSetBegin() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readSetBegin() - Method in class org.apache.thrift.protocol.TProtocol
-
- readSetBegin() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readSetBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readSetEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readSetEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- readSetEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readSetEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- readSetEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readSetEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readString() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readString() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Reads a byte[] (via readBinary), and then UTF-8 decodes it.
- readString() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readString() - Method in class org.apache.thrift.protocol.TProtocol
-
- readString() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readString() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readStringBody(int) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readStringBody(int) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readStructBegin() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readStructBegin() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Read a struct begin.
- readStructBegin() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readStructBegin() - Method in class org.apache.thrift.protocol.TProtocol
-
- readStructBegin() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readStructBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- readStructEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- readStructEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Doesn't actually consume any wire data, just removes the last field for
this struct from the field stack.
- readStructEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- readStructEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- readStructEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- readStructEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- receiveBase(TBase, String) - Method in class org.apache.thrift.TServiceClient
-
- registerProcessor(String, TProcessor) - Method in class org.apache.thrift.TMultiplexedProcessor
-
'Register' a service with this TMultiplexedProcessor
.
- registerSelector(Selector) - Method in class org.apache.thrift.transport.TNonblockingServerSocket
-
- registerSelector(Selector) - Method in class org.apache.thrift.transport.TNonblockingServerTransport
-
- registerSelector(Selector, int) - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Register the new SocketChannel with our Selector, indicating
we'd like to be notified when it's ready for I/O.
- registerSelector(Selector, int) - Method in class org.apache.thrift.transport.TNonblockingTransport
-
- REPLY - Static variable in class org.apache.thrift.protocol.TMessageType
-
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.AbstractNonblockingServer
-
Perform an invocation.
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.THsHaServer
-
We override the standard invoke method here to queue the invocation for
invoker service instead of immediately invoking.
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.TNonblockingServer
-
Perform an invocation.
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.TThreadedSelectorServer
-
We override the standard invoke method here to queue the invocation for
invoker service instead of immediately invoking.
- requestSelectInterestChange(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
-
Add FrameBuffer to the list of select interest changes and wake up the
selector if it's blocked.
- requestSelectInterestChange() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
When this FrameBuffer needs to change its select interests and execution
might not be in its select thread, then this method will make sure the
interest change gets done when the select thread wakes back up.
- requestTimeout - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
-
- requestTimeout(int) - Method in class org.apache.thrift.server.TThreadPoolServer.Args
-
- requestTimeoutUnit - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
-
- requestTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.TThreadPoolServer.Args
-
- requireClientAuth(boolean) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Set if client authentication is required
- REQUIRED - Static variable in class org.apache.thrift.TFieldRequirementType
-
- requirementType - Variable in class org.apache.thrift.meta_data.FieldMetaData
-
- reset() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- reset() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- reset() - Method in class org.apache.thrift.protocol.TProtocol
-
Reset any internal state back to a blank slate.
- reset() - Method in class org.apache.thrift.TByteArrayOutputStream
-
- reset() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
-
- reset(byte[]) - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- reset(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- resizeIfNecessary(int) - Method in class org.apache.thrift.transport.AutoExpandingBuffer
-
- response_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
- responseReady() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
After the processor has processed the invocation, whatever thread is
managing invocations should call this method on this FrameBuffer so we
know it's time to start trying to write again.
- retries_ - Variable in enum org.apache.thrift.transport.TFileTransport.TailPolicy
-
Number of retries before giving up
if 0, no retries
if -1, retry forever
- rightSize(ByteBuffer) - Static method in class org.apache.thrift.TBaseHelper
-
- run() - Method in class org.apache.thrift.server.TNonblockingServer.SelectAcceptThread
-
The work loop.
- run() - Method in class org.apache.thrift.server.TThreadedSelectorServer.AcceptThread
-
The work loop.
- run() - Method in class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
-
The work loop.
- SchemeFactory - Interface in org.apache.thrift.scheme
-
- seek(long) - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
-
- seek(long) - Method in interface org.apache.thrift.transport.TSeekableFile
-
- seek(long) - Method in class org.apache.thrift.transport.TSimpleFileTransport
-
Move file pointer to specified offset, new read/write calls will act here
- seek(long) - Method in class org.apache.thrift.transport.TStandardFile
-
- seekToChunk(int) - Method in class org.apache.thrift.transport.TFileTransport
-
- seekToEnd() - Method in class org.apache.thrift.transport.TFileTransport
-
- selectInterestChanges - Variable in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
-
- selectionKey_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
- selector - Variable in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
-
- selectorThreads - Variable in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
The number of threads for selecting on already-accepted connections
- selectorThreads(int) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- selectThread_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
- sendBase(String, TBase) - Method in class org.apache.thrift.TServiceClient
-
- sendResponse(AbstractNonblockingServer.AsyncFrameBuffer, TBase, byte, int) - Method in class org.apache.thrift.AsyncProcessFunction
-
- SEPARATOR - Static variable in class org.apache.thrift.protocol.TMultiplexedProtocol
-
Used to delimit the service name from the function name
- seqid - Variable in class org.apache.thrift.protocol.TMessage
-
- seqid_ - Variable in class org.apache.thrift.TServiceClient
-
- serialize(TBase) - Method in class org.apache.thrift.TSerializer
-
Serialize the Thrift object into a byte array.
- serve() - Method in class org.apache.thrift.server.AbstractNonblockingServer
-
Begin accepting connections and processing invocations.
- serve() - Method in class org.apache.thrift.server.TServer
-
The run method fires up the server and gets things going.
- serve() - Method in class org.apache.thrift.server.TSimpleServer
-
- serve() - Method in class org.apache.thrift.server.TThreadPoolServer
-
- ServerContext - Interface in org.apache.thrift.server
-
- serverSocket(ServerSocket) - Method in class org.apache.thrift.transport.TServerSocket.ServerSocketTransportArgs
-
- serverTransport_ - Variable in class org.apache.thrift.server.TServer
-
Server transport
- SET - Static variable in class org.apache.thrift.protocol.TType
-
- setAvailable(int) - Method in class org.apache.thrift.transport.TFileTransport.Event
-
- setBit(byte, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
-
Returns v, with the bit at position set to 1 or 0 depending on value.
- setBit(short, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
-
- setBit(int, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
-
- setBit(long, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
-
- setConnectTimeout(int) - Method in class org.apache.thrift.transport.THttpClient
-
- setCustomHeader(String, String) - Method in class org.apache.thrift.transport.THttpClient
-
- setCustomHeaders(Collection<Map.Entry<String, String>>) - Method in class org.apache.thrift.server.TExtensibleServlet
-
- setCustomHeaders(Collection<Map.Entry<String, String>>) - Method in class org.apache.thrift.server.TServlet
-
- setCustomHeaders(Map<String, String>) - Method in class org.apache.thrift.transport.THttpClient
-
- setField_ - Variable in class org.apache.thrift.TUnion
-
- setFieldValue(F, Object) - Method in interface org.apache.thrift.TBase
-
Set a field's value by field variable.
- setFieldValue(F, Object) - Method in class org.apache.thrift.TUnion
-
- setFieldValue(int, Object) - Method in class org.apache.thrift.TUnion
-
- setKeyStore(String, String, String, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Set the keystore, password, certificate type and the store type
- setKeyStore(String, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Set the keystore and password
- setMaxResponseBytes(int) - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- setMaxSkipDepth(int) - Static method in class org.apache.thrift.protocol.TProtocolUtil
-
Specifies the maximum recursive depth that the skip function will
traverse before throwing a TException.
- SetMetaData - Class in org.apache.thrift.meta_data
-
- SetMetaData(byte, FieldValueMetaData) - Constructor for class org.apache.thrift.meta_data.SetMetaData
-
- setNumTotalServers(int) - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- setReadTime(long) - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- setReadTimeout(int) - Method in class org.apache.thrift.transport.THttpClient
-
- setServerEventHandler(TServerEventHandler) - Method in class org.apache.thrift.server.TServer
-
- setServing(boolean) - Method in class org.apache.thrift.server.TServer
-
- setTailPolicy(TFileTransport.TailPolicy) - Method in class org.apache.thrift.transport.TFileTransport
-
Set file Tailing Policy
- setTimeout(long) - Method in class org.apache.thrift.async.TAsyncClient
-
- setTimeout(int) - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Sets the socket timeout, although this implementation never uses blocking operations so it is unused.
- setTimeout(int) - Method in class org.apache.thrift.transport.TSocket
-
Sets the socket timeout
- setTrustStore(String, String, String, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Set the truststore, password, certificate type and the store type
- setTrustStore(String, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Set the truststore and password
- ShortStack - Class in org.apache.thrift
-
ShortStack is a short-specific Stack implementation written for the express
purpose of very fast operations on TCompactProtocol's field id stack.
- ShortStack(int) - Constructor for class org.apache.thrift.ShortStack
-
- size - Variable in class org.apache.thrift.protocol.TList
-
- size - Variable in class org.apache.thrift.protocol.TMap
-
- size - Variable in class org.apache.thrift.protocol.TSet
-
- SIZE_LIMIT - Static variable in exception org.apache.thrift.protocol.TProtocolException
-
- skip(TProtocol, byte) - Static method in class org.apache.thrift.protocol.TProtocolUtil
-
Skips over the next data element from the provided input TProtocol object.
- skip(TProtocol, byte, int) - Static method in class org.apache.thrift.protocol.TProtocolUtil
-
Skips over the next data element from the provided input TProtocol object.
- skip(int) - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
-
- StandardScheme<T extends TBase> - Class in org.apache.thrift.scheme
-
- StandardScheme() - Constructor for class org.apache.thrift.scheme.StandardScheme
-
- standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.thrift.TUnion
-
Implementation should be generated to read the right stuff from the wire
based on the field header.
- standardSchemeWriteValue(TProtocol) - Method in class org.apache.thrift.TUnion
-
- start(I, T, AsyncMethodCallback<R>) - Method in class org.apache.thrift.AsyncProcessFunction
-
- startConnect() - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Non-blocking connection initialization.
- startConnect() - Method in class org.apache.thrift.transport.TNonblockingTransport
-
Non-blocking connection initialization.
- startListening() - Method in class org.apache.thrift.server.AbstractNonblockingServer
-
Have the server transport start accepting connections.
- startThreads() - Method in class org.apache.thrift.server.AbstractNonblockingServer
-
Starts any threads required for serving.
- startThreads() - Method in class org.apache.thrift.server.TNonblockingServer
-
Start the selector thread to deal with accepts and client messages.
- startThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServer
-
Start the accept and selector threads running to deal with clients.
- state_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
- stop() - Method in class org.apache.thrift.async.TAsyncClientManager
-
- STOP - Static variable in class org.apache.thrift.protocol.TType
-
- stop() - Method in class org.apache.thrift.server.TNonblockingServer
-
Stop serving and shut everything down.
- stop() - Method in class org.apache.thrift.server.TServer
-
Stop the server.
- stop() - Method in class org.apache.thrift.server.TSimpleServer
-
- stop() - Method in class org.apache.thrift.server.TThreadedSelectorServer
-
Stop serving and shut everything down.
- stop() - Method in class org.apache.thrift.server.TThreadPoolServer
-
- stopListening() - Method in class org.apache.thrift.server.AbstractNonblockingServer
-
Stop listening for connections.
- stopTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.THsHaServer.Args
-
- stopTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- stopTimeoutUnit - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
-
- stopTimeoutVal(int) - Method in class org.apache.thrift.server.THsHaServer.Args
-
- stopTimeoutVal(int) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- stopTimeoutVal - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
-
- strictRead_ - Variable in class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- strictRead_ - Variable in class org.apache.thrift.protocol.TBinaryProtocol
-
- strictWrite_ - Variable in class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- strictWrite_ - Variable in class org.apache.thrift.protocol.TBinaryProtocol
-
- STRING - Static variable in class org.apache.thrift.protocol.TType
-
- stringLengthLimit_ - Variable in class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- STRUCT - Static variable in class org.apache.thrift.protocol.TType
-
- structClass - Variable in class org.apache.thrift.meta_data.StructMetaData
-
- StructMetaData - Class in org.apache.thrift.meta_data
-
- StructMetaData(byte, Class<? extends TBase>) - Constructor for class org.apache.thrift.meta_data.StructMetaData
-
- TApplicationException - Exception in org.apache.thrift
-
Application level exception
- TApplicationException() - Constructor for exception org.apache.thrift.TApplicationException
-
- TApplicationException(int) - Constructor for exception org.apache.thrift.TApplicationException
-
- TApplicationException(int, String) - Constructor for exception org.apache.thrift.TApplicationException
-
- TApplicationException(String) - Constructor for exception org.apache.thrift.TApplicationException
-
- TAsyncClient - Class in org.apache.thrift.async
-
- TAsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.thrift.async.TAsyncClient
-
- TAsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport, long) - Constructor for class org.apache.thrift.async.TAsyncClient
-
- TAsyncClientFactory<T extends TAsyncClient> - Interface in org.apache.thrift.async
-
- TAsyncClientManager - Class in org.apache.thrift.async
-
Contains selector thread which transitions method call objects
- TAsyncClientManager() - Constructor for class org.apache.thrift.async.TAsyncClientManager
-
- TAsyncMethodCall<T> - Class in org.apache.thrift.async
-
Encapsulates an async method call
Need to generate:
- private void write_args(TProtocol protocol)
- public T getResult() throws , , ...
- TAsyncMethodCall(TAsyncClient, TProtocolFactory, TNonblockingTransport, AsyncMethodCallback<T>, boolean) - Constructor for class org.apache.thrift.async.TAsyncMethodCall
-
- TAsyncMethodCall.State - Enum in org.apache.thrift.async
-
- TBase<T extends TBase<?,?>,F extends TFieldIdEnum> - Interface in org.apache.thrift
-
Generic base interface for generated Thrift objects.
- TBaseAsyncProcessor<I> - Class in org.apache.thrift
-
- TBaseAsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.thrift.TBaseAsyncProcessor
-
- TBaseHelper - Class in org.apache.thrift
-
- TBaseProcessor<I> - Class in org.apache.thrift
-
- TBaseProcessor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.thrift.TBaseProcessor
-
- TBinaryProtocol - Class in org.apache.thrift.protocol
-
Binary protocol implementation for thrift.
- TBinaryProtocol(TTransport) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol
-
Constructor
- TBinaryProtocol(TTransport, boolean, boolean) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol
-
- TBinaryProtocol(TTransport, long, long, boolean, boolean) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol
-
- TBinaryProtocol.Factory - Class in org.apache.thrift.protocol
-
Factory
- TBinaryProtocol.Factory() - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- TBinaryProtocol.Factory(boolean, boolean) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- TBinaryProtocol.Factory(boolean, boolean, long, long) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
-
- TByteArrayOutputStream - Class in org.apache.thrift
-
Class that allows access to the underlying buf without doing deep
copies on it.
- TByteArrayOutputStream(int) - Constructor for class org.apache.thrift.TByteArrayOutputStream
-
- TByteArrayOutputStream() - Constructor for class org.apache.thrift.TByteArrayOutputStream
-
- TCompactProtocol - Class in org.apache.thrift.protocol
-
TCompactProtocol2 is the Java implementation of the compact protocol specified
in THRIFT-110.
- TCompactProtocol(TTransport, long, long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol
-
Create a TCompactProtocol.
- TCompactProtocol(TTransport, long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol
-
Deprecated.
Use constructor specifying both string limit and container limit instead
- TCompactProtocol(TTransport) - Constructor for class org.apache.thrift.protocol.TCompactProtocol
-
Create a TCompactProtocol.
- TCompactProtocol.Factory - Class in org.apache.thrift.protocol
-
TProtocolFactory that produces TCompactProtocols.
- TCompactProtocol.Factory() - Constructor for class org.apache.thrift.protocol.TCompactProtocol.Factory
-
- TCompactProtocol.Factory(long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol.Factory
-
- TCompactProtocol.Factory(long, long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol.Factory
-
- TDeserializer - Class in org.apache.thrift
-
Generic utility for easily deserializing objects from a byte array or Java
String.
- TDeserializer() - Constructor for class org.apache.thrift.TDeserializer
-
Create a new TDeserializer that uses the TBinaryProtocol by default.
- TDeserializer(TProtocolFactory) - Constructor for class org.apache.thrift.TDeserializer
-
Create a new TDeserializer.
- TEnum - Interface in org.apache.thrift
-
- TEnumHelper - Class in org.apache.thrift
-
Utility class with static methods for interacting with TEnum
- TEnumHelper() - Constructor for class org.apache.thrift.TEnumHelper
-
- testBit(byte, int) - Static method in class org.apache.thrift.EncodingUtils
-
Bitfield utilities.
- testBit(short, int) - Static method in class org.apache.thrift.EncodingUtils
-
- testBit(int, int) - Static method in class org.apache.thrift.EncodingUtils
-
- testBit(long, int) - Static method in class org.apache.thrift.EncodingUtils
-
- TException - Exception in org.apache.thrift
-
Generic exception class for Thrift.
- TException() - Constructor for exception org.apache.thrift.TException
-
- TException(String) - Constructor for exception org.apache.thrift.TException
-
- TException(Throwable) - Constructor for exception org.apache.thrift.TException
-
- TException(String, Throwable) - Constructor for exception org.apache.thrift.TException
-
- TExtensibleServlet - Class in org.apache.thrift.server
-
Servlet implementation class ThriftServer, that allows
TProcessor
and
TProtocolFactory
to be supplied after the
GenericServlet.init()
method has
finished.
- TExtensibleServlet() - Constructor for class org.apache.thrift.server.TExtensibleServlet
-
- TFastFramedTransport - Class in org.apache.thrift.transport
-
This transport is wire compatible with
TFramedTransport
, but makes
use of reusable, expanding read and write buffers in order to avoid
allocating new byte[]s all the time.
- TFastFramedTransport(TTransport) - Constructor for class org.apache.thrift.transport.TFastFramedTransport
-
- TFastFramedTransport(TTransport, int) - Constructor for class org.apache.thrift.transport.TFastFramedTransport
-
- TFastFramedTransport(TTransport, int, int) - Constructor for class org.apache.thrift.transport.TFastFramedTransport
-
- TFastFramedTransport.Factory - Class in org.apache.thrift.transport
-
- TFastFramedTransport.Factory() - Constructor for class org.apache.thrift.transport.TFastFramedTransport.Factory
-
- TFastFramedTransport.Factory(int) - Constructor for class org.apache.thrift.transport.TFastFramedTransport.Factory
-
- TFastFramedTransport.Factory(int, int) - Constructor for class org.apache.thrift.transport.TFastFramedTransport.Factory
-
- TField - Class in org.apache.thrift.protocol
-
Helper class that encapsulates field metadata.
- TField() - Constructor for class org.apache.thrift.protocol.TField
-
- TField(String, byte, short) - Constructor for class org.apache.thrift.protocol.TField
-
- TFieldIdEnum - Interface in org.apache.thrift
-
Interface for all generated struct Fields objects.
- TFieldRequirementType - Class in org.apache.thrift
-
Requirement type constants.
- TFieldRequirementType() - Constructor for class org.apache.thrift.TFieldRequirementType
-
- TFileProcessor - Class in org.apache.thrift.transport
-
FileProcessor: helps in processing files generated by TFileTransport.
- TFileProcessor(TProcessor, TProtocolFactory, TFileTransport, TTransport) - Constructor for class org.apache.thrift.transport.TFileProcessor
-
- TFileProcessor(TProcessor, TProtocolFactory, TProtocolFactory, TFileTransport, TTransport) - Constructor for class org.apache.thrift.transport.TFileProcessor
-
- TFileTransport - Class in org.apache.thrift.transport
-
FileTransport implementation of the TTransport interface.
- TFileTransport(String, boolean) - Constructor for class org.apache.thrift.transport.TFileTransport
-
File Transport ctor
- TFileTransport(TSeekableFile, boolean) - Constructor for class org.apache.thrift.transport.TFileTransport
-
File Transport ctor
- TFileTransport.ChunkState - Class in org.apache.thrift.transport
-
- TFileTransport.ChunkState() - Constructor for class org.apache.thrift.transport.TFileTransport.ChunkState
-
- TFileTransport.ChunkState(int) - Constructor for class org.apache.thrift.transport.TFileTransport.ChunkState
-
- TFileTransport.Event - Class in org.apache.thrift.transport
-
- TFileTransport.Event(byte[]) - Constructor for class org.apache.thrift.transport.TFileTransport.Event
-
Initialize an event.
- TFileTransport.TailPolicy - Enum in org.apache.thrift.transport
-
- TFileTransport.TruncableBufferedInputStream - Class in org.apache.thrift.transport
-
- TFileTransport.TruncableBufferedInputStream(InputStream) - Constructor for class org.apache.thrift.transport.TFileTransport.TruncableBufferedInputStream
-
- TFileTransport.TruncableBufferedInputStream(InputStream, int) - Constructor for class org.apache.thrift.transport.TFileTransport.TruncableBufferedInputStream
-
- TFramedTransport - Class in org.apache.thrift.transport
-
TFramedTransport is a buffered TTransport that ensures a fully read message
every time by preceding messages with a 4-byte frame size.
- TFramedTransport(TTransport, int) - Constructor for class org.apache.thrift.transport.TFramedTransport
-
Constructor wraps around another transport
- TFramedTransport(TTransport) - Constructor for class org.apache.thrift.transport.TFramedTransport
-
- TFramedTransport.Factory - Class in org.apache.thrift.transport
-
- TFramedTransport.Factory() - Constructor for class org.apache.thrift.transport.TFramedTransport.Factory
-
- TFramedTransport.Factory(int) - Constructor for class org.apache.thrift.transport.TFramedTransport.Factory
-
- THsHaServer - Class in org.apache.thrift.server
-
An extension of the TNonblockingServer to a Half-Sync/Half-Async server.
- THsHaServer(THsHaServer.Args) - Constructor for class org.apache.thrift.server.THsHaServer
-
Create the server with the specified Args configuration
- THsHaServer.Args - Class in org.apache.thrift.server
-
- THsHaServer.Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.THsHaServer.Args
-
- THttpClient - Class in org.apache.thrift.transport
-
HTTP implementation of the TTransport interface.
- THttpClient(String) - Constructor for class org.apache.thrift.transport.THttpClient
-
- THttpClient(String, HttpClient) - Constructor for class org.apache.thrift.transport.THttpClient
-
- THttpClient.Factory - Class in org.apache.thrift.transport
-
- THttpClient.Factory(String) - Constructor for class org.apache.thrift.transport.THttpClient.Factory
-
- THttpClient.Factory(String, HttpClient) - Constructor for class org.apache.thrift.transport.THttpClient.Factory
-
- TIMED_OUT - Static variable in exception org.apache.thrift.transport.TTransportException
-
- timeout_ - Variable in enum org.apache.thrift.transport.TFileTransport.TailPolicy
-
Time in milliseconds to sleep before next read
If 0, no sleep
- TIOStreamTransport - Class in org.apache.thrift.transport
-
This is the most commonly used base transport.
- TIOStreamTransport() - Constructor for class org.apache.thrift.transport.TIOStreamTransport
-
Subclasses can invoke the default constructor and then assign the input
streams in the open method.
- TIOStreamTransport(InputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
-
Input stream constructor.
- TIOStreamTransport(OutputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
-
Output stream constructor.
- TIOStreamTransport(InputStream, OutputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
-
Two-way stream constructor.
- TJSONProtocol - Class in org.apache.thrift.protocol
-
JSON protocol implementation for thrift.
- TJSONProtocol(TTransport) - Constructor for class org.apache.thrift.protocol.TJSONProtocol
-
Constructor
- TJSONProtocol(TTransport, boolean) - Constructor for class org.apache.thrift.protocol.TJSONProtocol
-
- TJSONProtocol.Factory - Class in org.apache.thrift.protocol
-
Factory for JSON protocol objects
- TJSONProtocol.Factory() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.Factory
-
- TJSONProtocol.Factory(boolean) - Constructor for class org.apache.thrift.protocol.TJSONProtocol.Factory
-
- TJSONProtocol.JSONBaseContext - Class in org.apache.thrift.protocol
-
- TJSONProtocol.JSONBaseContext() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.JSONBaseContext
-
- TJSONProtocol.JSONListContext - Class in org.apache.thrift.protocol
-
- TJSONProtocol.JSONListContext() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.JSONListContext
-
- TJSONProtocol.JSONPairContext - Class in org.apache.thrift.protocol
-
- TJSONProtocol.JSONPairContext() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.JSONPairContext
-
- TJSONProtocol.LookaheadReader - Class in org.apache.thrift.protocol
-
- TJSONProtocol.LookaheadReader() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.LookaheadReader
-
- TList - Class in org.apache.thrift.protocol
-
Helper class that encapsulates list metadata.
- TList() - Constructor for class org.apache.thrift.protocol.TList
-
- TList(byte, int) - Constructor for class org.apache.thrift.protocol.TList
-
- TMap - Class in org.apache.thrift.protocol
-
Helper class that encapsulates map metadata.
- TMap() - Constructor for class org.apache.thrift.protocol.TMap
-
- TMap(byte, byte, int) - Constructor for class org.apache.thrift.protocol.TMap
-
- TMemoryBuffer - Class in org.apache.thrift.transport
-
Memory buffer-based implementation of the TTransport interface.
- TMemoryBuffer(int) - Constructor for class org.apache.thrift.transport.TMemoryBuffer
-
Create a TMemoryBuffer with an initial buffer size of size.
- TMemoryInputTransport - Class in org.apache.thrift.transport
-
- TMemoryInputTransport() - Constructor for class org.apache.thrift.transport.TMemoryInputTransport
-
- TMemoryInputTransport(byte[]) - Constructor for class org.apache.thrift.transport.TMemoryInputTransport
-
- TMemoryInputTransport(byte[], int, int) - Constructor for class org.apache.thrift.transport.TMemoryInputTransport
-
- TMessage - Class in org.apache.thrift.protocol
-
Helper class that encapsulates struct metadata.
- TMessage() - Constructor for class org.apache.thrift.protocol.TMessage
-
- TMessage(String, byte, int) - Constructor for class org.apache.thrift.protocol.TMessage
-
- TMessageType - Class in org.apache.thrift.protocol
-
Message type constants in the Thrift protocol.
- TMessageType() - Constructor for class org.apache.thrift.protocol.TMessageType
-
- TMultiplexedProcessor - Class in org.apache.thrift
-
TMultiplexedProcessor
is a TProcessor
allowing
a single TServer
to provide multiple services.
- TMultiplexedProcessor() - Constructor for class org.apache.thrift.TMultiplexedProcessor
-
- TMultiplexedProtocol - Class in org.apache.thrift.protocol
-
TMultiplexedProtocol
is a protocol-independent concrete decorator
that allows a Thrift client to communicate with a multiplexing Thrift server,
by prepending the service name to the function name during function calls.
- TMultiplexedProtocol(TProtocol, String) - Constructor for class org.apache.thrift.protocol.TMultiplexedProtocol
-
Wrap the specified protocol, allowing it to be used to communicate with a
multiplexing server.
- TNonblockingMultiFetchClient - Class in org.apache.thrift
-
This class uses a single thread to set up non-blocking sockets to a set
of remote servers (hostname and port pairs), and sends a same request to
all these servers.
- TNonblockingMultiFetchClient(int, int, ByteBuffer, List<InetSocketAddress>) - Constructor for class org.apache.thrift.TNonblockingMultiFetchClient
-
- TNonblockingMultiFetchStats - Class in org.apache.thrift
-
This class keeps track of statistics for TNonblockinMultiFetchClient.
- TNonblockingMultiFetchStats() - Constructor for class org.apache.thrift.TNonblockingMultiFetchStats
-
- TNonblockingServer - Class in org.apache.thrift.server
-
A nonblocking TServer implementation.
- TNonblockingServer(AbstractNonblockingServer.AbstractNonblockingServerArgs) - Constructor for class org.apache.thrift.server.TNonblockingServer
-
- TNonblockingServer.Args - Class in org.apache.thrift.server
-
- TNonblockingServer.Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TNonblockingServer.Args
-
- TNonblockingServer.SelectAcceptThread - Class in org.apache.thrift.server
-
The thread that will be doing all the selecting, managing new connections
and those that still need to be read.
- TNonblockingServer.SelectAcceptThread(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TNonblockingServer.SelectAcceptThread
-
Set up the thread that will handle the non-blocking accepts, reads, and
writes.
- TNonblockingServerSocket - Class in org.apache.thrift.transport
-
Wrapper around ServerSocketChannel
- TNonblockingServerSocket(int) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
-
Creates just a port listening server socket
- TNonblockingServerSocket(int, int) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
-
Creates just a port listening server socket
- TNonblockingServerSocket(InetSocketAddress) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
-
- TNonblockingServerSocket(InetSocketAddress, int) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
-
- TNonblockingServerSocket(TNonblockingServerSocket.NonblockingAbstractServerSocketArgs) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
-
- TNonblockingServerSocket.NonblockingAbstractServerSocketArgs - Class in org.apache.thrift.transport
-
- TNonblockingServerSocket.NonblockingAbstractServerSocketArgs() - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket.NonblockingAbstractServerSocketArgs
-
- TNonblockingServerTransport - Class in org.apache.thrift.transport
-
Server transport that can be operated in a nonblocking fashion.
- TNonblockingServerTransport() - Constructor for class org.apache.thrift.transport.TNonblockingServerTransport
-
- TNonblockingSocket - Class in org.apache.thrift.transport
-
Transport for use with async client.
- TNonblockingSocket(String, int) - Constructor for class org.apache.thrift.transport.TNonblockingSocket
-
- TNonblockingSocket(String, int, int) - Constructor for class org.apache.thrift.transport.TNonblockingSocket
-
Create a new nonblocking socket transport that will be connected to host:port.
- TNonblockingSocket(SocketChannel) - Constructor for class org.apache.thrift.transport.TNonblockingSocket
-
Constructor that takes an already created socket.
- TNonblockingTransport - Class in org.apache.thrift.transport
-
- TNonblockingTransport() - Constructor for class org.apache.thrift.transport.TNonblockingTransport
-
- toByteArray(BitSet, int) - Static method in class org.apache.thrift.protocol.TTupleProtocol
-
Returns a byte array of at least length 1.
- toString() - Method in class org.apache.thrift.protocol.TField
-
- toString() - Method in class org.apache.thrift.protocol.TMessage
-
- toString() - Method in class org.apache.thrift.ShortStack
-
- toString(ByteBuffer, StringBuilder) - Static method in class org.apache.thrift.TBaseHelper
-
- toString() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
-
- toString(String) - Method in class org.apache.thrift.transport.TMemoryBuffer
-
Output the contents of the memory buffer as a String, using the supplied
encoding
- toString(TBase, String) - Method in class org.apache.thrift.TSerializer
-
Serialize the Thrift object into a Java string, using a specified
character set for encoding.
- toString(TBase) - Method in class org.apache.thrift.TSerializer
-
Serialize the Thrift object into a Java string, using the default JVM
charset encoding.
- toString() - Method in class org.apache.thrift.TUnion
-
- TProcessor - Interface in org.apache.thrift
-
A processor is a generic object which operates upon an input stream and
writes to some output stream.
- TProcessorFactory - Class in org.apache.thrift
-
The default processor factory just returns a singleton
instance.
- TProcessorFactory(TProcessor) - Constructor for class org.apache.thrift.TProcessorFactory
-
- TProtocol - Class in org.apache.thrift.protocol
-
Protocol interface definition.
- TProtocol(TTransport) - Constructor for class org.apache.thrift.protocol.TProtocol
-
Constructor
- TProtocolDecorator - Class in org.apache.thrift.protocol
-
TProtocolDecorator
forwards all requests to an enclosed
TProtocol
instance, providing a way to author concise
concrete decorator subclasses.
- TProtocolDecorator(TProtocol) - Constructor for class org.apache.thrift.protocol.TProtocolDecorator
-
Encloses the specified protocol.
- TProtocolException - Exception in org.apache.thrift.protocol
-
Protocol exceptions.
- TProtocolException() - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(int) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(int, String) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(String) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(int, Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(String, Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolException(int, String, Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
-
- TProtocolFactory - Interface in org.apache.thrift.protocol
-
Factory interface for constructing protocol instances.
- TProtocolUtil - Class in org.apache.thrift.protocol
-
Utility class with static methods for interacting with protocol data
streams.
- TProtocolUtil() - Constructor for class org.apache.thrift.protocol.TProtocolUtil
-
- trans_ - Variable in class org.apache.thrift.protocol.TProtocol
-
Transport
- trans_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
- transition(SelectionKey) - Method in class org.apache.thrift.async.TAsyncMethodCall
-
Transition to next state, doing whatever work is required.
- transport - Variable in class org.apache.thrift.async.TAsyncMethodCall
-
- transportFactory(TTransportFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
-
- trunc() - Method in class org.apache.thrift.transport.TFileTransport.TruncableBufferedInputStream
-
- trustManagerType - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
- trustPass - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
- trustStore - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
- trustStoreType - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
- TSaslClientTransport - Class in org.apache.thrift.transport
-
Wraps another Thrift TTransport
, but performs SASL client
negotiation on the call to open()
.
- TSaslClientTransport(SaslClient, TTransport) - Constructor for class org.apache.thrift.transport.TSaslClientTransport
-
Uses the given SaslClient
.
- TSaslClientTransport(String, String, String, String, Map<String, String>, CallbackHandler, TTransport) - Constructor for class org.apache.thrift.transport.TSaslClientTransport
-
Creates a SaslClient
using the given SASL-specific parameters.
- TSaslServerTransport - Class in org.apache.thrift.transport
-
Wraps another Thrift TTransport
, but performs SASL server
negotiation on the call to open()
.
- TSaslServerTransport(TTransport) - Constructor for class org.apache.thrift.transport.TSaslServerTransport
-
Uses the given underlying transport.
- TSaslServerTransport(String, String, String, Map<String, String>, CallbackHandler, TTransport) - Constructor for class org.apache.thrift.transport.TSaslServerTransport
-
Creates a SaslServer
using the given SASL-specific parameters.
- TSaslServerTransport.Factory - Class in org.apache.thrift.transport
-
TTransportFactory
to create
TSaslServerTransports.
- TSaslServerTransport.Factory() - Constructor for class org.apache.thrift.transport.TSaslServerTransport.Factory
-
Create a new Factory.
- TSaslServerTransport.Factory(String, String, String, Map<String, String>, CallbackHandler) - Constructor for class org.apache.thrift.transport.TSaslServerTransport.Factory
-
Create a new Factory
, initially with the single server
definition given.
- TSaslTransportException - Exception in org.apache.thrift.transport
-
- TSaslTransportException() - Constructor for exception org.apache.thrift.transport.TSaslTransportException
-
- TSaslTransportException(String) - Constructor for exception org.apache.thrift.transport.TSaslTransportException
-
- TSaslTransportException(Throwable) - Constructor for exception org.apache.thrift.transport.TSaslTransportException
-
- TSaslTransportException(String, Throwable) - Constructor for exception org.apache.thrift.transport.TSaslTransportException
-
- TSeekableFile - Interface in org.apache.thrift.transport
-
- TSerializer - Class in org.apache.thrift
-
Generic utility for easily serializing objects into a byte array or Java
String.
- TSerializer() - Constructor for class org.apache.thrift.TSerializer
-
Create a new TSerializer that uses the TBinaryProtocol by default.
- TSerializer(TProtocolFactory) - Constructor for class org.apache.thrift.TSerializer
-
Create a new TSerializer.
- TServer - Class in org.apache.thrift.server
-
Generic interface for a Thrift server.
- TServer(TServer.AbstractServerArgs) - Constructor for class org.apache.thrift.server.TServer
-
- TServer.AbstractServerArgs<T extends TServer.AbstractServerArgs<T>> - Class in org.apache.thrift.server
-
- TServer.AbstractServerArgs(TServerTransport) - Constructor for class org.apache.thrift.server.TServer.AbstractServerArgs
-
- TServer.Args - Class in org.apache.thrift.server
-
- TServer.Args(TServerTransport) - Constructor for class org.apache.thrift.server.TServer.Args
-
- TServerEventHandler - Interface in org.apache.thrift.server
-
Interface that can handle events from the server core.
- TServerSocket - Class in org.apache.thrift.transport
-
Wrapper around ServerSocket for Thrift.
- TServerSocket(ServerSocket) - Constructor for class org.apache.thrift.transport.TServerSocket
-
Creates a server socket from underlying socket object
- TServerSocket(ServerSocket, int) - Constructor for class org.apache.thrift.transport.TServerSocket
-
Creates a server socket from underlying socket object
- TServerSocket(int) - Constructor for class org.apache.thrift.transport.TServerSocket
-
Creates just a port listening server socket
- TServerSocket(int, int) - Constructor for class org.apache.thrift.transport.TServerSocket
-
Creates just a port listening server socket
- TServerSocket(InetSocketAddress) - Constructor for class org.apache.thrift.transport.TServerSocket
-
- TServerSocket(InetSocketAddress, int) - Constructor for class org.apache.thrift.transport.TServerSocket
-
- TServerSocket(TServerSocket.ServerSocketTransportArgs) - Constructor for class org.apache.thrift.transport.TServerSocket
-
- TServerSocket.ServerSocketTransportArgs - Class in org.apache.thrift.transport
-
- TServerSocket.ServerSocketTransportArgs() - Constructor for class org.apache.thrift.transport.TServerSocket.ServerSocketTransportArgs
-
- TServerTransport - Class in org.apache.thrift.transport
-
Server transport.
- TServerTransport() - Constructor for class org.apache.thrift.transport.TServerTransport
-
- TServerTransport.AbstractServerTransportArgs<T extends TServerTransport.AbstractServerTransportArgs<T>> - Class in org.apache.thrift.transport
-
- TServerTransport.AbstractServerTransportArgs() - Constructor for class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
-
- TServiceClient - Class in org.apache.thrift
-
A TServiceClient is used to communicate with a TService implementation
across protocols and transports.
- TServiceClient(TProtocol) - Constructor for class org.apache.thrift.TServiceClient
-
- TServiceClient(TProtocol, TProtocol) - Constructor for class org.apache.thrift.TServiceClient
-
- TServiceClientFactory<T extends TServiceClient> - Interface in org.apache.thrift
-
A TServiceClientFactory provides a general way to get a TServiceClient
connected to a remote TService via a protocol.
- TServlet - Class in org.apache.thrift.server
-
Servlet implementation class ThriftServer
- TServlet(TProcessor, TProtocolFactory, TProtocolFactory) - Constructor for class org.apache.thrift.server.TServlet
-
- TServlet(TProcessor, TProtocolFactory) - Constructor for class org.apache.thrift.server.TServlet
-
- TSet - Class in org.apache.thrift.protocol
-
Helper class that encapsulates set metadata.
- TSet() - Constructor for class org.apache.thrift.protocol.TSet
-
- TSet(byte, int) - Constructor for class org.apache.thrift.protocol.TSet
-
- TSet(TList) - Constructor for class org.apache.thrift.protocol.TSet
-
- TSimpleFileTransport - Class in org.apache.thrift.transport
-
Basic file support for the TTransport interface
- TSimpleFileTransport(String, boolean, boolean, boolean) - Constructor for class org.apache.thrift.transport.TSimpleFileTransport
-
Create a transport backed by a simple file
- TSimpleFileTransport(String, boolean, boolean) - Constructor for class org.apache.thrift.transport.TSimpleFileTransport
-
Create a transport backed by a simple file
Implicitly opens file to conform to C++ behavior.
- TSimpleFileTransport(String) - Constructor for class org.apache.thrift.transport.TSimpleFileTransport
-
Create a transport backed by a simple read only disk file (implicitly opens
file)
- TSimpleJSONProtocol - Class in org.apache.thrift.protocol
-
JSON protocol implementation for thrift.
- TSimpleJSONProtocol(TTransport) - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol
-
Constructor
- TSimpleJSONProtocol.CollectionMapKeyException - Exception in org.apache.thrift.protocol
-
- TSimpleJSONProtocol.CollectionMapKeyException(String) - Constructor for exception org.apache.thrift.protocol.TSimpleJSONProtocol.CollectionMapKeyException
-
- TSimpleJSONProtocol.Context - Class in org.apache.thrift.protocol
-
- TSimpleJSONProtocol.Context() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.Context
-
- TSimpleJSONProtocol.Factory - Class in org.apache.thrift.protocol
-
Factory
- TSimpleJSONProtocol.Factory() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.Factory
-
- TSimpleJSONProtocol.ListContext - Class in org.apache.thrift.protocol
-
- TSimpleJSONProtocol.ListContext() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.ListContext
-
- TSimpleJSONProtocol.MapContext - Class in org.apache.thrift.protocol
-
- TSimpleJSONProtocol.MapContext() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.MapContext
-
- TSimpleJSONProtocol.StructContext - Class in org.apache.thrift.protocol
-
- TSimpleJSONProtocol.StructContext() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.StructContext
-
- TSimpleServer - Class in org.apache.thrift.server
-
Simple singlethreaded server for testing.
- TSimpleServer(TServer.AbstractServerArgs) - Constructor for class org.apache.thrift.server.TSimpleServer
-
- TSocket - Class in org.apache.thrift.transport
-
Socket implementation of the TTransport interface.
- TSocket(Socket) - Constructor for class org.apache.thrift.transport.TSocket
-
Constructor that takes an already created socket.
- TSocket(String, int) - Constructor for class org.apache.thrift.transport.TSocket
-
Creates a new unconnected socket that will connect to the given host
on the given port.
- TSocket(String, int, int) - Constructor for class org.apache.thrift.transport.TSocket
-
Creates a new unconnected socket that will connect to the given host
on the given port.
- TSSLTransportFactory - Class in org.apache.thrift.transport
-
A Factory for providing and setting up Client and Server SSL wrapped
TSocket and TServerSocket
- TSSLTransportFactory() - Constructor for class org.apache.thrift.transport.TSSLTransportFactory
-
- TSSLTransportFactory.TSSLTransportParameters - Class in org.apache.thrift.transport
-
A Class to hold all the SSL parameters
- TSSLTransportFactory.TSSLTransportParameters() - Constructor for class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
- TSSLTransportFactory.TSSLTransportParameters(String, String[]) - Constructor for class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Create parameters specifying the protocol and cipher suites
- TSSLTransportFactory.TSSLTransportParameters(String, String[], boolean) - Constructor for class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
-
Create parameters specifying the protocol, cipher suites and if client authentication
is required
- TStandardFile - Class in org.apache.thrift.transport
-
- TStandardFile(String) - Constructor for class org.apache.thrift.transport.TStandardFile
-
- TStruct - Class in org.apache.thrift.protocol
-
Helper class that encapsulates struct metadata.
- TStruct() - Constructor for class org.apache.thrift.protocol.TStruct
-
- TStruct(String) - Constructor for class org.apache.thrift.protocol.TStruct
-
- TThreadedSelectorServer - Class in org.apache.thrift.server
-
A Half-Sync/Half-Async server with a separate pool of threads to handle
non-blocking I/O.
- TThreadedSelectorServer(TThreadedSelectorServer.Args) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer
-
Create the server with the specified Args configuration
- TThreadedSelectorServer.AcceptThread - Class in org.apache.thrift.server
-
The thread that selects on the server transport (listen socket) and accepts
new connections to hand off to the IO selector threads
- TThreadedSelectorServer.AcceptThread(TNonblockingServerTransport, TThreadedSelectorServer.SelectorThreadLoadBalancer) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.AcceptThread
-
Set up the AcceptThead
- TThreadedSelectorServer.Args - Class in org.apache.thrift.server
-
- TThreadedSelectorServer.Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- TThreadedSelectorServer.Args.AcceptPolicy - Enum in org.apache.thrift.server
-
Determines the strategy for handling new accepted connections.
- TThreadedSelectorServer.SelectorThread - Class in org.apache.thrift.server
-
The SelectorThread(s) will be doing all the selecting on accepted active
connections.
- TThreadedSelectorServer.SelectorThread() - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
-
Set up the SelectorThread with an unbounded queue for incoming accepts.
- TThreadedSelectorServer.SelectorThread(int) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
-
Set up the SelectorThread with an bounded queue for incoming accepts.
- TThreadedSelectorServer.SelectorThread(BlockingQueue<TNonblockingTransport>) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
-
Set up the SelectorThread with a specified queue for connections.
- TThreadedSelectorServer.SelectorThreadLoadBalancer - Class in org.apache.thrift.server
-
A round robin load balancer for choosing selector threads for new
connections.
- TThreadedSelectorServer.SelectorThreadLoadBalancer(Collection<T>) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThreadLoadBalancer
-
- TThreadPoolServer - Class in org.apache.thrift.server
-
Server which uses Java's built in ThreadPool management to spawn off
a worker pool that
- TThreadPoolServer(TThreadPoolServer.Args) - Constructor for class org.apache.thrift.server.TThreadPoolServer
-
- TThreadPoolServer.Args - Class in org.apache.thrift.server
-
- TThreadPoolServer.Args(TServerTransport) - Constructor for class org.apache.thrift.server.TThreadPoolServer.Args
-
- TTransport - Class in org.apache.thrift.transport
-
Generic class that encapsulates the I/O layer.
- TTransport() - Constructor for class org.apache.thrift.transport.TTransport
-
- TTransportException - Exception in org.apache.thrift.transport
-
Transport exceptions.
- TTransportException() - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(int) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(int, String) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(String) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(int, Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(String, Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportException(int, String, Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
-
- TTransportFactory - Class in org.apache.thrift.transport
-
Factory class used to create wrapped instance of Transports.
- TTransportFactory() - Constructor for class org.apache.thrift.transport.TTransportFactory
-
- TTupleProtocol - Class in org.apache.thrift.protocol
-
- TTupleProtocol(TTransport) - Constructor for class org.apache.thrift.protocol.TTupleProtocol
-
- TTupleProtocol.Factory - Class in org.apache.thrift.protocol
-
- TTupleProtocol.Factory() - Constructor for class org.apache.thrift.protocol.TTupleProtocol.Factory
-
- TType - Class in org.apache.thrift.protocol
-
Type constants in the Thrift protocol.
- TType() - Constructor for class org.apache.thrift.protocol.TType
-
- TUnion<T extends TUnion<?,?>,F extends TFieldIdEnum> - Class in org.apache.thrift
-
- TUnion() - Constructor for class org.apache.thrift.TUnion
-
- TUnion(F, Object) - Constructor for class org.apache.thrift.TUnion
-
- TUnion(TUnion<T, F>) - Constructor for class org.apache.thrift.TUnion
-
- TupleScheme<T extends TBase> - Class in org.apache.thrift.scheme
-
- TupleScheme() - Constructor for class org.apache.thrift.scheme.TupleScheme
-
- tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.thrift.TUnion
-
- tupleSchemeWriteValue(TProtocol) - Method in class org.apache.thrift.TUnion
-
- type - Variable in class org.apache.thrift.meta_data.FieldValueMetaData
-
- type - Variable in class org.apache.thrift.protocol.TField
-
- type - Variable in class org.apache.thrift.protocol.TMessage
-
- type_ - Variable in exception org.apache.thrift.protocol.TProtocolException
-
- type_ - Variable in exception org.apache.thrift.TApplicationException
-
- type_ - Variable in exception org.apache.thrift.transport.TTransportException
-
- waitForShutdown() - Method in class org.apache.thrift.server.AbstractNonblockingServer
-
A method that will block until when threads handling the serving have been
shut down.
- waitForShutdown() - Method in class org.apache.thrift.server.THsHaServer
-
- waitForShutdown() - Method in class org.apache.thrift.server.TNonblockingServer
-
- waitForShutdown() - Method in class org.apache.thrift.server.TThreadedSelectorServer
-
Joins the accept and selector threads and shuts down the executor service.
- wakeupSelector() - Method in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
-
If the selector is blocked, wake it up.
- wakeupSelector() - Method in class org.apache.thrift.server.TThreadedSelectorServer.AcceptThread
-
If the selector is blocked, wake it up.
- workerThreads(int) - Method in class org.apache.thrift.server.THsHaServer.Args
-
- workerThreads(int) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
-
- wrapsFullArray(ByteBuffer) - Static method in class org.apache.thrift.TBaseHelper
-
- write() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONBaseContext
-
- write() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONListContext
-
- write() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONPairContext
-
- write() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.Context
-
- write() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.ListContext
-
- write() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.MapContext
-
- write() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.StructContext
-
- write(TProtocol, T) - Method in interface org.apache.thrift.scheme.IScheme
-
- write() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
-
Give this FrameBuffer a chance to write its output to the final client.
- write(TProtocol) - Method in exception org.apache.thrift.TApplicationException
-
- write(TProtocol) - Method in interface org.apache.thrift.TBase
-
Writes the objects out to the protocol
- write(byte[], int, int) - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TFastFramedTransport
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TFileTransport
-
Writes up to len bytes from the buffer.
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TFramedTransport
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.THttpClient
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TIOStreamTransport
-
Writes to the underlying output stream if not null.
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryBuffer
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryInputTransport
-
- write(ByteBuffer) - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Perform a nonblocking write of the data in buffer;
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TNonblockingSocket
-
Writes to the underlying output stream if not null.
- write(ByteBuffer) - Method in class org.apache.thrift.transport.TNonblockingTransport
-
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TSimpleFileTransport
-
Write len many bytes from buff starting at offset
- write(byte[]) - Method in class org.apache.thrift.transport.TTransport
-
Writes the buffer to the output
- write(byte[], int, int) - Method in class org.apache.thrift.transport.TTransport
-
Writes up to len bytes from the buffer.
- write(TProtocol) - Method in class org.apache.thrift.TUnion
-
- write_args(TProtocol) - Method in class org.apache.thrift.async.TAsyncMethodCall
-
- writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a byte array, using a varint for the size.
- writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeBitSet(BitSet, int) - Method in class org.apache.thrift.protocol.TTupleProtocol
-
- writeBool(boolean) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeBool(boolean) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a boolean value.
- writeBool(boolean) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeBool(boolean) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeBool(boolean) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeBool(boolean) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeByte(byte) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeByte(byte) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a byte.
- writeByte(byte) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeByte(byte) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeByte(byte) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeByte(byte) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeCollectionBegin(byte, int) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Abstract method for writing the start of lists and sets.
- writeContext_ - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
Current context that we are in
- writeContextStack_ - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
Stack of nested contexts that we may be in.
- writeDouble(double) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeDouble(double) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a double to the wire as 8 bytes.
- writeDouble(double) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeDouble(double) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeDouble(double) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeDouble(double) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a field header containing the field id and field type.
- writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeFieldEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeFieldEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- writeFieldEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeFieldEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeFieldEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeFieldEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeFieldStop() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeFieldStop() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write the STOP symbol so we know there are no more fields in this struct.
- writeFieldStop() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeFieldStop() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeFieldStop() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeFieldStop() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeI16(short) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeI16(short) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write an I16 as a zigzag varint.
- writeI16(short) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeI16(short) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeI16(short) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeI16(short) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeI32(int) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeI32(int) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write an i32 as a zigzag varint.
- writeI32(int) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeI32(int) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeI32(int) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeI32(int) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeI64(long) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeI64(long) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write an i64 as a zigzag varint.
- writeI64(long) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeI64(long) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeI64(long) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeI64(long) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeListBegin(TList) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeListBegin(TList) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a list header.
- writeListBegin(TList) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeListBegin(TList) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeListBegin(TList) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeListBegin(TList) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeListEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeListEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- writeListEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeListEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeListEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeListEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a map header.
- writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeMapEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeMapEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- writeMapEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeMapEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeMapEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeMapEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a message header to the wire.
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TMultiplexedProtocol
-
Prepends the service name to the function name, separated by TMultiplexedProtocol.SEPARATOR.
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TProtocol
-
Writing methods.
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeMessageEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeMessageEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- writeMessageEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeMessageEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeMessageEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeMessageEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a set header.
- writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeSetEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeSetEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
- writeSetEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeSetEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeSetEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeSetEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeString(String) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeString(String) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a string to the wire with a varint size preceding.
- writeString(String) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeString(String) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeString(String) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeString(String) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a struct begin.
- writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TProtocol
-
- writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- writeStructEnd() - Method in class org.apache.thrift.protocol.TBinaryProtocol
-
- writeStructEnd() - Method in class org.apache.thrift.protocol.TCompactProtocol
-
Write a struct end.
- writeStructEnd() - Method in class org.apache.thrift.protocol.TJSONProtocol
-
- writeStructEnd() - Method in class org.apache.thrift.protocol.TProtocol
-
- writeStructEnd() - Method in class org.apache.thrift.protocol.TProtocolDecorator
-
- writeStructEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
-
- WRONG_METHOD_NAME - Static variable in exception org.apache.thrift.TApplicationException
-