Index

A B C D E F G H I J K L M N O P R S T U V W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

AbstractNonblockingServer - Class in org.apache.thrift.server
Provides common methods and classes used by nonblocking TServer implementations.
AbstractNonblockingServer(AbstractNonblockingServer.AbstractNonblockingServerArgs<?>) - Constructor for class org.apache.thrift.server.AbstractNonblockingServer
 
AbstractNonblockingServer.AbstractNonblockingServerArgs<T extends AbstractNonblockingServer.AbstractNonblockingServerArgs<T>> - Class in org.apache.thrift.server
 
AbstractNonblockingServer.AbstractSelectThread - Class in org.apache.thrift.server
An abstract thread that handles selecting on a set of transports and FrameBuffers associated with selected keys corresponding to requests.
AbstractNonblockingServer.AsyncFrameBuffer - Class in org.apache.thrift.server
 
AbstractNonblockingServer.FrameBuffer - Class in org.apache.thrift.server
Class that implements a sort of state machine around the interaction with a client and an invoker.
AbstractNonblockingServerArgs(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.AbstractNonblockingServer.AbstractNonblockingServerArgs
 
AbstractSelectThread() - Constructor for class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
 
AbstractServerArgs(TServerTransport) - Constructor for class org.apache.thrift.server.TServer.AbstractServerArgs
 
AbstractServerTransportArgs() - Constructor for class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
 
accept() - Method in class org.apache.thrift.transport.TNonblockingServerSocket
 
accept() - Method in class org.apache.thrift.transport.TNonblockingServerTransport
 
accept() - Method in class org.apache.thrift.transport.TServerSocket
 
accept() - Method in class org.apache.thrift.transport.TServerTransport
Accept incoming connection on the server socket.
accept(T) - Method in interface org.apache.thrift.protocol.TProtocol.ReadCallback
 
acceptPolicy(TThreadedSelectorServer.Args.AcceptPolicy) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
 
acceptQueueSizePerThread(int) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
 
AcceptThread(TNonblockingServerTransport, TThreadedSelectorServer.SelectorThreadLoadBalancer) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.AcceptThread
Set up the AcceptThead
addAcceptedConnection(TNonblockingTransport) - Method in class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
Hands off an accepted connection to be handled by this thread.
addCustomHeader(String, String) - Method in class org.apache.thrift.server.TExtensibleServlet
 
addCustomHeader(String, String) - Method in class org.apache.thrift.server.TServlet
 
additionalData - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
addSaslMechanism(String, String, String, Map<String, String>, CallbackHandler) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
addSaslMechanism(String, String, String, Map<String, String>, CallbackHandler) - Method in class org.apache.thrift.transport.sasl.TSaslServerFactory
 
addServerDefinition(String, String, String, Map<String, String>, CallbackHandler) - Method in class org.apache.thrift.transport.TSaslServerTransport
Add a supported server definition to this transport.
addServerDefinition(String, String, String, Map<String, String>, CallbackHandler) - Method in class org.apache.thrift.transport.TSaslServerTransport.Factory
Add a supported server definition to the transports created by this factory.
addStructMetaDataMap(Class<T>, Map<F, FieldMetaData>) - Static method in class org.apache.thrift.meta_data.FieldMetaData
 
ALREADY_OPEN - Static variable in exception org.apache.thrift.transport.TTransportException
 
append(StringBuilder, String, Object...) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
Helper method to append a formatted string to the given StringBuilder.
areEqual(T, T, StringBuilder) - Method in class org.apache.thrift.partial.PartialThriftComparer
Compares thrift objects t1 and t2 and returns true if they are equal false otherwise.
Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.THsHaServer.Args
 
Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TNonblockingServer.Args
 
Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TSaslNonblockingServer.Args
 
Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.Args
 
Args(TServerTransport) - Constructor for class org.apache.thrift.server.TServer.Args
 
Args(TServerTransport) - Constructor for class org.apache.thrift.server.TThreadPoolServer.Args
 
array() - Method in class org.apache.thrift.transport.AutoExpandingBuffer
 
assertContextIsNotMapKey(String) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
Used to make sure that we are not encountering a map whose keys are containers
AsyncFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer
 
AsyncMethodCallback<T> - Interface in org.apache.thrift.async
A handler interface asynchronous clients can implement to receive future notice of the results of an asynchronous method call.
AsyncMethodFutureAdapter<T> - Class in org.apache.thrift.async
A simple adapter that bridges AsyncMethodCallback with CompletableFuture-returning style clients.
AsyncProcessFunction<I,T extends TBase,R> - Class in org.apache.thrift
 
AsyncProcessFunction(String) - Constructor for class org.apache.thrift.AsyncProcessFunction
 
AUTHENTICATION_FAILURE - Enum constant in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
 
AutoExpandingBuffer - Class in org.apache.thrift.transport
Helper class that wraps a byte[] so that it can expand and be reused.
AutoExpandingBuffer(int) - Constructor for class org.apache.thrift.transport.AutoExpandingBuffer
 
AutoExpandingBufferReadTransport - Class in org.apache.thrift.transport
TTransport for reading from an AutoExpandingBuffer.
AutoExpandingBufferReadTransport(TConfiguration, int) - Constructor for class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
AutoExpandingBufferWriteTransport - Class in org.apache.thrift.transport
TTransport for writing to an AutoExpandingBuffer.
AutoExpandingBufferWriteTransport(TConfiguration, int, int) - Constructor for class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
Constructor.

B

backlog(int) - Method in class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
 
BAD - Enum constant in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 
BAD_SEQUENCE_ID - Static variable in exception org.apache.thrift.TApplicationException
 
BAD_VERSION - Static variable in exception org.apache.thrift.protocol.TProtocolException
 
BASE_CONTEXT - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
bindAddr(InetSocketAddress) - Method in class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
 
BOOL - Static variable in class org.apache.thrift.protocol.TType
 
buffer_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
build() - Method in class org.apache.thrift.TConfiguration.Builder
 
buildFrame(byte[], int, int, byte[], int, int) - Method in class org.apache.thrift.transport.sasl.DataFrameWriter
 
buildFrame(byte[], int, int, byte[], int, int) - Method in class org.apache.thrift.transport.sasl.FrameWriter
 
buildFrame(byte[], int, int, byte[], int, int) - Method in class org.apache.thrift.transport.sasl.SaslNegotiationFrameWriter
 
BYTE - Static variable in class org.apache.thrift.protocol.TType
 
byteBuffer - Variable in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
byteBufferToByteArray(ByteBuffer) - Static method in class org.apache.thrift.TBaseHelper
 
byteBufferToByteArray(ByteBuffer, byte[], int) - Static method in class org.apache.thrift.TBaseHelper
 
bytesToHexString(byte[]) - Static method in class org.apache.thrift.utils.StringUtils
Stringify a byte array to the hex representation for each byte.
bytesToHexString(byte[], int, int) - Static method in class org.apache.thrift.utils.StringUtils
Stringify a portion of the byte array.
byValue(byte) - Static method in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 

C

call() - Method in interface org.apache.thrift.protocol.TProtocol.ReadCollectionCallback
 
call(TAsyncMethodCall<?>) - Method in class org.apache.thrift.async.TAsyncClientManager
 
call(T) - Method in interface org.apache.thrift.protocol.TProtocol.WriteCallback
 
CALL - Static variable in class org.apache.thrift.protocol.TMessageType
 
cbh - Variable in class org.apache.thrift.transport.sasl.TSaslServerDefinition
 
changeSelectInterests() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
Give this FrameBuffer a chance to set its interest to write, once data has come in.
checkArgument(boolean, String, Object...) - Static method in class org.apache.thrift.partial.Validate
 
checkGreater(long, String, long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the first value is greater than the second value.
checkGreaterOrEqual(long, String, long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the first value is greater than or equal to the second value.
checkIntegerMultiple(long, String, long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the first value is an integer multiple of the second value.
checkLessOrEqual(long, String, long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the first value is less than or equal to the second value.
checkNotNegative(long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given integer argument is not negative.
checkNotNull(Object, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given reference argument is not null.
checkNotNullAndNotEmpty(byte[], String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given array is not null and has at least one element.
checkNotNullAndNotEmpty(int[], String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given array is not null and has at least one element.
checkNotNullAndNotEmpty(long[], String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given array is not null and has at least one element.
checkNotNullAndNotEmpty(short[], String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given array is not null and has at least one element.
checkNotNullAndNotEmpty(Iterable<T>, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given buffer is not null and has non-zero capacity.
checkNotNullAndNotEmpty(String, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given string is not null and has non-zero length.
checkNotNullAndNotEmpty(T[], String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given array is not null and has at least one element.
checkNotNullAndNumberOfElements(Collection<T>, int, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given set is not null and has an exact number of items.
checkPathExists(Path, String) - Static method in class org.apache.thrift.partial.Validate
 
checkPathExistsAsDir(Path, String) - Static method in class org.apache.thrift.partial.Validate
 
checkPathExistsAsFile(Path, String) - Static method in class org.apache.thrift.partial.Validate
 
checkPositiveInteger(long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given integer argument is not zero or negative.
checkReadBytesAvailable(long) - Method in class org.apache.thrift.transport.layered.TLayeredTransport
 
checkReadBytesAvailable(long) - Method in class org.apache.thrift.transport.TEndpointTransport
Throws if there are not enough bytes in the input stream to satisfy a read of numBytes bytes of data
checkReadBytesAvailable(long) - Method in class org.apache.thrift.transport.TFileTransport
 
checkReadBytesAvailable(long) - Method in class org.apache.thrift.transport.TTransport
 
checkReadBytesAvailable(TList) - Method in class org.apache.thrift.protocol.TProtocol
 
checkReadBytesAvailable(TMap) - Method in class org.apache.thrift.protocol.TProtocol
 
checkReadBytesAvailable(TSet) - Method in class org.apache.thrift.protocol.TProtocol
 
checkReady() - Method in class org.apache.thrift.async.TAsyncClient
 
checkRequired(boolean, String) - Static method in class org.apache.thrift.partial.Validate
 
checkState(boolean, String, Object...) - Static method in class org.apache.thrift.partial.Validate
 
checkType(F, Object) - Method in class org.apache.thrift.TUnion
Implementation should be generated so that we can efficiently type check various values.
checkValid(boolean, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the expression (that checks a field is valid) is true.
checkValid(boolean, String, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the expression (that checks a field is valid) is true.
checkValuesEqual(long, String, long, String) - Static method in class org.apache.thrift.partial.Validate
Validates that the given two values are equal.
checkWithinRange(double, String, double, double) - Static method in class org.apache.thrift.partial.Validate
Validates that the given value is within the given range of values.
checkWithinRange(long, String, long, long) - Static method in class org.apache.thrift.partial.Validate
Validates that the given value is within the given range of values.
ChunkState() - Constructor for class org.apache.thrift.transport.TFileTransport.ChunkState
 
ChunkState(int) - Constructor for class org.apache.thrift.transport.TFileTransport.ChunkState
 
cipherSuites - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
cleanupSelectionKey(SelectionKey) - Method in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
Do connection-close cleanup on a given SelectionKey.
clear() - Method in interface org.apache.thrift.TBase
Return to the state of having just been initialized, as though you had just called the default constructor.
clear() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
clear() - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
Only clears the read buffer!
clear() - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
clear() - Method in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
clear() - Method in interface org.apache.thrift.transport.sasl.FrameHeaderReader
Clear the header and make it available to read a new header.
clear() - Method in class org.apache.thrift.transport.sasl.FrameReader
Reset the state of the reader so that it can be reused to read a new frame.
clear() - Method in class org.apache.thrift.transport.sasl.FrameWriter
Release the byte buffer.
clear() - Method in class org.apache.thrift.transport.TByteBuffer
Convenience method to call clear() on the underlying NIO ByteBuffer.
clear() - Method in class org.apache.thrift.transport.TMemoryInputTransport
 
clear() - Method in class org.apache.thrift.TUnion
 
clearBit(byte, int) - Static method in class org.apache.thrift.EncodingUtils
Returns v, with the bit at position set to zero.
clearBit(int, int) - Static method in class org.apache.thrift.EncodingUtils
 
clearBit(long, int) - Static method in class org.apache.thrift.EncodingUtils
 
clearBit(short, int) - Static method in class org.apache.thrift.EncodingUtils
 
client - Variable in class org.apache.thrift.async.TAsyncMethodCall
 
clientAuth - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
clientTimeout(int) - Method in class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
 
close() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
Shut the connection down.
close() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
close() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
 
close() - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
close() - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
close() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
Release all the resources managed by this state machine (connection, selection and sasl server).
close() - Method in class org.apache.thrift.transport.TByteBuffer
 
close() - Method in class org.apache.thrift.transport.TFileTransport
Closes the transport.
close() - Method in class org.apache.thrift.transport.THttpClient
 
close() - Method in class org.apache.thrift.transport.TIOStreamTransport
Closes both the input and output streams.
close() - Method in class org.apache.thrift.transport.TMemoryBuffer
 
close() - Method in class org.apache.thrift.transport.TMemoryInputTransport
 
close() - Method in class org.apache.thrift.transport.TMemoryTransport
 
close() - Method in class org.apache.thrift.transport.TNonblockingServerSocket
 
close() - Method in class org.apache.thrift.transport.TNonblockingSocket
Closes the socket.
close() - Method in class org.apache.thrift.transport.TSaslClientTransport
Closes the underlying transport and disposes of the SASL implementation underlying this transport.
close() - Method in interface org.apache.thrift.transport.TSeekableFile
 
close() - Method in class org.apache.thrift.transport.TServerSocket
 
close() - Method in class org.apache.thrift.transport.TServerTransport
 
close() - Method in class org.apache.thrift.transport.TSimpleFileTransport
Close file, subsequent read/write activity will throw exceptions
close() - Method in class org.apache.thrift.transport.TSocket
Closes the socket.
close() - Method in class org.apache.thrift.transport.TStandardFile
 
close() - Method in class org.apache.thrift.transport.TTransport
Closes the transport.
close() - Method in class org.apache.thrift.transport.TZlibTransport
 
CLOSED - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
CLOSING - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
code - Variable in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
 
CollectionMapKeyException(String) - Constructor for exception org.apache.thrift.protocol.TSimpleJSONProtocol.CollectionMapKeyException
 
colon_ - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol.StructContext
 
compareTo(boolean, boolean) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(byte[], byte[]) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(byte, byte) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(double, double) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(int, int) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(long, long) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(short, short) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(Comparable, Comparable) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(Object, Object) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(String, String) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(List, List) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(Map, Map) - Static method in class org.apache.thrift.TBaseHelper
 
compareTo(Set, Set) - Static method in class org.apache.thrift.TBaseHelper
 
COMPLETE - Enum constant in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 
CONNECTING - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
consumeBuffer(int) - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
consumeBuffer(int) - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
consumeBuffer(int) - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
consumeBuffer(int) - Method in class org.apache.thrift.transport.TMemoryInputTransport
 
consumeBuffer(int) - Method in class org.apache.thrift.transport.TTransport
Consume len bytes from the underlying buffer.
containerLengthLimit_ - Variable in class org.apache.thrift.protocol.TBinaryProtocol.Factory
 
Context() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.Context
 
context_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
copyBinary(byte[]) - Static method in class org.apache.thrift.TBaseHelper
 
copyBinary(ByteBuffer) - Static method in class org.apache.thrift.TBaseHelper
 
CORRUPTED_DATA - Static variable in exception org.apache.thrift.transport.TTransportException
 
countConsumedMessageBytes(long) - Method in class org.apache.thrift.transport.TEndpointTransport
Consumes numBytes from the RemainingMessageSize.
create() - Static method in class org.apache.thrift.async.AsyncMethodFutureAdapter
 
create(ThriftMetadata.ThriftObject, TFieldIdEnum, FieldMetaData, Iterable<ThriftField>) - Static method in class org.apache.thrift.partial.ThriftMetadata.ThriftStructBase
 
createContext(TProtocol, TProtocol) - Method in interface org.apache.thrift.server.TServerEventHandler
Called when a new client has connected and is about to being processing.
createDefaultExecutor(TThreadedSelectorServer.Args) - Static method in class org.apache.thrift.server.TThreadedSelectorServer
Helper to create the invoker if one is not specified
createFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Method in class org.apache.thrift.server.TNonblockingServer.SelectAcceptThread
 
createFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Method in class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
 
createInvokerPool(THsHaServer.Args) - Static method in class org.apache.thrift.server.THsHaServer
Helper to create an invoker pool
createNewList(int) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
createNewList(int) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
createNewMap(int) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
createNewMap(int) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
createNewSet(int) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
createNewSet(int) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
createNewStruct() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
createNewStruct(ThriftMetadata.ThriftStruct) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
createNewStruct(ThriftMetadata.ThriftStruct) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
createSelectorThreadLoadBalancer(Collection<? extends TThreadedSelectorServer.SelectorThread>) - Method in class org.apache.thrift.server.TThreadedSelectorServer
Creates a SelectorThreadLoadBalancer to be used by the accept thread for assigning newly accepted connections across the threads.
custom() - Static method in class org.apache.thrift.TConfiguration
 

D

data - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
DataFrameHeaderReader - Class in org.apache.thrift.transport.sasl
The header for data frame, it only contains a 4-byte payload size.
DataFrameHeaderReader() - Constructor for class org.apache.thrift.transport.sasl.DataFrameHeaderReader
 
DataFrameReader - Class in org.apache.thrift.transport.sasl
Frames for thrift (serialized) messages.
DataFrameReader() - Constructor for class org.apache.thrift.transport.sasl.DataFrameReader
 
DataFrameWriter - Class in org.apache.thrift.transport.sasl
Write frames of thrift messages.
DataFrameWriter() - Constructor for class org.apache.thrift.transport.sasl.DataFrameWriter
 
decodeBigEndian(byte[]) - Static method in class org.apache.thrift.EncodingUtils
Decode a series of 4 bytes from buf, starting at position 0, and interpret them as an integer.
decodeBigEndian(byte[], int) - Static method in class org.apache.thrift.EncodingUtils
Decode a series of 4 bytes from buf, start at offset, and interpret them as an integer.
decodeFrameSize(byte[]) - Static method in class org.apache.thrift.transport.layered.TFramedTransport
 
deepCopy() - Method in interface org.apache.thrift.TBase
Performs a deep copy of this instance and returns the copy.
DEFAULT - Static variable in class org.apache.thrift.TConfiguration
 
DEFAULT - Static variable in class org.apache.thrift.TFieldRequirementType
 
DEFAULT_BUF_CAPACITY - Static variable in class org.apache.thrift.transport.layered.TFastFramedTransport
How big should the default read and write buffers be?
DEFAULT_CHUNK_SIZE - Static variable in class org.apache.thrift.transport.TFileTransport.ChunkState
Chunk Size.
DEFAULT_MAX_FRAME_SIZE - Static variable in class org.apache.thrift.TConfiguration
 
DEFAULT_MAX_LENGTH - Static variable in class org.apache.thrift.transport.TSaslClientTransport
 
DEFAULT_MAX_MESSAGE_SIZE - Static variable in class org.apache.thrift.TConfiguration
 
DEFAULT_RECURSION_DEPTH - Static variable in class org.apache.thrift.TConfiguration
 
deleteContext(ServerContext, TProtocol, TProtocol) - Method in interface org.apache.thrift.server.TServerEventHandler
Called when a client has finished request-handling to delete server context.
DEPTH_LIMIT - Static variable in exception org.apache.thrift.protocol.TProtocolException
 
deserialize(TBase, byte[]) - Method in class org.apache.thrift.TDeserializer
Deserialize the Thrift object from a byte array.
deserialize(TBase, byte[], int, int) - Method in class org.apache.thrift.TDeserializer
Deserialize the Thrift object from a byte array.
deserialize(TBase, String, String) - Method in class org.apache.thrift.TDeserializer
Deserialize the Thrift object from a Java string, using a specified character set for decoding.
dispose() - Method in interface org.apache.thrift.transport.sasl.SaslPeer
Close this peer and release resources.
dispose() - Method in class org.apache.thrift.transport.sasl.ServerSaslPeer
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.thrift.server.TExtensibleServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.thrift.server.TServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.thrift.server.TExtensibleServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.thrift.server.TServlet
 
DOUBLE - Static variable in class org.apache.thrift.protocol.TType
 

E

elementData - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftList
 
elementData - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftSet
 
elemMetaData - Variable in class org.apache.thrift.meta_data.ListMetaData
 
elemMetaData - Variable in class org.apache.thrift.meta_data.SetMetaData
 
elemType - Variable in class org.apache.thrift.protocol.TList
 
elemType - Variable in class org.apache.thrift.protocol.TSet
 
emit(byte[], int, int) - Method in class org.apache.thrift.transport.TFileTransport.Event
 
encode(byte) - Static method in class org.apache.thrift.partial.TFieldData
 
encode(byte, short) - Static method in class org.apache.thrift.partial.TFieldData
 
encodeBigEndian(int, byte[]) - Static method in class org.apache.thrift.EncodingUtils
Encode integer as a series of 4 bytes into buf starting at position 0 within that buffer.
encodeBigEndian(int, byte[], int) - Static method in class org.apache.thrift.EncodingUtils
Encode integer as a series of 4 bytes into buf starting at position offset.
encodeFrameSize(int, byte[]) - Static method in class org.apache.thrift.transport.layered.TFramedTransport
 
EncodingUtils - Class in org.apache.thrift
Utility methods for use when encoding/decoding raw data as byte arrays.
EncodingUtils() - Constructor for class org.apache.thrift.EncodingUtils
 
END_OF_FILE - Static variable in exception org.apache.thrift.transport.TTransportException
 
ENUM - Static variable in class org.apache.thrift.protocol.TType
This is not part of the TBinaryProtocol spec but Java specific implementation detail
EnumCache - Class in org.apache.thrift.partial
Provides a memoized way to lookup an enum by its value.
EnumCache() - Constructor for class org.apache.thrift.partial.EnumCache
 
enumClass - Variable in class org.apache.thrift.meta_data.EnumMetaData
 
enumForId(short) - Method in class org.apache.thrift.TUnion
 
EnumMetaData - Class in org.apache.thrift.meta_data
 
EnumMetaData(byte, Class<? extends TEnum>) - Constructor for class org.apache.thrift.meta_data.EnumMetaData
 
equals(Object) - Method in class org.apache.thrift.partial.ThriftField
 
equals(Object) - Method in class org.apache.thrift.protocol.TField
 
equals(Object) - Method in class org.apache.thrift.protocol.TMessage
 
ERROR - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
ERROR - Enum constant in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 
escapeNum() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONBaseContext
 
escapeNum() - Method in class org.apache.thrift.protocol.TJSONProtocol.JSONPairContext
 
evaluate(byte[]) - Method in interface org.apache.thrift.transport.sasl.SaslPeer
Evaluate and validate the negotiation message (response/challenge) received from peer.
evaluate(byte[]) - Method in class org.apache.thrift.transport.sasl.ServerSaslPeer
 
EVALUATING_SASL_RESPONSE - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
Event(byte[]) - Constructor for class org.apache.thrift.transport.TFileTransport.Event
Initialize an event.
eventHandler_ - Variable in class org.apache.thrift.server.TServer
 
EXCEPTION - Static variable in class org.apache.thrift.protocol.TMessageType
 
execute() - Method in class org.apache.thrift.server.TThreadPoolServer
 
executorService - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
 
executorService(ExecutorService) - Method in class org.apache.thrift.server.THsHaServer.Args
 
executorService(ExecutorService) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
 
executorService(ExecutorService) - Method in class org.apache.thrift.server.TThreadPoolServer.Args
 

F

Factory() - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
 
Factory() - Constructor for class org.apache.thrift.protocol.TCompactProtocol.Factory
 
Factory() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.Factory
 
Factory() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.Factory
 
Factory() - Constructor for class org.apache.thrift.protocol.TTupleProtocol.Factory
 
Factory() - Constructor for class org.apache.thrift.transport.layered.TFastFramedTransport.Factory
 
Factory() - Constructor for class org.apache.thrift.transport.layered.TFramedTransport.Factory
 
Factory() - Constructor for class org.apache.thrift.transport.TSaslServerTransport.Factory
Create a new Factory.
Factory() - Constructor for class org.apache.thrift.transport.TZlibTransport.Factory
 
Factory(boolean) - Constructor for class org.apache.thrift.protocol.TJSONProtocol.Factory
 
Factory(boolean, boolean) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
 
Factory(boolean, boolean, long, long) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
 
Factory(int) - Constructor for class org.apache.thrift.transport.layered.TFastFramedTransport.Factory
 
Factory(int) - Constructor for class org.apache.thrift.transport.layered.TFramedTransport.Factory
 
Factory(int, int) - Constructor for class org.apache.thrift.transport.layered.TFastFramedTransport.Factory
 
Factory(long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol.Factory
 
Factory(long, long) - Constructor for class org.apache.thrift.protocol.TBinaryProtocol.Factory
 
Factory(long, long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol.Factory
 
Factory(String) - Constructor for class org.apache.thrift.transport.THttpClient.Factory
 
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.
Factory(String, HttpClient) - Constructor for class org.apache.thrift.transport.THttpClient.Factory
 
FAIR_ACCEPT - Enum constant in enum class org.apache.thrift.server.TThreadedSelectorServer.Args.AcceptPolicy
Require accepted connection registration to be handled by the executor.
FAST_ACCEPT - Enum constant in enum class org.apache.thrift.server.TThreadedSelectorServer.Args.AcceptPolicy
Handle the accepts as fast as possible, disregarding the status of the executor service.
fetch() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
Main entry function for fetching from servers.
fieldForId(int) - Method in interface org.apache.thrift.TBase
Get the F instance that corresponds to fieldId.
fieldId - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
FieldMetaData - Class in org.apache.thrift.meta_data
This class is used to store meta data about thrift fields.
FieldMetaData(String, byte, FieldValueMetaData) - Constructor for class org.apache.thrift.meta_data.FieldMetaData
 
FieldMetaData(String, byte, FieldValueMetaData, Map<String, String>) - Constructor for class org.apache.thrift.meta_data.FieldMetaData
 
fieldName - Variable in class org.apache.thrift.meta_data.FieldMetaData
 
fieldNamesAsString_ - Variable in class org.apache.thrift.protocol.TJSONProtocol.Factory
 
fields - Variable in class org.apache.thrift.partial.ThriftField
List of sub-fields of this field.
fields - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
FieldValueMetaData - Class in org.apache.thrift.meta_data
FieldValueMetaData and collection of subclasses to store metadata about the value(s) of a field
FieldValueMetaData(byte) - Constructor for class org.apache.thrift.meta_data.FieldValueMetaData
 
FieldValueMetaData(byte, boolean) - Constructor for class org.apache.thrift.meta_data.FieldValueMetaData
 
FieldValueMetaData(byte, String) - Constructor for class org.apache.thrift.meta_data.FieldValueMetaData
 
fill(TTransport, int) - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
finishConnect() - Method in class org.apache.thrift.transport.TNonblockingSocket
Non-blocking connection completion.
finishConnect() - Method in class org.apache.thrift.transport.TNonblockingTransport
Non-blocking connection completion.
first_ - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol.ListContext
 
first_ - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol.StructContext
 
FixedSizeHeaderReader - Class in org.apache.thrift.transport.sasl
Headers' size should be predefined.
FixedSizeHeaderReader() - Constructor for class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
flip() - Method in class org.apache.thrift.transport.TByteBuffer
Convenience method to call flip() on the underlying NIO ByteBuffer.
flush() - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
flush() - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
flush() - Method in class org.apache.thrift.transport.TFileTransport
Flush any pending data out of a transport buffer.
flush() - Method in class org.apache.thrift.transport.THttpClient
 
flush() - Method in class org.apache.thrift.transport.TIOStreamTransport
Flushes the underlying output stream if not null.
flush() - Method in class org.apache.thrift.transport.TNonblockingSocket
Noop.
flush() - Method in class org.apache.thrift.transport.TSaslClientTransport
Flushes to the underlying transport.
flush() - Method in class org.apache.thrift.transport.TTransport
Flush any pending data out of a transport buffer.
FrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
frameBytes - Variable in class org.apache.thrift.transport.sasl.FrameWriter
 
FrameHeaderReader - Interface in org.apache.thrift.transport.sasl
Read headers for a frame.
FrameReader<T extends FrameHeaderReader> - Class in org.apache.thrift.transport.sasl
Read frames from a transport.
FrameReader(T) - Constructor for class org.apache.thrift.transport.sasl.FrameReader
 
frameTrans_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
FrameWriter - Class in org.apache.thrift.transport.sasl
Write frame (header and payload) to transport in a nonblocking way.
FrameWriter() - Constructor for class org.apache.thrift.transport.sasl.FrameWriter
 
fromByteArray(byte[]) - Static method in class org.apache.thrift.protocol.TTupleProtocol
Returns a bitset containing the values in bytes.
fromFieldNames(Class<T>, Collection<String>) - Static method in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
fromFields(Class<T>, Iterable<ThriftField>) - Static method in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
fromNames(Collection<String>) - Static method in class org.apache.thrift.partial.ThriftField
Generates and returns n-ary tree of fields and their sub-fields.
fromNullable(T) - Static method in class org.apache.thrift.Option
Wraps value in an Option type, depending on whether or not value is null
fromString(TBase, String) - Method in class org.apache.thrift.TDeserializer
Deserialize the Thrift object from a Java string, using the default JVM charset encoding.

G

get() - Method in class org.apache.thrift.Option
Get the value of the Option (if it is defined)
get() - Method in class org.apache.thrift.Option.None
 
get() - Method in class org.apache.thrift.Option.Some
 
get() - Method in class org.apache.thrift.TByteArrayOutputStream
 
get(Class<? extends TEnum>, int) - Method in class org.apache.thrift.partial.EnumCache
Gets an instance of the enum type enumClass corresponding to the given value.
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.layered.TFastFramedTransport
 
getBuffer() - Method in class org.apache.thrift.transport.layered.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.layered.TFastFramedTransport
 
getBufferPosition() - Method in class org.apache.thrift.transport.layered.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.
getByteBuffer() - Method in class org.apache.thrift.transport.TByteBuffer
Gets the underlying NIO ByteBuffer.
getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
getBytesRemainingInBuffer() - Method in class org.apache.thrift.transport.layered.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) - 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) - 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.
getConfiguration() - Method in class org.apache.thrift.transport.layered.TLayeredTransport
 
getConfiguration() - Method in class org.apache.thrift.transport.TEndpointTransport
 
getConfiguration() - Method in class org.apache.thrift.transport.TFileTransport
 
getConfiguration() - Method in class org.apache.thrift.transport.TTransport
 
getCurChunk() - Method in class org.apache.thrift.transport.TFileTransport
 
getCurrentPhase() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
Get current phase of the state machine.
getDetails() - Method in exception org.apache.thrift.transport.sasl.TSaslNegotiationException
 
getElemType() - Method in class org.apache.thrift.protocol.TList
 
getElemType() - Method in class org.apache.thrift.protocol.TSet
 
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
getErrorType() - Method in exception org.apache.thrift.transport.sasl.TSaslNegotiationException
 
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
 
getExecutorService() - Method in class org.apache.thrift.server.TThreadPoolServer
 
getFetchStats() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
 
getFetchTimeoutSeconds() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
 
getFieldAnnotations() - Method in class org.apache.thrift.meta_data.FieldMetaData
 
getFieldDesc(F) - Method in class org.apache.thrift.TUnion
 
getFieldName() - Method in interface org.apache.thrift.TFieldIdEnum
Gets the field's name, exactly as in the IDL.
getFieldNames() - Method in class org.apache.thrift.partial.ThriftField
 
getFieldValue() - Method in class org.apache.thrift.TUnion
 
getFieldValue(int) - Method in class org.apache.thrift.TUnion
 
getFieldValue(F) - Method in interface org.apache.thrift.TBase
Get a field's value by field variable.
getFieldValue(F) - 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
 
getFuture() - Method in class org.apache.thrift.async.AsyncMethodFutureAdapter
 
getHeader() - Method in class org.apache.thrift.transport.sasl.FrameReader
 
getHeaderSize() - Method in class org.apache.thrift.transport.sasl.FrameReader
 
getId(int) - Static method in class org.apache.thrift.partial.TFieldData
 
getIndent(int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
Gets a space string whose length is proportional to the given indent level.
getInnerTransport() - Method in class org.apache.thrift.transport.layered.TLayeredTransport
 
getInProtocolFactory() - Method in class org.apache.thrift.server.TExtensibleServlet
Returns the appropriate in TProtocolFactory.
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
 
getInvoker() - Method in class org.apache.thrift.server.THsHaServer
 
getKey() - Method in interface org.apache.thrift.protocol.TProtocol.ReadMapEntryCallback
 
getKeyType() - Method in class org.apache.thrift.protocol.TMap
 
getLength() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
 
getMaxFrameSize() - Method in class org.apache.thrift.TConfiguration
 
getMaxFrameSize() - Method in class org.apache.thrift.transport.TEndpointTransport
 
getMaxMessageSize() - Method in class org.apache.thrift.TConfiguration
 
getMaxMessageSize() - Method in class org.apache.thrift.transport.TEndpointTransport
 
getMaxRecvBufBytesPerServer() - Method in class org.apache.thrift.TNonblockingMultiFetchClient
 
getMaxResponseBytes() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
getMaxWorkerThreads() - Method in class org.apache.thrift.server.THsHaServer.Args
 
getMessage() - Method in exception org.apache.thrift.TApplicationException
 
getMetadata() - Method in class org.apache.thrift.TDeserializer
Gets the metadata used for partial deserialization.
getMethodName() - Method in class org.apache.thrift.AsyncProcessFunction
 
getMethodName() - Method in class org.apache.thrift.ProcessFunction
 
getMinSerializedSize(byte) - Method in class org.apache.thrift.protocol.TBinaryProtocol
Return the minimum number of bytes a type will consume on the wire
getMinSerializedSize(byte) - Method in class org.apache.thrift.protocol.TCompactProtocol
Return the minimum number of bytes a type will consume on the wire
getMinSerializedSize(byte) - Method in class org.apache.thrift.protocol.TJSONProtocol
Return the minimum number of bytes a type will consume on the wire
getMinSerializedSize(byte) - Method in class org.apache.thrift.protocol.TProtocol
Return min serialized size in bytes
getMinSerializedSize(byte) - Method in class org.apache.thrift.protocol.TProtocolDecorator
 
getMinSerializedSize(byte) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
Return the minimum number of bytes a type will consume on the wire
getMinWorkerThreads() - Method in class org.apache.thrift.server.THsHaServer.Args
 
getName() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
Gets the name of this field.
getName() - Method in class org.apache.thrift.protocol.TMessage
 
getName() - Method in class org.apache.thrift.protocol.TStruct
 
getNextPhase() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
Get next phase of the state machine.
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
Returns the appropriate out TProtocolFactory.
getOutput() - Method in class org.apache.thrift.transport.TMemoryTransport
Get all the bytes written by thrift output protocol.
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
 
getPayload() - Method in class org.apache.thrift.transport.sasl.FrameReader
 
getPayloadSize() - Method in class org.apache.thrift.transport.sasl.FrameReader
 
getPort() - Method in class org.apache.thrift.transport.TNonblockingServerSocket
 
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
Returns the appropriate TProcessor.
getProcessor(NonblockingSaslHandler) - Method in class org.apache.thrift.transport.sasl.TBaseSaslProcessorFactory
 
getProcessor(NonblockingSaslHandler) - Method in interface org.apache.thrift.transport.sasl.TSaslProcessorFactory
 
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
 
getRecursionLimit() - Method in class org.apache.thrift.TConfiguration
 
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
Returns a copy of requestBuf, so that requestBuf will not be modified by others.
getResult() - Method in class org.apache.thrift.async.TAsyncMethodCall
 
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
 
getSaslClient() - Method in class org.apache.thrift.transport.TSaslClientTransport
Get the underlying SaslClient.
getSaslPeer(String) - Method in class org.apache.thrift.transport.sasl.TSaslServerFactory
 
getSaslServer() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
 
getSaslServer() - Method in class org.apache.thrift.transport.TSaslClientTransport
Get the underlying SaslServer.
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
 
getSeqid() - Method in class org.apache.thrift.protocol.TMessage
 
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
 
getShouldStop() - Method in class org.apache.thrift.server.TServer
 
getSize() - Method in class org.apache.thrift.protocol.TList
 
getSize() - Method in class org.apache.thrift.protocol.TMap
 
getSize() - Method in class org.apache.thrift.protocol.TSet
 
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
 
getStatus() - Method in class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 
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
 
getStructClass() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftStructBase
 
getStructClass(FieldMetaData) - Static method in class org.apache.thrift.partial.ThriftMetadata.ThriftStructBase
 
getStructDesc() - Method in class org.apache.thrift.TUnion
 
getStructMetaDataMap(Class<T>) - Static method in class org.apache.thrift.meta_data.FieldMetaData
Returns a map with metadata (i.e. instances of FieldMetaData) that describe the fields of the given class.
getSubElementName(TFieldIdEnum) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
getSubElementName(TFieldIdEnum, String) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
getSummary() - Method in exception org.apache.thrift.transport.sasl.TSaslNegotiationException
 
getTailPolicy() - Method in class org.apache.thrift.transport.TFileTransport
Get File Tailing Policy
getThriftFieldId() - Method in interface org.apache.thrift.TFieldIdEnum
Gets 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.layered.TFastFramedTransport.Factory
 
getTransport(TTransport) - Method in class org.apache.thrift.transport.layered.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.
getTransport(TTransport) - Method in class org.apache.thrift.transport.TZlibTransport.Factory
 
getType() - Method in class org.apache.thrift.protocol.TMessage
 
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
 
getType(int) - Static method in class org.apache.thrift.partial.TFieldData
 
getTypedefName() - Method in class org.apache.thrift.meta_data.FieldValueMetaData
 
getUnderlyingTransport() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
 
getUnderlyingTransport() - Method in class org.apache.thrift.transport.TSaslClientTransport
Get the underlying transport that Sasl is using.
getValue() - Method in interface org.apache.thrift.protocol.TProtocol.ReadMapEntryCallback
 
getValue() - Method in interface org.apache.thrift.TEnum
 
getValue() - Method in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 
getValueType() - Method in class org.apache.thrift.protocol.TMap
 
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.

H

handleRead() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
When current phase is intrested in read selection, calling this will run the current phase and its following phases if the following ones are interested to read, until there is nothing available in the underlying transport.
handleRead(SelectionKey) - Method in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
Do the work required to read from a readable client.
handleResponse(ClassicHttpResponse) - Method in class org.apache.thrift.THttpClientResponseHandler
 
handleSaslStartMessage() - Method in class org.apache.thrift.transport.TSaslClientTransport
Performs the client side of the initial portion of the Thrift SASL protocol.
handleSaslStartMessage() - Method in class org.apache.thrift.transport.TSaslServerTransport
Performs the server side of the initial portion of the Thrift SASL protocol.
handleWrite() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
Similiar to handleRead.
handleWrite(SelectionKey) - Method in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
Let a writable client get written, if there's data to be written.
hasError() - Method in class org.apache.thrift.async.TAsyncClient
Is the client in an error state?
hashCode() - Method in class org.apache.thrift.partial.ThriftField
 
hashCode() - Method in class org.apache.thrift.protocol.TField
 
hashCode() - Method in class org.apache.thrift.protocol.TMessage
 
hashCode(double) - Static method in class org.apache.thrift.TBaseHelper
 
hashCode(long) - Static method in class org.apache.thrift.TBaseHelper
 
hasTimeout() - Method in class org.apache.thrift.async.TAsyncClient
 
hasTimeout() - Method in class org.apache.thrift.async.TAsyncMethodCall
 
hasUnion() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftContainer
 
hasUnion() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftList
 
hasUnion() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftMap
 
hasUnion() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftSet
 
HEADER_BYTES - Static variable in class org.apache.thrift.transport.sasl.SaslNegotiationFrameWriter
 
headerSize() - Method in class org.apache.thrift.transport.sasl.DataFrameHeaderReader
 
headerSize() - Method in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
headerSize() - Method in class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 

I

I16 - Static variable in class org.apache.thrift.protocol.TType
 
I32 - Static variable in class org.apache.thrift.protocol.TType
 
I64 - Static variable in class org.apache.thrift.protocol.TType
 
id - Variable in class org.apache.thrift.protocol.TField
 
incNumConnectErrorServers() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
incNumInvalidFrameSize() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
incNumOverflowedRecvBuf() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
incNumReadCompletedServers() - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
incTotalRecvBufBytes(int) - Method in class org.apache.thrift.TNonblockingMultiFetchStats
 
init(ServletConfig) - Method in class org.apache.thrift.server.TExtensibleServlet
 
INITIIALIIZING - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
inProt_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
inputFile_ - Variable in class org.apache.thrift.transport.TFileTransport
Underlying file being read
inputFile_ - Variable in class org.apache.thrift.transport.TStandardFile
 
inputProtocolFactory(TProtocolFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
inputProtocolFactory_ - Variable in class org.apache.thrift.server.TServer
Input Protocol Factory
inputStream_ - Variable in class org.apache.thrift.transport.TIOStreamTransport
Underlying inputStream
inputTransportFactory(TTransportFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
inputTransportFactory_ - Variable in class org.apache.thrift.server.TServer
Input Transport Factory
inspect() - Method in class org.apache.thrift.transport.TMemoryBuffer
 
INTERNAL_ERROR - Enum constant in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
 
INTERNAL_ERROR - Static variable in exception org.apache.thrift.TApplicationException
 
interrupt() - Method in class org.apache.thrift.transport.TNonblockingServerSocket
 
interrupt() - Method in class org.apache.thrift.transport.TServerSocket
 
interrupt() - Method in class org.apache.thrift.transport.TServerTransport
Optional method implementation.
inTrans_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
INVALID_DATA - Static variable in exception org.apache.thrift.protocol.TProtocolException
 
INVALID_MESSAGE_TYPE - Static variable in exception org.apache.thrift.TApplicationException
 
INVALID_PROTOCOL - Static variable in exception org.apache.thrift.TApplicationException
 
INVALID_TRANSFORM - Static variable in exception org.apache.thrift.TApplicationException
 
invoke() - Method in class org.apache.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer
 
invoke() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
Actually invoke the method signified by this FrameBuffer.
iprot_ - Variable in class org.apache.thrift.TServiceClient
 
isAsyncProcessor() - Method in class org.apache.thrift.TProcessorFactory
 
isAuthenticated() - Method in interface org.apache.thrift.transport.sasl.SaslPeer
 
isAuthenticated() - Method in class org.apache.thrift.transport.sasl.ServerSaslPeer
 
isBinary() - Method in class org.apache.thrift.meta_data.FieldValueMetaData
 
isBinary() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftPrimitive
 
IScheme<T extends TBase> - Interface in org.apache.thrift.scheme
 
isComplete() - Method in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
isComplete() - Method in interface org.apache.thrift.transport.sasl.FrameHeaderReader
 
isComplete() - Method in class org.apache.thrift.transport.sasl.FrameReader
 
isComplete() - Method in class org.apache.thrift.transport.sasl.FrameWriter
 
isContainer() - Method in class org.apache.thrift.meta_data.FieldValueMetaData
 
isCurrentPhaseDone() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
 
isDataProtected() - Method in interface org.apache.thrift.transport.sasl.SaslPeer
This method can only be called when the negotiation is complete (isAuthenticated returns true).
isDataProtected() - Method in class org.apache.thrift.transport.sasl.ServerSaslPeer
 
isDefined() - Method in class org.apache.thrift.Option
Whether the Option is defined or not
isDefined() - Method in class org.apache.thrift.Option.None
 
isDefined() - Method in class org.apache.thrift.Option.Some
 
isFinished() - Method in class org.apache.thrift.async.TAsyncMethodCall
 
isFrameFullyRead() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
Check if this FrameBuffer has a full frame read.
isKey - Variable in class org.apache.thrift.protocol.TSimpleJSONProtocol.MapContext
 
isKeyStoreSet - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
isMapKey() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.Context
Returns whether the current value is a key in a map
isMapKey() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol.MapContext
 
isOneway() - Method in class org.apache.thrift.AsyncProcessFunction
 
isOneway() - Method in class org.apache.thrift.ProcessFunction
 
isOpen() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
isOpen() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
 
isOpen() - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
isOpen() - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
isOpen() - Method in class org.apache.thrift.transport.TByteBuffer
 
isOpen() - Method in class org.apache.thrift.transport.TFileTransport
open if both input/output open unless readonly
isOpen() - Method in class org.apache.thrift.transport.THttpClient
 
isOpen() - Method in class org.apache.thrift.transport.TIOStreamTransport
 
isOpen() - Method in class org.apache.thrift.transport.TMemoryBuffer
 
isOpen() - Method in class org.apache.thrift.transport.TMemoryInputTransport
 
isOpen() - Method in class org.apache.thrift.transport.TMemoryTransport
 
isOpen() - Method in class org.apache.thrift.transport.TNonblockingSocket
Checks whether the socket is connected.
isOpen() - Method in class org.apache.thrift.transport.TSaslClientTransport
True if the underlying transport is open and the SASL handshake is complete.
isOpen() - Method in class org.apache.thrift.transport.TSimpleFileTransport
Test file status
isOpen() - Method in class org.apache.thrift.transport.TSocket
Checks whether the socket is connected.
isOpen() - Method in class org.apache.thrift.transport.TTransport
Queries whether the transport is open.
isOpen() - Method in class org.apache.thrift.transport.TZlibTransport
 
isRunning() - Method in class org.apache.thrift.async.TAsyncClientManager
 
isServing() - Method in class org.apache.thrift.server.TServer
 
isSet() - Method in class org.apache.thrift.TUnion
 
isSet(int) - Method in class org.apache.thrift.TUnion
 
isSet(F) - Method in interface org.apache.thrift.TBase
Check if a field is currently set or unset.
isSet(F) - Method in class org.apache.thrift.TUnion
 
isStopped() - Method in class org.apache.thrift.server.TNonblockingServer
 
isStopped() - Method in class org.apache.thrift.server.TNonblockingServer.SelectAcceptThread
 
isStruct() - Method in class org.apache.thrift.meta_data.FieldValueMetaData
 
isTrustStoreSet - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
isTypedef() - Method in class org.apache.thrift.meta_data.FieldValueMetaData
 
isUnion() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftStructBase
 
isUnion(FieldMetaData) - Static method in class org.apache.thrift.partial.ThriftMetadata.ThriftStructBase
 
isWrapperFor(Class<?>) - Method in interface org.apache.thrift.server.ServerContext
Returns true if this server context is a wrapper for the provided application specific context interface argument or returns false otherwise.

J

joinSelector() - Method in class org.apache.thrift.server.TNonblockingServer
Block until the selector thread exits.
joinThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServer
 
JSONBaseContext() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.JSONBaseContext
 
JSONListContext() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.JSONListContext
 
JSONPairContext() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.JSONPairContext
 

K

keyData - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftMap
 
keyManagerType - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
keyMetaData - Variable in class org.apache.thrift.meta_data.MapMetaData
 
keyPass - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
keyStore - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
keyStoreStream - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
keyStoreType - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
keyType - Variable in class org.apache.thrift.protocol.TMap
 
knownMessageSize - Variable in class org.apache.thrift.transport.TEndpointTransport
 

L

len() - Method in class org.apache.thrift.TByteArrayOutputStream
 
length() - Method in class org.apache.thrift.transport.TMemoryBuffer
 
length() - Method in interface org.apache.thrift.transport.TSeekableFile
 
length() - Method in class org.apache.thrift.transport.TSimpleFileTransport
Return the length of the file in bytes
length() - Method in class org.apache.thrift.transport.TStandardFile
 
LIST - Static variable in class org.apache.thrift.protocol.TType
 
ListContext() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.ListContext
 
listen() - Method in class org.apache.thrift.transport.TNonblockingServerSocket
 
listen() - Method in class org.apache.thrift.transport.TServerSocket
 
listen() - Method in class org.apache.thrift.transport.TServerTransport
 
ListMetaData - Class in org.apache.thrift.meta_data
 
ListMetaData(byte, FieldValueMetaData) - Constructor for class org.apache.thrift.meta_data.ListMetaData
 
LOGGER - Variable in class org.apache.thrift.server.AbstractNonblockingServer
 
LOGGER - Variable in class org.apache.thrift.TBaseAsyncProcessor
 
LookaheadReader() - Constructor for class org.apache.thrift.protocol.TJSONProtocol.LookaheadReader
 

M

main(String[]) - Static method in class org.apache.thrift.transport.TFileTransport
test program
MAP - Static variable in class org.apache.thrift.protocol.TType
 
MapContext() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.MapContext
 
MapMetaData - Class in org.apache.thrift.meta_data
 
MapMetaData(byte, FieldValueMetaData, FieldValueMetaData) - Constructor for class org.apache.thrift.meta_data.MapMetaData
 
maxFrameSize(int) - Method in class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
 
maxReadBufferBytes - Variable in class org.apache.thrift.server.AbstractNonblockingServer.AbstractNonblockingServerArgs
 
maxWorkerThreads - Variable in class org.apache.thrift.server.THsHaServer.Args
 
maxWorkerThreads - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
 
maxWorkerThreads(int) - Method in class org.apache.thrift.server.THsHaServer.Args
 
maxWorkerThreads(int) - Method in class org.apache.thrift.server.TThreadPoolServer.Args
 
mechanism - Variable in class org.apache.thrift.transport.sasl.TSaslServerDefinition
 
MECHANISM_NAME_BYTES - Static variable in class org.apache.thrift.transport.TSaslClientTransport
 
MECHANISME_MISMATCH - Enum constant in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
 
minWorkerThreads - Variable in class org.apache.thrift.server.THsHaServer.Args
 
minWorkerThreads - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
 
minWorkerThreads(int) - Method in class org.apache.thrift.server.THsHaServer.Args
 
minWorkerThreads(int) - Method in class org.apache.thrift.server.TThreadPoolServer.Args
 
MISSING_RESULT - Static variable in exception org.apache.thrift.TApplicationException
 

N

name - Variable in class org.apache.thrift.partial.ThriftField
Name of this field as it appears in a thrift file.
name - Variable in class org.apache.thrift.protocol.TField
 
name - Variable in class org.apache.thrift.protocol.TMessage
 
name - Variable in class org.apache.thrift.protocol.TStruct
 
NEGATIVE_SIZE - Static variable in exception org.apache.thrift.protocol.TProtocolException
 
NegotiationStatus - Enum Class in org.apache.thrift.transport.sasl
Status bytes used during the initial Thrift SASL handshake.
networkThreads(int) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
nextThread() - Method in class org.apache.thrift.server.TThreadedSelectorServer.SelectorThreadLoadBalancer
 
noFields - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
NonblockingAbstractServerSocketArgs() - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket.NonblockingAbstractServerSocketArgs
 
NonblockingSaslHandler - Class in org.apache.thrift.transport.sasl
State machine managing one sasl connection in a nonblocking way.
NonblockingSaslHandler(SelectionKey, TNonblockingTransport, TSaslServerFactory, TSaslProcessorFactory, TProtocolFactory, TProtocolFactory, TServerEventHandler) - Constructor for class org.apache.thrift.transport.sasl.NonblockingSaslHandler
 
NonblockingSaslHandler.Phase - Enum Class in org.apache.thrift.transport.sasl
 
none() - Static method in class org.apache.thrift.Option
 
None() - Constructor for class org.apache.thrift.Option.None
 
NOT_IMPLEMENTED - Static variable in exception org.apache.thrift.protocol.TProtocolException
 
NOT_OPEN - Static variable in exception org.apache.thrift.transport.TTransportException
 
NOWAIT - Enum constant in enum class org.apache.thrift.transport.TFileTransport.TailPolicy
 
Nullable - Annotation Interface in org.apache.thrift.annotation
Annotation indicating a field, method return, or method parameter may be null.

O

of(Class<T>) - Static method in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
OK - Enum constant in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 
onComplete() - Method in class org.apache.thrift.async.TAsyncClient
Called by delegate method when finished
onComplete() - Method in class org.apache.thrift.transport.sasl.DataFrameHeaderReader
 
onComplete() - Method in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
Actions (e.g. validation) to carry out when the header is complete.
onComplete() - Method in class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 
onComplete(T) - Method in interface org.apache.thrift.async.AsyncMethodCallback
This method will be called when the remote side has completed invoking your method call and the result is fully read.
onComplete(T) - Method in class org.apache.thrift.async.AsyncMethodFutureAdapter
 
onError(Exception) - Method in interface org.apache.thrift.async.AsyncMethodCallback
This method will be called when there is either an unexpected client-side exception like an IOException or else when the remote method raises an exception, either declared in the IDL or due to an unexpected server-side error.
onError(Exception) - Method in class org.apache.thrift.async.AsyncMethodFutureAdapter
 
onError(Exception) - Method in class org.apache.thrift.async.TAsyncClient
Called by delegate method on error.
onError(Exception) - Method in class org.apache.thrift.async.TAsyncMethodCall
 
ONEWAY - Static variable in class org.apache.thrift.protocol.TMessageType
 
open() - Method in class org.apache.thrift.transport.AutoExpandingBufferReadTransport
 
open() - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
 
open() - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
open() - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
open() - Method in class org.apache.thrift.transport.TByteBuffer
 
open() - Method in class org.apache.thrift.transport.TFileTransport
Diverging from the cpp model and sticking to the TSocket model Files are not opened in ctor - but in explicit open call
open() - Method in class org.apache.thrift.transport.THttpClient
 
open() - Method in class org.apache.thrift.transport.TIOStreamTransport
The streams must already be open.
open() - Method in class org.apache.thrift.transport.TMemoryBuffer
 
open() - Method in class org.apache.thrift.transport.TMemoryInputTransport
 
open() - Method in class org.apache.thrift.transport.TMemoryTransport
Opening on an in memory transport should have no effect.
open() - Method in class org.apache.thrift.transport.TNonblockingSocket
Do not call, the implementation provides its own lazy non-blocking connect.
open() - Method in class org.apache.thrift.transport.TSaslClientTransport
Opens the underlying transport if it's not already open and then performs SASL negotiation.
open() - Method in class org.apache.thrift.transport.TSimpleFileTransport
Open file if not previously opened.
open() - Method in class org.apache.thrift.transport.TSocket
Connects the socket, creating a new socket object if necessary.
open() - Method in class org.apache.thrift.transport.TTransport
Opens the transport for reading/writing.
open() - Method in class org.apache.thrift.transport.TZlibTransport
 
oprot_ - Variable in class org.apache.thrift.TServiceClient
 
Option<T> - Class in org.apache.thrift
Implementation of the Option type pattern
Option() - Constructor for class org.apache.thrift.Option
 
Option.None<T> - Class in org.apache.thrift
The None type, representing an absent value (instead of "null")
Option.Some<T> - Class in org.apache.thrift
The Some type, representing an existence of some value
OPTIONAL - Static variable in class org.apache.thrift.TFieldRequirementType
 
or(T) - Method in class org.apache.thrift.Option
Get the contained value (if defined) or else return a default value
org.apache.thrift - package org.apache.thrift
 
org.apache.thrift.annotation - package org.apache.thrift.annotation
 
org.apache.thrift.async - package org.apache.thrift.async
 
org.apache.thrift.meta_data - package org.apache.thrift.meta_data
 
org.apache.thrift.partial - package org.apache.thrift.partial
 
org.apache.thrift.protocol - package org.apache.thrift.protocol
 
org.apache.thrift.scheme - package org.apache.thrift.scheme
 
org.apache.thrift.server - package org.apache.thrift.server
 
org.apache.thrift.transport - package org.apache.thrift.transport
 
org.apache.thrift.transport.layered - package org.apache.thrift.transport.layered
 
org.apache.thrift.transport.sasl - package org.apache.thrift.transport.sasl
 
org.apache.thrift.utils - package org.apache.thrift.utils
 
outProt_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
outputProtocolFactory(TProtocolFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
outputProtocolFactory_ - Variable in class org.apache.thrift.server.TServer
Output Protocol Factory
outputStream_ - Variable in class org.apache.thrift.transport.TFileTransport
Underlying outputStream
outputStream_ - Variable in class org.apache.thrift.transport.TIOStreamTransport
Underlying outputStream
outputTransportFactory(TTransportFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
outputTransportFactory_ - Variable in class org.apache.thrift.server.TServer
Output Transport Factory
outTrans_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 

P

paddedByteString(byte) - Static method in class org.apache.thrift.TBaseHelper
 
parent - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
 
partialDeserialize(TBase, byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only a single Thrift object (addressed by recursively using field id) from a byte record.
partialDeserializeBool(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only a boolean field (addressed by recursively using field id) from a byte record.
partialDeserializeByte(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only a byte field (addressed by recursively using field id) from a byte record.
partialDeserializeByteArray(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only a binary field (addressed by recursively using field id) from a byte record.
partialDeserializeDouble(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only a double field (addressed by recursively using field id) from a byte record.
partialDeserializeI16(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only an i16 field (addressed by recursively using field id) from a byte record.
partialDeserializeI32(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only an i32 field (addressed by recursively using field id) from a byte record.
partialDeserializeI64(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only an i64 field (addressed by recursively using field id) from a byte record.
partialDeserializeObject(byte[]) - Method in class org.apache.thrift.TDeserializer
Partially deserializes the given serialized blob.
partialDeserializeObject(byte[], int, int) - Method in class org.apache.thrift.TDeserializer
Partially deserializes the given serialized blob.
partialDeserializeSetFieldIdInUnion(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only the id of the field set in a TUnion (addressed by recursively using field id) from a byte record.
partialDeserializeString(byte[], TFieldIdEnum, TFieldIdEnum...) - Method in class org.apache.thrift.TDeserializer
Deserialize only a string field (addressed by recursively using field id) from a byte record.
partialDeserializeThriftObject(TBase, byte[], int, int) - Method in class org.apache.thrift.TDeserializer
Partially deserializes the given serialized blob into the given TBase instance.
PartialThriftComparer<T extends TBase> - Class in org.apache.thrift.partial
Enables comparison of two TBase instances such that the comparison is limited to the subset of fields defined by the supplied metadata.
PartialThriftComparer(ThriftMetadata.ThriftStruct) - Constructor for class org.apache.thrift.partial.PartialThriftComparer
Constructs an instance of PartialThriftComparer.
path_ - Variable in class org.apache.thrift.transport.TStandardFile
 
PAYLOAD_LENGTH_BYTES - Static variable in class org.apache.thrift.transport.sasl.DataFrameHeaderReader
 
PAYLOAD_LENGTH_BYTES - Static variable in class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 
PAYLOAD_LENGTH_BYTES - Static variable in class org.apache.thrift.transport.TSaslClientTransport
 
payloadSize() - Method in class org.apache.thrift.transport.sasl.DataFrameHeaderReader
 
payloadSize() - Method in interface org.apache.thrift.transport.sasl.FrameHeaderReader
As the thrift sasl specification states, all sasl messages (both for negotiatiing and for sending data) should have a header to indicate the size of the payload.
payloadSize() - Method in class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 
peek() - Method in class org.apache.thrift.protocol.TJSONProtocol.LookaheadReader
 
peek() - Method in class org.apache.thrift.transport.TTransport
Is there more data to be read?
popWriteContext() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
Pop the last write context off the stack
port(int) - Method in class org.apache.thrift.transport.TServerTransport.AbstractServerTransportArgs
 
prepareBinary(ByteBuffer) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareBinary(ByteBuffer) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
prepareEnum(Class<? extends TEnum>, int) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareEnum(Class<? extends TEnum>, int) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
prepareList(Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareList(Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
prepareMap(Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareMap(Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
prepareMethodCall() - Method in class org.apache.thrift.async.TAsyncMethodCall
Initialize buffers.
prepareSet(Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareSet(Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
prepareString(ByteBuffer) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareString(ByteBuffer) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
prepareStruct(Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
prepareStruct(Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
preServe() - Method in interface org.apache.thrift.server.TServerEventHandler
Called before the server begins.
preServe() - Method in class org.apache.thrift.server.TThreadPoolServer
 
process(int, TProtocol, TProtocol, I) - Method in class org.apache.thrift.ProcessFunction
 
process(TProtocol, TProtocol) - Method in class org.apache.thrift.TBaseAsyncProcessor
 
process(TProtocol, TProtocol) - Method in class org.apache.thrift.TBaseProcessor
 
process(TProtocol, TProtocol) - Method in class org.apache.thrift.TMultiplexedProcessor
This implementation of process performs the following steps: Read the beginning of the message.
process(TProtocol, TProtocol) - Method in interface org.apache.thrift.TProcessor
 
process(AbstractNonblockingServer.AsyncFrameBuffer) - Method in interface org.apache.thrift.TAsyncProcessor
Process a single frame.
process(AbstractNonblockingServer.AsyncFrameBuffer) - Method in class org.apache.thrift.TBaseAsyncProcessor
 
processChunk() - Method in class org.apache.thrift.transport.TFileProcessor
Process a current chunk
processChunk(int) - Method in class org.apache.thrift.transport.TFileProcessor
Process a single chunk
processChunk(int, int) - Method in class org.apache.thrift.transport.TFileProcessor
Process from start to last chunk both inclusive where chunks begin from 0
processContext(ServerContext, TTransport, TTransport) - Method in interface org.apache.thrift.server.TServerEventHandler
Called when a client is about to call the processor.
ProcessFunction<I,T extends TBase> - Class in org.apache.thrift
 
ProcessFunction(String) - Constructor for class org.apache.thrift.ProcessFunction
 
PROCESSING - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
processingThreads(int) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
processInterestChanges() - Method in class org.apache.thrift.server.AbstractNonblockingServer.AbstractSelectThread
Check to see if there are any FrameBuffers that have switched their interest type from read to write or vice versa.
processor(TProcessor) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
processor(TProcessor) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
processorFactory(TProcessorFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
processorFactory_ - Variable in class org.apache.thrift.server.TServer
Core processor
props - Variable in class org.apache.thrift.transport.sasl.TSaslServerDefinition
 
protocol - Variable in class org.apache.thrift.transport.sasl.TSaslServerDefinition
 
protocol - Variable in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
PROTOCOL_ERROR - Enum constant in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
 
PROTOCOL_ERROR - Static variable in exception org.apache.thrift.TApplicationException
 
protocolFactory(TProtocolFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
pushWriteContext(TSimpleJSONProtocol.Context) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
Push a new write context onto the stack.

R

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() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
Give this FrameBuffer a chance to read.
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.layered.TFastFramedTransport
 
read(byte[], int, int) - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
read(byte[], int, int) - Method in class org.apache.thrift.transport.TByteBuffer
 
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.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(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryTransport
 
read(byte[], int, int) - Method in class org.apache.thrift.transport.TNonblockingSocket
Reads from the underlying input stream if not null.
read(byte[], int, int) - Method in class org.apache.thrift.transport.TSaslClientTransport
Read from the underlying transport.
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(ByteBuffer) - Method in class org.apache.thrift.transport.TNonblockingSocket
Perform a nonblocking read into buffer.
read(ByteBuffer) - Method in class org.apache.thrift.transport.TTransport
Reads a sequence of bytes from this channel into the given buffer.
read(TProtocol) - Method in exception org.apache.thrift.TApplicationException
 
read(TProtocol) - Method in interface org.apache.thrift.TSerializable
Reads the TObject from the given input protocol.
read(TProtocol) - Method in class org.apache.thrift.TUnion
 
read(TProtocol, T) - Method in interface org.apache.thrift.scheme.IScheme
 
read(TTransport) - Method in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
read(TTransport) - Method in interface org.apache.thrift.transport.sasl.FrameHeaderReader
(Nonblocking) Read fields from underlying transport layer.
read(TTransport) - Method in class org.apache.thrift.transport.sasl.FrameReader
(Nonblocking) Read available bytes out of the transport without blocking to wait for incoming data.
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 ByteBuffer from the wire.
readBinary() - Method in class org.apache.thrift.protocol.TJSONProtocol
 
readBinary() - Method in class org.apache.thrift.protocol.TProtocolDecorator
 
readBinary() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readBool() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readByte() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readDouble() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readDouble() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readField(TProtocol.ReadCallback<TField, T>) - Method in class org.apache.thrift.protocol.TProtocol
read a field by delegating to a callback, handles begin and end automatically, and returns whether the stop signal was encountered.
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.TProtocolDecorator
 
readFieldBegin() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readFieldBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readFieldBeginData() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
readFieldBeginData() - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
readFieldEnd() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readFieldEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readFrom(TProtocol) - Static method in exception org.apache.thrift.TApplicationException
Convenience factory method for constructing a TApplicationException given a TProtocol input
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.TProtocolDecorator
 
readI16() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readI32() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readI64() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readI64() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
READING_REQUEST - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
READING_RESPONSE_BODY - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
READING_RESPONSE_SIZE - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
READING_SASL_RESPONSE - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
readJSONSyntaxChar(byte[]) - Method in class org.apache.thrift.protocol.TJSONProtocol
 
readLength() - Method in class org.apache.thrift.transport.TSaslClientTransport
Read a 4-byte word from the underlying transport and interpret it as an integer.
readList(TProtocol.ReadCallback<TList, T>) - Method in class org.apache.thrift.protocol.TProtocol
read a List by delegating to the callback, handles begin and end automatically.
readList(TProtocol.ReadCollectionCallback<T>) - Method in class org.apache.thrift.protocol.TProtocol
read a List by delegating element reading to the callback, handles begin and end automatically.
readList(TProtocol.ReadCollectionCallback<T>, IntFunction<List<T>>) - Method in class org.apache.thrift.protocol.TProtocol
read a List by delegating element reading to the callback, handles begin and end automatically, with a specialized list creator given the size hint.
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.TProtocolDecorator
 
readListBegin() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readListBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readListBegin(byte) - Method in class org.apache.thrift.protocol.TTupleProtocol
 
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.TProtocolDecorator
 
readListEnd() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readListEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readListEnd() - Method in class org.apache.thrift.protocol.TTupleProtocol
 
readMap(TProtocol.ReadCallback<TMap, T>) - Method in class org.apache.thrift.protocol.TProtocol
read a Map of elements by delegating to the callback, handles begin and end automatically.
readMap(TProtocol.ReadMapEntryCallback<K, V>) - Method in class org.apache.thrift.protocol.TProtocol
read a Map of elements by delegating key and value reading to the callback, handles begin and end automatically.
readMap(TProtocol.ReadMapEntryCallback<K, V>, IntFunction<Map<K, V>>) - Method in class org.apache.thrift.protocol.TProtocol
read a Map of elements by delegating key and value reading to the callback, handles begin and end automatically, with a specialized map creator given the size hint.
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.TProtocolDecorator
 
readMapBegin() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readMapBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readMapBegin(byte, byte) - Method in class org.apache.thrift.protocol.TTupleProtocol
 
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.TProtocolDecorator
 
readMapEnd() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readMapEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readMapEnd() - Method in class org.apache.thrift.protocol.TTupleProtocol
 
readMessage(TProtocol.ReadCallback<TMessage, T>) - Method in class org.apache.thrift.protocol.TProtocol
read a message by delegating to a callback, handles begin and end automatically.
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.TProtocolDecorator
 
readMessageBegin() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readMessageEnd() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readMessageEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readSet(TProtocol.ReadCallback<TSet, T>) - Method in class org.apache.thrift.protocol.TProtocol
read a Set of elements by delegating to the callback, handles begin and end automatically
readSet(TProtocol.ReadCollectionCallback<T>) - Method in class org.apache.thrift.protocol.TProtocol
read a Set of elements by delegating element reading to the callback, handles begin and end automatically
readSet(TProtocol.ReadCollectionCallback<T>, IntFunction<Set<T>>) - Method in class org.apache.thrift.protocol.TProtocol
read a Set of elements by delegating element reading to the callback, handles begin and end automatically, with a specialized set creator given the size hint.
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.TProtocolDecorator
 
readSetBegin() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readSetBegin() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readSetBegin(byte) - Method in class org.apache.thrift.protocol.TTupleProtocol
 
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.TProtocolDecorator
 
readSetEnd() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readSetEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readSetEnd() - Method in class org.apache.thrift.protocol.TTupleProtocol
 
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.TProtocolDecorator
 
readString() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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
 
readStruct(TProtocol.ReadCallback<TStruct, T>) - Method in class org.apache.thrift.protocol.TProtocol
read a struct by delegating to a callback, handles begin and end automatically.
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.TProtocolDecorator
 
readStructBegin() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
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.TProtocolDecorator
 
readStructEnd() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readStructEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
readUuid() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
readUuid() - Method in class org.apache.thrift.protocol.TCompactProtocol
 
readUuid() - Method in class org.apache.thrift.protocol.TJSONProtocol
 
readUuid() - Method in class org.apache.thrift.protocol.TProtocolDecorator
 
readUuid() - Method in interface org.apache.thrift.protocol.TReadProtocol
 
readUuid() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
receiveBase(TBase<?, ?>, String) - Method in class org.apache.thrift.TServiceClient
 
receiveSaslMessage() - Method in class org.apache.thrift.transport.TSaslClientTransport
Read a complete Thrift SASL message.
registerDefault(TProcessor) - Method in class org.apache.thrift.TMultiplexedProcessor
Register a service to be called to process queries without service name
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
 
remainingMessageSize - Variable in class org.apache.thrift.transport.TEndpointTransport
 
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() - 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.
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.
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
 
resetConsumedMessageSize(long) - Method in class org.apache.thrift.transport.TEndpointTransport
Resets RemainingMessageSize to the configured maximum
resetWriteContext() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
Reset the write context stack to its initial state.
resizeIfNecessary(int) - Method in class org.apache.thrift.transport.AutoExpandingBuffer
 
response_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
RESPONSE_READ - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
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.
rethrowUnhandledExceptions() - Method in class org.apache.thrift.ProcessFunction
 
retries_ - Variable in enum class 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.
runCurrentPhase() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
Run state machine.

S

SaslNegotiationFrameReader - Class in org.apache.thrift.transport.sasl
Read frames for sasl negotiatiions.
SaslNegotiationFrameReader() - Constructor for class org.apache.thrift.transport.sasl.SaslNegotiationFrameReader
 
SaslNegotiationFrameWriter - Class in org.apache.thrift.transport.sasl
Writer for sasl negotiation frames.
SaslNegotiationFrameWriter() - Constructor for class org.apache.thrift.transport.sasl.SaslNegotiationFrameWriter
 
SaslNegotiationHeaderReader - Class in org.apache.thrift.transport.sasl
Header for sasl negotiation frames.
SaslNegotiationHeaderReader() - Constructor for class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 
SaslPeer - Interface in org.apache.thrift.transport.sasl
A peer in a sasl negotiation.
saslProcessorFactory(TSaslProcessorFactory) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
saslServerFactory(TSaslServerFactory) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
saslThreads(int) - Method in class org.apache.thrift.server.TSaslNonblockingServer.Args
 
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
 
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.
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
 
SelectorThread() - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
Set up the SelectorThread with an unbounded queue for incoming accepts.
SelectorThread(int) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
Set up the SelectorThread with an bounded queue for incoming accepts.
SelectorThread(BlockingQueue<TNonblockingTransport>) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThread
Set up the SelectorThread with a specified queue for connections.
SelectorThreadLoadBalancer(Collection<T>) - Constructor for class org.apache.thrift.server.TThreadedSelectorServer.SelectorThreadLoadBalancer
 
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
 
sendAndThrowMessage(NegotiationStatus, String) - Method in class org.apache.thrift.transport.TSaslClientTransport
Send a Thrift SASL message with the given status (usually BAD or ERROR) and string message, and then throw a TTransportException with the given message.
sendBase(String, TBase<?, ?>) - Method in class org.apache.thrift.TServiceClient
 
sendBaseOneway(String, TBase<?, ?>) - Method in class org.apache.thrift.TServiceClient
 
sendResponse(AbstractNonblockingServer.AsyncFrameBuffer, TSerializable, byte, int) - Method in class org.apache.thrift.AsyncProcessFunction
 
sendSaslMessage(NegotiationStatus, byte[]) - Method in class org.apache.thrift.transport.TSaslClientTransport
Send a complete Thrift SASL message.
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.TSaslNonblockingServer
 
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
 
serverName - Variable in class org.apache.thrift.transport.sasl.TSaslServerDefinition
 
ServerSaslPeer - Class in org.apache.thrift.transport.sasl
Server side sasl peer, a wrapper around SaslServer to provide some handy methods.
ServerSaslPeer(SaslServer) - Constructor for class org.apache.thrift.transport.sasl.ServerSaslPeer
 
serverSocket(ServerSocket) - Method in class org.apache.thrift.transport.TServerSocket.ServerSocketTransportArgs
 
ServerSocketTransportArgs() - Constructor for 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
 
setBinary(TBase, TFieldIdEnum, ByteBuffer) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setBinary(V, TFieldIdEnum, ByteBuffer) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
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(int, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
 
setBit(long, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
 
setBit(short, int, boolean) - Static method in class org.apache.thrift.EncodingUtils
 
setBool(TBase, TFieldIdEnum, boolean) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setBool(V, TFieldIdEnum, boolean) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setByte(TBase, TFieldIdEnum, byte) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setByte(V, TFieldIdEnum, byte) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setConnectTimeout(int) - Method in class org.apache.thrift.transport.THttpClient
 
setConnectTimeout(int) - Method in class org.apache.thrift.transport.TSocket
Sets the time after which the connection attempt will time out
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
 
setDouble(TBase, TFieldIdEnum, double) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setDouble(V, TFieldIdEnum, double) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setEnumField(TBase, TFieldIdEnum, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setEnumField(V, TFieldIdEnum, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setField_ - Variable in class org.apache.thrift.TUnion
 
setFieldValue(int, Object) - Method 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
 
setInt16(TBase, TFieldIdEnum, short) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setInt16(V, TFieldIdEnum, short) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setInt32(TBase, TFieldIdEnum, int) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setInt32(V, TFieldIdEnum, int) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setInt64(TBase, TFieldIdEnum, long) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setInt64(V, TFieldIdEnum, long) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setKeyStore(InputStream, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
Set the keystore and password
setKeyStore(InputStream, 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
setKeyStore(String, String, String, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
Set the keystore, password, certificate type and the store type
setListElement(Object, int, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setListElement(Object, int, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setListField(TBase, TFieldIdEnum, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setListField(V, TFieldIdEnum, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setMapElement(Object, int, Object, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setMapElement(Object, int, Object, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setMapField(TBase, TFieldIdEnum, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setMapField(V, TFieldIdEnum, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setMaxFrameSize(int) - Method in class org.apache.thrift.TConfiguration.Builder
 
setMaxFrameSize(int) - Method in class org.apache.thrift.TConfiguration
 
setMaxFrameSize(int) - Method in class org.apache.thrift.transport.TEndpointTransport
 
setMaxMessageSize(int) - Method in class org.apache.thrift.TConfiguration.Builder
 
setMaxMessageSize(int) - Method in class org.apache.thrift.TConfiguration
 
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
Deprecated.
setRecursionLimit(int) - Method in class org.apache.thrift.TConfiguration.Builder
 
setRecursionLimit(int) - Method in class org.apache.thrift.TConfiguration
 
setSaslServer(SaslServer) - Method in class org.apache.thrift.transport.TSaslClientTransport
 
setServerEventHandler(TServerEventHandler) - Method in class org.apache.thrift.server.TServer
 
setServing(boolean) - Method in class org.apache.thrift.server.TServer
 
setSetElement(Object, int, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setSetElement(Object, int, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setSetField(TBase, TFieldIdEnum, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setSetField(V, TFieldIdEnum, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setShouldStop(boolean) - Method in class org.apache.thrift.server.TServer
 
setSocketTimeout(int) - Method in class org.apache.thrift.transport.TSocket
Sets the socket timeout
setString(TBase, TFieldIdEnum, ByteBuffer) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setString(V, TFieldIdEnum, ByteBuffer) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setStructField(TBase, TFieldIdEnum, Object) - Method in class org.apache.thrift.partial.ThriftStructProcessor
 
setStructField(V, TFieldIdEnum, Object) - Method in interface org.apache.thrift.partial.ThriftFieldValueProcessor
 
setTailPolicy(TFileTransport.TailPolicy) - Method in class org.apache.thrift.transport.TFileTransport
Set file Tailing Policy
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 and connection timeout.
setTimeout(long) - Method in class org.apache.thrift.async.TAsyncClient
 
setTrustStore(InputStream, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
Set the truststore and password
setTrustStore(InputStream, 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
setTrustStore(String, String, String, String) - Method in class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
Set the truststore, password, certificate type and the store type
shutdown() - Method in class org.apache.thrift.server.TSaslNonblockingServer
Gracefully shut down the server and block until all threads are stopped.
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(byte) - Method in class org.apache.thrift.protocol.TProtocol
 
skip(byte, int) - Method in class org.apache.thrift.protocol.TProtocol
 
skip(int) - Method in class org.apache.thrift.transport.TFileTransport.ChunkState
 
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.
skipBinary() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipBinary() - Method in class org.apache.thrift.protocol.TCompactProtocol
 
skipBinary() - Method in class org.apache.thrift.protocol.TProtocol
 
skipBool() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipBool() - Method in class org.apache.thrift.protocol.TProtocol
The default implementation of all skip() methods calls the corresponding read() method.
skipByte() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipByte() - Method in class org.apache.thrift.protocol.TProtocol
 
skipBytes(int) - Method in class org.apache.thrift.protocol.TProtocol
 
skipDouble() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipDouble() - Method in class org.apache.thrift.protocol.TProtocol
 
skipI16() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipI16() - Method in class org.apache.thrift.protocol.TProtocol
 
skipI32() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipI32() - Method in class org.apache.thrift.protocol.TProtocol
 
skipI64() - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
skipI64() - Method in class org.apache.thrift.protocol.TProtocol
 
skippedBytes - Variable in class org.apache.thrift.protocol.TProtocol
 
some(T) - Static method in class org.apache.thrift.Option
Wrap value in a Some type (NB!
Some(T) - Constructor for class org.apache.thrift.Option.Some
 
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
 
START - Enum constant in enum class org.apache.thrift.transport.sasl.NegotiationStatus
 
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
 
STATUS_BYTES - Static variable in class org.apache.thrift.transport.sasl.SaslNegotiationHeaderReader
 
STATUS_BYTES - Static variable in class org.apache.thrift.transport.TSaslClientTransport
 
stepToNextPhase() - Method in class org.apache.thrift.transport.sasl.NonblockingSaslHandler
When current phase is finished, it's expected to call this method first before running the state machine again.
stop() - Method in class org.apache.thrift.async.TAsyncClientManager
 
stop() - Method in class org.apache.thrift.server.TNonblockingServer
Stop serving and shut everything down.
stop() - Method in class org.apache.thrift.server.TSaslNonblockingServer
Trigger a graceful shutdown, but it does not block to wait for the shutdown to finish.
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
 
STOP - Static variable in class org.apache.thrift.protocol.TType
 
stopListening() - Method in class org.apache.thrift.server.AbstractNonblockingServer
Stop listening for connections.
stopped_ - Variable in class org.apache.thrift.server.TServer
 
stopTimeoutUnit - Variable in class org.apache.thrift.server.TThreadPoolServer.Args
 
stopTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.THsHaServer.Args
 
stopTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
 
stopTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.TThreadPoolServer.Args
 
stopTimeoutVal - 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(int) - Method 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
 
StringUtils - Class in org.apache.thrift.utils
 
STRUCT - Static variable in class org.apache.thrift.protocol.TType
 
structClass - Variable in class org.apache.thrift.meta_data.StructMetaData
 
StructContext() - Constructor for class org.apache.thrift.protocol.TSimpleJSONProtocol.StructContext
 
StructMetaData - Class in org.apache.thrift.meta_data
 
StructMetaData(byte, Class<? extends TBase>) - Constructor for class org.apache.thrift.meta_data.StructMetaData
 

T

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.
TAsyncMethodCall(TAsyncClient, TProtocolFactory, TNonblockingTransport, AsyncMethodCallback<T>, boolean) - Constructor for class org.apache.thrift.async.TAsyncMethodCall
 
TAsyncMethodCall.State - Enum Class in org.apache.thrift.async
 
TAsyncProcessor - Interface in org.apache.thrift
 
TBase<T extends TBase<T,F>,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
 
TBaseSaslProcessorFactory - Class in org.apache.thrift.transport.sasl
 
TBaseSaslProcessorFactory(TProcessor) - Constructor for class org.apache.thrift.transport.sasl.TBaseSaslProcessorFactory
 
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) - 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
TByteArrayOutputStream - Class in org.apache.thrift
Class that allows access to the underlying buf without doing deep copies on it.
TByteArrayOutputStream() - Constructor for class org.apache.thrift.TByteArrayOutputStream
 
TByteArrayOutputStream(int) - Constructor for class org.apache.thrift.TByteArrayOutputStream
 
TByteBuffer - Class in org.apache.thrift.transport
ByteBuffer-backed implementation of TTransport.
TByteBuffer(ByteBuffer) - Constructor for class org.apache.thrift.transport.TByteBuffer
Creates a new TByteBuffer wrapping a given NIO ByteBuffer.
TByteBuffer(TConfiguration, ByteBuffer) - Constructor for class org.apache.thrift.transport.TByteBuffer
Creates a new TByteBuffer wrapping a given NIO ByteBuffer and custom TConfiguration.
TCompactProtocol - Class in org.apache.thrift.protocol
TCompactProtocol2 is the Java implementation of the compact protocol specified in THRIFT-110.
TCompactProtocol(TTransport) - 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, long, long) - Constructor for class org.apache.thrift.protocol.TCompactProtocol
Create a TCompactProtocol.
TCompactProtocol.Factory - Class in org.apache.thrift.protocol
TProtocolFactory that produces TCompactProtocols.
TConfiguration - Class in org.apache.thrift
 
TConfiguration() - Constructor for class org.apache.thrift.TConfiguration
 
TConfiguration(int, int, int) - Constructor for class org.apache.thrift.TConfiguration
 
TConfiguration.Builder - Class in org.apache.thrift
 
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(Class<? extends TBase>, Collection<String>, ThriftFieldValueProcessor, TProtocolFactory) - Constructor for class org.apache.thrift.TDeserializer
Construct a new TDeserializer that supports partial deserialization that outputs instances of type controlled by the given processor.
TDeserializer(Class<? extends TBase>, Collection<String>, TProtocolFactory) - Constructor for class org.apache.thrift.TDeserializer
Construct a new TDeserializer that supports partial deserialization that outputs TBase instances.
TDeserializer(TProtocolFactory) - Constructor for class org.apache.thrift.TDeserializer
Create a new TDeserializer.
TEndpointTransport - Class in org.apache.thrift.transport
 
TEndpointTransport(TConfiguration) - Constructor for class org.apache.thrift.transport.TEndpointTransport
 
TEnum - Interface in org.apache.thrift
 
TEnumHelper - Class in org.apache.thrift
Utility class with static methods for interacting with TEnum
TEOFException - Exception in org.apache.thrift.transport
End of file, especially, the underlying socket is closed.
TEOFException(String) - Constructor for exception org.apache.thrift.transport.TEOFException
 
testBit(byte, int) - Static method in class org.apache.thrift.EncodingUtils
Bitfield utilities.
testBit(int, int) - Static method in class org.apache.thrift.EncodingUtils
 
testBit(long, int) - Static method in class org.apache.thrift.EncodingUtils
 
testBit(short, 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(String, Throwable) - Constructor for exception org.apache.thrift.TException
 
TException(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.layered
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.layered.TFastFramedTransport
Create a new TFastFramedTransport.
TFastFramedTransport(TTransport, int) - Constructor for class org.apache.thrift.transport.layered.TFastFramedTransport
Create a new TFastFramedTransport.
TFastFramedTransport(TTransport, int, int) - Constructor for class org.apache.thrift.transport.layered.TFastFramedTransport
 
TFastFramedTransport.Factory - Class in org.apache.thrift.transport.layered
 
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
 
TFieldData - Class in org.apache.thrift.partial
Holds the type and id members of a TField into a single int.
TFieldData() - Constructor for class org.apache.thrift.partial.TFieldData
 
TFieldIdEnum - Interface in org.apache.thrift
Interface for all generated struct Fields objects.
TFieldRequirementType - Class in org.apache.thrift
Requirement type constants.
TFileProcessor - Class in org.apache.thrift.transport
FileProcessor: helps in processing files generated by TFileTransport.
TFileProcessor(TProcessor, TProtocolFactory, TProtocolFactory, TFileTransport, TTransport) - Constructor for class org.apache.thrift.transport.TFileProcessor
 
TFileProcessor(TProcessor, 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.Event - Class in org.apache.thrift.transport
 
TFileTransport.TailPolicy - Enum Class in org.apache.thrift.transport
 
TFileTransport.TruncableBufferedInputStream - Class in org.apache.thrift.transport
 
TFramedTransport - Class in org.apache.thrift.transport.layered
TFramedTransport is a buffered TTransport that ensures a fully read message every time by preceding messages with a 4-byte frame size.
TFramedTransport(TTransport) - Constructor for class org.apache.thrift.transport.layered.TFramedTransport
 
TFramedTransport(TTransport, int) - Constructor for class org.apache.thrift.transport.layered.TFramedTransport
Constructor wraps around another transport
TFramedTransport.Factory - Class in org.apache.thrift.transport.layered
 
ThriftContainer(ThriftMetadata.ThriftObject, TFieldIdEnum, FieldMetaData) - Constructor for class org.apache.thrift.partial.ThriftMetadata.ThriftContainer
 
ThriftField - Class in org.apache.thrift.partial
Holds name of a thrift field and of its sub-fields recursively.
ThriftFieldValueProcessor<V> - Interface in org.apache.thrift.partial
Provides an abstraction to process deserialized field values and place them into the collection that holds them.
ThriftMetadata - Class in org.apache.thrift.partial
Container for Thrift metadata classes such as ThriftMetadata.ThriftPrimitive, ThriftMetadata.ThriftList, etc.
ThriftMetadata() - Constructor for class org.apache.thrift.partial.ThriftMetadata
 
ThriftMetadata.ThriftContainer - Class in org.apache.thrift.partial
Metadata of container like objects: list, set, map
ThriftMetadata.ThriftEnum - Class in org.apache.thrift.partial
 
ThriftMetadata.ThriftList - Class in org.apache.thrift.partial
 
ThriftMetadata.ThriftMap - Class in org.apache.thrift.partial
 
ThriftMetadata.ThriftObject - Class in org.apache.thrift.partial
Base class of field types that can be partially deserialized.
ThriftMetadata.ThriftPrimitive - Class in org.apache.thrift.partial
Metadata about primitive types.
ThriftMetadata.ThriftSet - Class in org.apache.thrift.partial
 
ThriftMetadata.ThriftStruct<U extends TBase> - Class in org.apache.thrift.partial
Metadata of a Thrift struct.
ThriftMetadata.ThriftStructBase<U extends TBase> - Class in org.apache.thrift.partial
Base class for metadata of ThriftStruct and ThriftUnion.
ThriftMetadata.ThriftUnion<U extends TBase> - Class in org.apache.thrift.partial
Metadata of a Thrift union.
ThriftStructBase(ThriftMetadata.ThriftObject, TFieldIdEnum, FieldMetaData) - Constructor for class org.apache.thrift.partial.ThriftMetadata.ThriftStructBase
 
ThriftStructProcessor - Class in org.apache.thrift.partial
Provides a way to create and initialize an instance of TBase during partial deserialization.
ThriftStructProcessor() - Constructor for class org.apache.thrift.partial.ThriftStructProcessor
 
ThriftUnion(ThriftMetadata.ThriftObject, TFieldIdEnum, FieldMetaData, Iterable<ThriftField>) - Constructor for class org.apache.thrift.partial.ThriftMetadata.ThriftUnion
 
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
 
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(TConfiguration, String) - Constructor for class org.apache.thrift.transport.THttpClient
 
THttpClient(TConfiguration, String, HttpClient) - Constructor for class org.apache.thrift.transport.THttpClient
 
THttpClient.Factory - Class in org.apache.thrift.transport
 
THttpClientResponseHandler - Class in org.apache.thrift
 
THttpClientResponseHandler() - Constructor for class org.apache.thrift.THttpClientResponseHandler
 
TIMED_OUT - Static variable in exception org.apache.thrift.transport.TTransportException
 
timeout_ - Variable in enum class org.apache.thrift.transport.TFileTransport.TailPolicy
Time in milliseconds to sleep before next read If 0, no sleep
TInvalidSaslFrameException - Exception in org.apache.thrift.transport.sasl
Got an invalid frame that does not respect the thrift sasl protocol.
TInvalidSaslFrameException(String) - Constructor for exception org.apache.thrift.transport.sasl.TInvalidSaslFrameException
 
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, constructs an input only transport.
TIOStreamTransport(InputStream, OutputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
Two-way stream constructor.
TIOStreamTransport(OutputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
Output stream constructor, constructs an output only transport.
TIOStreamTransport(TConfiguration) - 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(TConfiguration, InputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
Input stream constructor, constructs an input only transport.
TIOStreamTransport(TConfiguration, InputStream, OutputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
Two-way stream constructor.
TIOStreamTransport(TConfiguration, OutputStream) - Constructor for class org.apache.thrift.transport.TIOStreamTransport
Output stream constructor, constructs an output only transport.
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.JSONBaseContext - Class in org.apache.thrift.protocol
 
TJSONProtocol.JSONListContext - Class in org.apache.thrift.protocol
 
TJSONProtocol.JSONPairContext - Class in org.apache.thrift.protocol
 
TJSONProtocol.LookaheadReader - Class in org.apache.thrift.protocol
 
TLayeredTransport - Class in org.apache.thrift.transport.layered
 
TLayeredTransport(TTransport) - Constructor for class org.apache.thrift.transport.layered.TLayeredTransport
 
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.
TMemoryBuffer(TConfiguration, 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
 
TMemoryInputTransport(TConfiguration) - Constructor for class org.apache.thrift.transport.TMemoryInputTransport
 
TMemoryInputTransport(TConfiguration, byte[]) - Constructor for class org.apache.thrift.transport.TMemoryInputTransport
 
TMemoryInputTransport(TConfiguration, byte[], int, int) - Constructor for class org.apache.thrift.transport.TMemoryInputTransport
 
TMemoryTransport - Class in org.apache.thrift.transport
In memory transport with separate buffers for input and output.
TMemoryTransport(byte[]) - Constructor for class org.apache.thrift.transport.TMemoryTransport
 
TMemoryTransport(TConfiguration, byte[]) - Constructor for class org.apache.thrift.transport.TMemoryTransport
 
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.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.
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(int, int, int) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
 
TNonblockingServerSocket(InetSocketAddress) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
 
TNonblockingServerSocket(InetSocketAddress, int) - Constructor for class org.apache.thrift.transport.TNonblockingServerSocket
 
TNonblockingServerSocket(InetSocketAddress, int, 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
 
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(TConfiguration) - Constructor for class org.apache.thrift.transport.TNonblockingTransport
 
toByteArray() - Method in class org.apache.thrift.transport.TByteBuffer
Convenience method to convert the underlying NIO ByteBuffer to a plain old byte array.
toByteArray(BitSet, int) - Static method in class org.apache.thrift.protocol.TTupleProtocol
Returns a byte array of at least length 1.
toBytes() - Method in class org.apache.thrift.transport.sasl.FixedSizeHeaderReader
 
toBytes() - Method in interface org.apache.thrift.transport.sasl.FrameHeaderReader
 
toOptional() - Method in class org.apache.thrift.Option
Turn this Option into Java 8 Optional type
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftEnum
 
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftList
 
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftMap
 
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftObject
Converts this instance to formatted and indented string representation.
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftPrimitive
 
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftSet
 
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
toPrettyString(StringBuilder, int) - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftUnion
 
toString() - Method in class org.apache.thrift.Option.None
 
toString() - Method in class org.apache.thrift.Option.Some
 
toString() - Method in class org.apache.thrift.partial.ThriftField
 
toString() - Method in class org.apache.thrift.partial.ThriftMetadata.ThriftStruct
 
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.TNonblockingMultiFetchStats
 
toString() - Method in class org.apache.thrift.transport.TNonblockingSocket
 
toString() - Method in class org.apache.thrift.TUnion
 
toString(ByteBuffer, StringBuilder) - Static method in class org.apache.thrift.TBaseHelper
 
toString(Charset) - Method in class org.apache.thrift.TByteArrayOutputStream
 
toString(Charset) - Method in class org.apache.thrift.transport.TMemoryBuffer
Output the contents of the memory buffer as a String, using the supplied encoding
toString(Collection<ByteBuffer>, StringBuilder) - Static method in class org.apache.thrift.TBaseHelper
 
toString(TBase<?, ?>) - Method in class org.apache.thrift.TSerializer
Serialize the Thrift object into a Java string, using the default JVM charset encoding.
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
TProtocol.ReadCallback<T,R> - Interface in org.apache.thrift.protocol
 
TProtocol.ReadCollectionCallback<R> - Interface in org.apache.thrift.protocol
 
TProtocol.ReadMapEntryCallback<K,V> - Interface in org.apache.thrift.protocol
 
TProtocol.WriteCallback<T> - Interface in org.apache.thrift.protocol
 
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(int, String, Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
 
TProtocolException(int, Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
 
TProtocolException(String) - Constructor for exception org.apache.thrift.protocol.TProtocolException
 
TProtocolException(String, Throwable) - Constructor for exception org.apache.thrift.protocol.TProtocolException
 
TProtocolException(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.
trans_ - Variable in class org.apache.thrift.protocol.TProtocol
Transport
trans_ - Variable in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
 
transport - Variable in class org.apache.thrift.async.TAsyncMethodCall
 
transportFactory(TTransportFactory) - Method in class org.apache.thrift.server.TServer.AbstractServerArgs
 
TReadProtocol - Interface in org.apache.thrift.protocol
 
trunc() - Method in class org.apache.thrift.transport.TFileTransport.TruncableBufferedInputStream
 
TruncableBufferedInputStream(InputStream) - Constructor for class org.apache.thrift.transport.TFileTransport.TruncableBufferedInputStream
 
TruncableBufferedInputStream(InputStream, int) - Constructor for 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
 
trustStoreStream - 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(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.
TSaslClientTransport(SaslClient, TTransport) - Constructor for class org.apache.thrift.transport.TSaslClientTransport
Uses the given SaslClient.
TSaslNegotiationException - Exception in org.apache.thrift.transport.sasl
Exception for sasl negotiation errors.
TSaslNegotiationException(TSaslNegotiationException.ErrorType, String) - Constructor for exception org.apache.thrift.transport.sasl.TSaslNegotiationException
 
TSaslNegotiationException(TSaslNegotiationException.ErrorType, String, Throwable) - Constructor for exception org.apache.thrift.transport.sasl.TSaslNegotiationException
 
TSaslNegotiationException.ErrorType - Enum Class in org.apache.thrift.transport.sasl
 
TSaslNonblockingServer - Class in org.apache.thrift.server
TServer with sasl support, using asynchronous execution and nonblocking io.
TSaslNonblockingServer(TSaslNonblockingServer.Args) - Constructor for class org.apache.thrift.server.TSaslNonblockingServer
 
TSaslNonblockingServer.Args - Class in org.apache.thrift.server
 
TSaslProcessorFactory - Interface in org.apache.thrift.transport.sasl
Get processor for a given state machine, so that users can customize the behavior of a TProcessor by interacting with the state machine.
TSaslServerDefinition - Class in org.apache.thrift.transport.sasl
Contains all the parameters used to define a SASL server implementation.
TSaslServerDefinition(String, String, String, Map<String, String>, CallbackHandler) - Constructor for class org.apache.thrift.transport.sasl.TSaslServerDefinition
 
TSaslServerFactory - Class in org.apache.thrift.transport.sasl
Factory to create sasl server.
TSaslServerFactory() - Constructor for class org.apache.thrift.transport.sasl.TSaslServerFactory
 
TSaslServerTransport - Class in org.apache.thrift.transport
Wraps another Thrift TTransport, but performs SASL server negotiation on the call to open().
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(TTransport) - Constructor for class org.apache.thrift.transport.TSaslServerTransport
Uses the given underlying transport.
TSaslServerTransport.Factory - Class in org.apache.thrift.transport
TTransportFactory to create TSaslServerTransports.
TSeekableFile - Interface in org.apache.thrift.transport
 
TSerializable - Interface in org.apache.thrift
Generic base interface for generated Thrift objects.
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.Args - Class in org.apache.thrift.server
 
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(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(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(TServerSocket.ServerSocketTransportArgs) - Constructor for class org.apache.thrift.transport.TServerSocket
 
TServerSocket.ServerSocketTransportArgs - Class in org.apache.thrift.transport
 
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
 
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) - Constructor for class org.apache.thrift.server.TServlet
 
TServlet(TProcessor, TProtocolFactory, 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) - Constructor for class org.apache.thrift.transport.TSimpleFileTransport
Create a transport backed by a simple read only disk file (implicitly opens 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, boolean, boolean, boolean) - Constructor for class org.apache.thrift.transport.TSimpleFileTransport
Create a transport backed by a simple file
TSimpleFileTransport(TConfiguration, String, boolean, boolean, boolean) - Constructor for class org.apache.thrift.transport.TSimpleFileTransport
Create a transport backed by a simple 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.Context - Class in org.apache.thrift.protocol
 
TSimpleJSONProtocol.Factory - Class in org.apache.thrift.protocol
Factory
TSimpleJSONProtocol.ListContext - Class in org.apache.thrift.protocol
 
TSimpleJSONProtocol.MapContext - Class in org.apache.thrift.protocol
 
TSimpleJSONProtocol.StructContext - Class in org.apache.thrift.protocol
 
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(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.
TSocket(Socket) - Constructor for class org.apache.thrift.transport.TSocket
Constructor that takes an already created socket.
TSocket(TConfiguration, 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(TConfiguration, 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.
TSocket(TConfiguration, String, int, 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, with a specific connection timeout and a specific socket timeout.
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
TSSLTransportParameters() - Constructor for class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
 
TSSLTransportParameters(String, String[]) - Constructor for class org.apache.thrift.transport.TSSLTransportFactory.TSSLTransportParameters
Create parameters specifying the protocol and cipher suites
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.Args - Class in org.apache.thrift.server
 
TThreadedSelectorServer.Args.AcceptPolicy - Enum Class 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.SelectorThreadLoadBalancer - Class in org.apache.thrift.server
A round robin load balancer for choosing selector threads for new connections.
TThreadPoolServer - Class in org.apache.thrift.server
Server which uses Java's built in ThreadPool management to spawn off a worker pool that deals with client connections in blocking way.
TThreadPoolServer(TThreadPoolServer.Args) - Constructor for class org.apache.thrift.server.TThreadPoolServer
 
TThreadPoolServer.Args - Class in org.apache.thrift.server
 
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(int, String, Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
 
TTransportException(int, Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
 
TTransportException(String) - Constructor for exception org.apache.thrift.transport.TTransportException
 
TTransportException(String, Throwable) - Constructor for exception org.apache.thrift.transport.TTransportException
 
TTransportException(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
 
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<T,F>,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
 
TWriteProtocol - Interface in org.apache.thrift.protocol
 
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
 
TZlibTransport - Class in org.apache.thrift.transport
TZlibTransport deflates on write and inflates on read.
TZlibTransport(TTransport) - Constructor for class org.apache.thrift.transport.TZlibTransport
Constructs a new TZlibTransport instance.
TZlibTransport(TTransport, int) - Constructor for class org.apache.thrift.transport.TZlibTransport
Constructs a new TZlibTransport instance.
TZlibTransport.Factory - Class in org.apache.thrift.transport
 

U

underlyingTransport - Variable in class org.apache.thrift.transport.TSaslClientTransport
Transport underlying this one.
UNKNOWN - Static variable in exception org.apache.thrift.protocol.TProtocolException
 
UNKNOWN - Static variable in exception org.apache.thrift.TApplicationException
 
UNKNOWN - Static variable in exception org.apache.thrift.transport.TTransportException
 
UNKNOWN_METHOD - Static variable in exception org.apache.thrift.TApplicationException
 
UNSUPPORTED_CLIENT_TYPE - Static variable in exception org.apache.thrift.TApplicationException
 
unwrap(byte[]) - Method in interface org.apache.thrift.transport.sasl.SaslPeer
Unwrap the whole byte array.
unwrap(byte[], int, int) - Method in interface org.apache.thrift.transport.sasl.SaslPeer
Unwrap protected data to raw bytes.
unwrap(byte[], int, int) - Method in class org.apache.thrift.transport.sasl.ServerSaslPeer
 
unwrap(Class<T>) - Method in interface org.apache.thrift.server.ServerContext
Returns an object that implements the given interface to allow access to application specific contexts.
updateKnownMessageSize(long) - Method in class org.apache.thrift.transport.layered.TLayeredTransport
 
updateKnownMessageSize(long) - Method in class org.apache.thrift.transport.TEndpointTransport
Updates RemainingMessageSize to reflect then known real message size (e.g. framed transport).
updateKnownMessageSize(long) - Method in class org.apache.thrift.transport.TFileTransport
 
updateKnownMessageSize(long) - Method in class org.apache.thrift.transport.TTransport
 
UUID - Static variable in class org.apache.thrift.protocol.TType
 

V

validate() - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
 
Validate - Class in org.apache.thrift.partial
A superset of Validate class in Apache commons lang3.
value_ - Variable in class org.apache.thrift.TUnion
 
valueData - Variable in class org.apache.thrift.partial.ThriftMetadata.ThriftMap
 
valueMetaData - Variable in class org.apache.thrift.meta_data.FieldMetaData
 
valueMetaData - Variable in class org.apache.thrift.meta_data.MapMetaData
 
valueOf(String) - Static method in enum class org.apache.thrift.async.TAsyncMethodCall.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.thrift.server.TThreadedSelectorServer.Args.AcceptPolicy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.thrift.transport.sasl.NegotiationStatus
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.thrift.transport.TFileTransport.TailPolicy
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.apache.thrift.async.TAsyncMethodCall.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.thrift.server.TThreadedSelectorServer.Args.AcceptPolicy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.thrift.transport.sasl.NegotiationStatus
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.thrift.transport.sasl.TSaslNegotiationException.ErrorType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.thrift.transport.TFileTransport.TailPolicy
Returns an array containing the constants of this enum class, in the order they are declared.
valueType - Variable in class org.apache.thrift.protocol.TMap
 
VERSION_1 - Static variable in class org.apache.thrift.protocol.TBinaryProtocol
 
VERSION_MASK - Static variable in class org.apache.thrift.protocol.TBinaryProtocol
 
VOID - Static variable in class org.apache.thrift.protocol.TType
 

W

WAIT_FOREVER - Enum constant in enum class org.apache.thrift.transport.TFileTransport.TailPolicy
 
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
A method that will block until when threads handling the serving have been shut down.
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.
waitForShutdown() - Method in class org.apache.thrift.server.TThreadPoolServer
 
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.
withHeaderAndPayload(byte[], byte[]) - Method in class org.apache.thrift.transport.sasl.FrameWriter
Provide (maybe empty) header and payload to the frame.
withHeaderAndPayload(byte[], int, int, byte[], int, int) - Method in class org.apache.thrift.transport.sasl.FrameWriter
Provide extra header and payload to the frame.
withOnlyPayload(byte[]) - Method in class org.apache.thrift.transport.sasl.FrameWriter
Provide only payload to the frame.
withOnlyPayload(byte[], int, int) - Method in class org.apache.thrift.transport.sasl.DataFrameWriter
 
withOnlyPayload(byte[], int, int) - Method in class org.apache.thrift.transport.sasl.FrameWriter
Provide only payload to the frame.
withOnlyPayload(byte[], int, int) - Method in class org.apache.thrift.transport.sasl.SaslNegotiationFrameWriter
 
workerThreads(int) - Method in class org.apache.thrift.server.THsHaServer.Args
workerThreads(int) - Method in class org.apache.thrift.server.TThreadedSelectorServer.Args
 
wrap(byte[]) - Method in interface org.apache.thrift.transport.sasl.SaslPeer
Wrap the whole byte array.
wrap(byte[], int, int) - Method in interface org.apache.thrift.transport.sasl.SaslPeer
Wrap raw bytes to protect it.
wrap(byte[], int, int) - Method in class org.apache.thrift.transport.sasl.ServerSaslPeer
 
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() - Method in class org.apache.thrift.server.AbstractNonblockingServer.FrameBuffer
Give this FrameBuffer a chance to write its output to the final client.
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.AutoExpandingBufferReadTransport
 
write(byte[], int, int) - Method in class org.apache.thrift.transport.AutoExpandingBufferWriteTransport
 
write(byte[], int, int) - Method in class org.apache.thrift.transport.layered.TFastFramedTransport
 
write(byte[], int, int) - Method in class org.apache.thrift.transport.layered.TFramedTransport
 
write(byte[], int, int) - Method in class org.apache.thrift.transport.TByteBuffer
 
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.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(byte[], int, int) - Method in class org.apache.thrift.transport.TMemoryTransport
 
write(byte[], int, int) - Method in class org.apache.thrift.transport.TNonblockingSocket
Writes to the underlying output stream if not null.
write(byte[], int, int) - Method in class org.apache.thrift.transport.TSaslClientTransport
Write to the underlying transport.
write(byte[], int, int) - Method in class org.apache.thrift.transport.TSimpleFileTransport
Write len many bytes from buff starting at offset
write(byte[], int, int) - Method in class org.apache.thrift.transport.TTransport
Writes up to len bytes from the buffer.
write(ByteBuffer) - Method in class org.apache.thrift.transport.TNonblockingSocket
Perform a nonblocking write of the data in buffer;
write(ByteBuffer) - Method in class org.apache.thrift.transport.TTransport
Writes a sequence of bytes to the buffer.
write(TProtocol) - Method in exception org.apache.thrift.TApplicationException
 
write(TProtocol) - Method in interface org.apache.thrift.TSerializable
Writes the objects out to the protocol
write(TProtocol) - Method in class org.apache.thrift.TUnion
 
write(TProtocol, T) - Method in interface org.apache.thrift.scheme.IScheme
 
write(TNonblockingTransport) - Method in class org.apache.thrift.transport.sasl.FrameWriter
Nonblocking write to the underlying transport.
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.TProtocolDecorator
 
writeBinary(ByteBuffer) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeBinary(ByteBuffer) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeBool(boolean) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeBool(boolean) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeByte(byte) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeByte(byte) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeDouble(double) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeDouble(double) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeField(TField, TProtocol.WriteCallback<Void>) - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
writeFieldBegin(TField) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeFieldBegin(TField) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeFieldEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeFieldEnd() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeFieldStop() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeFieldStop() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeI16(short) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeI16(short) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeI32(int) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeI32(int) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeI64(long) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeI64(long) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeLength(int) - Method in class org.apache.thrift.transport.TSaslClientTransport
Write the given integer as 4 bytes to the underlying transport.
writeList(byte, List<T>, TProtocol.WriteCallback<T>) - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
writeListBegin(TList) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeListBegin(TList) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeListEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeListEnd() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeMap(byte, byte, Map<K, V>, TProtocol.WriteCallback<Map.Entry<K, V>>) - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
writeMapBegin(TMap) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeMapBegin(TMap) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeMapEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeMapEnd() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeMessage(TMessage, TProtocol.WriteCallback<Void>) - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
writeMessageBegin(TMessage) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeMessageBegin(TMessage) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeMessageEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeMessageEnd() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeSet(byte, Set<T>, TProtocol.WriteCallback<T>) - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
writeSetBegin(TSet) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeSetBegin(TSet) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeSetEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeSetEnd() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeString(String) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeString(String) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeStruct(TStruct, TProtocol.WriteCallback<Void>) - Method in class org.apache.thrift.protocol.TProtocol
 
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.TProtocolDecorator
 
writeStructBegin(TStruct) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeStructBegin(TStruct) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
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.TProtocolDecorator
 
writeStructEnd() - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeStructEnd() - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
writeUuid(UUID) - Method in class org.apache.thrift.protocol.TBinaryProtocol
 
writeUuid(UUID) - Method in class org.apache.thrift.protocol.TCompactProtocol
 
writeUuid(UUID) - Method in class org.apache.thrift.protocol.TJSONProtocol
 
writeUuid(UUID) - Method in class org.apache.thrift.protocol.TProtocolDecorator
 
writeUuid(UUID) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
writeUuid(UUID) - Method in interface org.apache.thrift.protocol.TWriteProtocol
 
WRITING_FAILURE_MESSAGE - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
WRITING_REQUEST_BODY - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
WRITING_REQUEST_SIZE - Enum constant in enum class org.apache.thrift.async.TAsyncMethodCall.State
 
WRITING_RESPONSE - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
WRITING_SASL_CHALLENGE - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
WRITING_SUCCESS_MESSAGE - Enum constant in enum class org.apache.thrift.transport.sasl.NonblockingSaslHandler.Phase
 
WRONG_METHOD_NAME - Static variable in exception org.apache.thrift.TApplicationException
 

_

___currentMethod - Variable in class org.apache.thrift.async.TAsyncClient
 
___manager - Variable in class org.apache.thrift.async.TAsyncClient
 
___protocolFactory - Variable in class org.apache.thrift.async.TAsyncClient
 
___transport - Variable in class org.apache.thrift.async.TAsyncClient
 
_writeStringData(String) - Method in class org.apache.thrift.protocol.TSimpleJSONProtocol
 
A B C D E F G H I J K L M N O P R S T U V W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form