_streambase
index
c:\users\build\sbxbuild\482\co\streambase\lib\python2.7\_streambase.pyd

 
Functions
       
ArgumentOutOfRange_swigregister(...)
ArgumentOutOfRange_throwMyself(...)
ArgumentOutOfRange_throwMyself(ArgumentOutOfRange self)
BoolVector___bool__(...)
BoolVector___bool__(BoolVector self) -> bool
BoolVector___delitem__(...)
__delitem__(difference_type i)
BoolVector___delitem__(BoolVector self, PySliceObject slice)
BoolVector___delslice__(...)
BoolVector___delslice__(BoolVector self, difference_type i, difference_type j)
BoolVector___getitem__(...)
__getitem__(PySliceObject slice) -> BoolVector
BoolVector___getitem__(BoolVector self, difference_type i) -> value_type
BoolVector___getslice__(...)
BoolVector___getslice__(BoolVector self, difference_type i, difference_type j) -> BoolVector
BoolVector___len__(...)
BoolVector___len__(BoolVector self) -> size_type
BoolVector___nonzero__(...)
BoolVector___nonzero__(BoolVector self) -> bool
BoolVector___setitem__(...)
__setitem__(PySliceObject slice, BoolVector v)
__setitem__(PySliceObject slice)
BoolVector___setitem__(BoolVector self, difference_type i, value_type x)
BoolVector___setslice__(...)
__setslice__(difference_type i, difference_type j, BoolVector v = std::vector< bool,std::allocator< bool > >())
BoolVector___setslice__(BoolVector self, difference_type i, difference_type j)
BoolVector_append(...)
BoolVector_append(BoolVector self, value_type x)
BoolVector_assign(...)
BoolVector_assign(BoolVector self, size_type n, value_type x)
BoolVector_back(...)
BoolVector_back(BoolVector self) -> value_type
BoolVector_begin(...)
BoolVector_begin(BoolVector self) -> iterator
BoolVector_capacity(...)
BoolVector_capacity(BoolVector self) -> size_type
BoolVector_clear(...)
BoolVector_clear(BoolVector self)
BoolVector_empty(...)
BoolVector_empty(BoolVector self) -> bool
BoolVector_end(...)
BoolVector_end(BoolVector self) -> iterator
BoolVector_erase(...)
erase(iterator pos) -> iterator
BoolVector_erase(BoolVector self, iterator first, iterator last) -> iterator
BoolVector_front(...)
BoolVector_front(BoolVector self) -> value_type
BoolVector_get_allocator(...)
BoolVector_get_allocator(BoolVector self) -> allocator_type
BoolVector_insert(...)
insert(iterator pos, value_type x) -> iterator
BoolVector_insert(BoolVector self, iterator pos, size_type n, value_type x)
BoolVector_iterator(...)
BoolVector_iterator(BoolVector self) -> SwigPyIterator
BoolVector_pop(...)
BoolVector_pop(BoolVector self) -> value_type
BoolVector_pop_back(...)
BoolVector_pop_back(BoolVector self)
BoolVector_push_back(...)
BoolVector_push_back(BoolVector self, value_type x)
BoolVector_rbegin(...)
BoolVector_rbegin(BoolVector self) -> reverse_iterator
BoolVector_rend(...)
BoolVector_rend(BoolVector self) -> reverse_iterator
BoolVector_reserve(...)
BoolVector_reserve(BoolVector self, size_type n)
BoolVector_resize(...)
resize(size_type new_size)
BoolVector_resize(BoolVector self, size_type new_size, value_type x)
BoolVector_size(...)
BoolVector_size(BoolVector self) -> size_type
BoolVector_swap(...)
BoolVector_swap(BoolVector self, BoolVector v)
BoolVector_swigregister(...)
ClientSettings_checkClientExitStatus(...)
ClientSettings_checkClientExitStatus(ClientSettings self) -> bool
 
Should we check the client exit status.
 
if we should check the client exit status
ClientSettings_getExitStatusTimeout(...)
ClientSettings_getExitStatusTimeout(ClientSettings self) -> NMSTL::Time
 
Get the timeout used when sending a request to the server to get the
clients exit status.
 
Time (in milliseconds) of the time to wait for the clients exit status
ClientSettings_getHeartbeatTimeout(...)
ClientSettings_getHeartbeatTimeout(ClientSettings self) -> NMSTL::Time
 
Get the heart beat timeout.
 
Time (in milliseconds) the tuple quiesent timeout
ClientSettings_getMaxDequeuerQueueSize(...)
ClientSettings_getMaxDequeuerQueueSize(ClientSettings self) -> unsigned int
ClientSettings_getMaxInputPacketSize(...)
ClientSettings_getMaxInputPacketSize(ClientSettings self) -> unsigned int
 
Get the maximum size of the input tuple in binary mode.
 
max size of the input tuple (in bytes)
ClientSettings_getMaxTupleBufferCacheSize(...)
ClientSettings_getMaxTupleBufferCacheSize(ClientSettings self) -> unsigned int
ClientSettings_getOpenTimeout(...)
ClientSettings_getOpenTimeout(ClientSettings self) -> NMSTL::Time
 
Get the timeout used when opening a connection.
 
Time (in milliseconds) that the tuple i/o will wait before assuming
the server is down.
ClientSettings_getReconnectSleep(...)
ClientSettings_getReconnectSleep(ClientSettings self) -> NMSTL::Time
 
Get the amount of time to sleep between reconnect requests.
 
Time (in milliseconds) to sleep between reconnect timeouts in the
event that the TupleConnection is disconnected from its server.
ClientSettings_getWriteTimeout(...)
ClientSettings_getWriteTimeout(ClientSettings self) -> NMSTL::Time
 
Get the timeout used when writing to a connection.
 
Time (in milliseconds) that the tuple i/o will wait before assuming
the server is down.
ClientSettings_getXmlRpcTimeout(...)
ClientSettings_getXmlRpcTimeout(ClientSettings self) -> NMSTL::Time
 
Get the timeout used when making an xmlrpc request.
 
Time (in milliseconds) that the tuple i/o will wait before assuming
the server is down.
ClientSettings_setExitStatusTimeout(...)
ClientSettings_setExitStatusTimeout(ClientSettings self, NMSTL::Time exitStatusTimeout)
 
Set the timeout used when sending a request to the server to get the
clients exit status.
 
Parameters:
-----------
 
exitStatusTimeout:  new value (in milliseconds) for the exit status
timeout
ClientSettings_setHeartbeatTimeout(...)
ClientSettings_setHeartbeatTimeout(ClientSettings self, NMSTL::Time heartbeatTimeout)
 
Set the heart beat timeout.
 
Parameters:
-----------
 
heartbeatTimeout:  new value (in milliseconds) for the heartbeat
timeout
ClientSettings_setMaxDequeuerQueueSize(...)
ClientSettings_setMaxDequeuerQueueSize(ClientSettings self, unsigned int maxDequeuerQueueSize)
 
Set the maximum number of tuples to be kept in the Dequeuer Thread's
internal queue before applying back-pressure to the server.
 
Parameters:
-----------
 
maxDequeuerQueueSize:  maximum number of tuples to allow to wait in
the Dequeuer Thread's internal queue before blocking dequeues from the
server.
ClientSettings_setMaxInputPacketSize(...)
ClientSettings_setMaxInputPacketSize(ClientSettings self, unsigned int maxInputPacketSize)
 
Set the maximum size of the input tuple in binary mode.
 
Parameters:
-----------
 
maxInputPacketSize:  new value (in milliseconds) for the
maxInputPacket size
ClientSettings_setOpenTimeout(...)
ClientSettings_setOpenTimeout(ClientSettings self, NMSTL::Time tupleOpenTimeout)
 
Set the timeout used when opening a binary connection.
 
Parameters:
-----------
 
tupleOpenTimeout:  new value (in milliseconds) for the tuple open
timeout
ClientSettings_setReconnectSleep(...)
ClientSettings_setReconnectSleep(ClientSettings self, NMSTL::Time reconnectSleep)
 
Set the amount of time to sleep between reconnect requests.
 
Parameters:
-----------
 
reconnectSleep:  new value (in milliseconds) for reconnect sleep
ClientSettings_setTcpNoDelay(...)
ClientSettings_setTcpNoDelay(ClientSettings self, bool tcpNoDelay)
 
Enable/disable TCP_NO_DELAY.
 
Parameters:
-----------
 
tcpNoDelay:  enable/disable TCP_NO_DELAY
ClientSettings_setWriteTimeout(...)
ClientSettings_setWriteTimeout(ClientSettings self, NMSTL::Time tupleWriteTimeout)
 
Set the timeout used when writing to a connection.
 
Parameters:
-----------
 
tupleWriteTimeout:  new value (in milliseconds) for the tuple write
timeout
ClientSettings_setXmlRpcTimeout(...)
ClientSettings_setXmlRpcTimeout(ClientSettings self, NMSTL::Time xmlrpcTimeout)
 
Set the timeout used when making an xmlrpc request.
 
Parameters:
-----------
 
xmlrpcTimeout:  new value (in milliseconds) for the xmlrpc request
timeout
ClientSettings_swigregister(...)
ClientSettings_tcpNoDelay(...)
ClientSettings_tcpNoDelay(ClientSettings self) -> bool
 
Is TCP_NODELAY set.
 
if tcpNoDealy set
Client_canDequeue(...)
Client_canDequeue(Client self) -> bool
 
Return true if we can call dequeue without blocking.
 
This means that there is something to dequeue from the server. This
dequeued item could be Tuples, a null (server shutdown) or an
exception. boolean if we can dequeue without blocking
Client_checkLicense(...)
Client_checkLicense(Client self, string featureName) -> bool
Client_close(...)
Client_close(Client self)
 
Terminate the client.
 
May be invoked from a different thread. StreamBaseClient memory,
network, and thread resources are not released until close() is
called.
 
Returns immediately.
Client_dequeue(...)
dequeue() -> DequeueResult
Client_dequeue(Client self, int timeout_ms) -> DequeueResult
 
Dequeue tuples from any subscribed stream
 
This method blocks until at least one tuple is available on any
subscribed stream, or the StreamBase server is shut down.
Client_describe(...)
Client_describe(Client self, string entity) -> string
 
Returns an XML description of an entity, or an empty string if the
method does not exist.
Client_doByteSwap(...)
Client_doByteSwap(Client self) -> bool
Client_enableBuffering(...)
enableBuffering(int buffer_size, int flush_interval = DEFAULT_FLUSH_INTERVAL)
Client_enableBuffering(Client self, int buffer_size)
 
Turn on buffering. The WakeAndFlushBuffer thread is only started if
flush_interval > 0.
Client_enableConnectionlessEnqueue(...)
Client_enableConnectionlessEnqueue(Client self, bool enable)
Client_enableHeartbeating(...)
Client_enableHeartbeating(Client self)
 
Enable heartbeating for this client. Generally this is only for
enqueue-only clients.
Client_enqueue(...)
enqueue(string stream_name, Tuple tuple)
enqueue(StreamProperties props, Tuple tuple)
enqueue(string stream_name, TupleList tuples)
Client_enqueue(Client self, StreamProperties props, TupleList tuples)
 
enqueue(self, string stream_name, (tuple,list,dict) pyTuple)
enqueue(self, StreamProperties props, (tuple,list,dict) pyTuple)
 
Enqueue tuples to an input stream.
 
This method may block due to network congestion or StreamBase
server congestion.
 
If provided a Python tuple, list, or dict, enqueue will attempt to
convert it to a Tuple object using the Schema of the target stream
before sending it to the server.
Client_flushAllBuffers(...)
Client_flushAllBuffers(Client self)
 
Flush any pending enqueue buffers.
 
This operation has no effect if buffering is not enabled.
 
Exceptions:
-----------
 
StreamBaseException if there is an IO error while flushing the buffer
Client_flushBuffer(...)
flushBuffer(StreamProperties props)
Client_flushBuffer(Client self, string stream_name)
 
Flush any pending enqueue buffer for the stream name provided.
 
This operation has no effect if buffering is not enabled or there is
no buffer to flush for the given stream. Note: Note that this will
cause inter-stream ordering to be interrupted.
 
Parameters:
-----------
 
stream_name:  the stream whose enqueue buffers to flush, if not empty
 
Exceptions:
-----------
 
StreamBaseException if there is an IO error while flushing the buffer
 
Deprecated stream_name use StreamProperties based flushBuffer
 
use flushAllBuffers() to preserve inter-stream ordering
Client_getBufferSize(...)
Client_getBufferSize(Client self) -> int
 
Return buffer size (in tuples)
Client_getConnectionID(...)
Client_getConnectionID(Client self) -> string
 
Return the Connection ID for this Client Connection.
 
Only Valid once an enqueue/dequeue has been attempted. connection ID
in binary format
Client_getConnectionIdAsHexString(...)
Client_getConnectionIdAsHexString(Client self) -> string
 
Return the Connection ID for this Client Connection.
 
Only Valid once an enqueue/dequeue has been attempted. connection ID
in Hexadecimal format
Client_getDynamicVariables(...)
Client_getDynamicVariables(Client self, string modulePath) -> Tuple
 
Get all the dynamic variables in the given module, and return them as
a Tuple where the field names are the names of the dynamic variables,
and the field values are the current values of the dynamic variables.
 
Exceptions:
-----------
 
StreamBaseException on network or other errors, or if there are no
dynamic variables in the named module
Client_getIsBuffering(...)
Client_getIsBuffering(Client self) -> bool
 
Return whether buffering is turned on or off.
Client_getIsConnectionlessEnqueue(...)
Client_getIsConnectionlessEnqueue(Client self) -> bool
Client_getSchemaByHash(...)
Client_getSchemaByHash(Client self, string hash) -> Schema
 
Returns a schema with a particular hash.
Client_getSchemaByName(...)
Client_getSchemaByName(Client self, string name) -> Schema
 
Returns a schema by name.
 
This will only succeed for named schemas; anonymous schemas assigned
to a port should instead be looked up via
getStreamProperties().getSchema().
Client_getSchemaForStream(...)
getSchemaForStream(string entity, CaptureTransformStrategy strategy = FLATTEN) -> Schema
Client_getSchemaForStream(Client self, string entity) -> Schema
 
Returns the schema of a stream, throwing an exception if the stream
does not exist.
Client_getSettings(...)
Client_getSettings(Client self) -> ClientSettings
 
Get the settings for the client.
Client_getStreamProperties(...)
getStreamProperties(string entity, CaptureTransformStrategy strategy = FLATTEN) -> StreamProperties
Client_getStreamProperties(Client self, string entity) -> StreamProperties
 
Returns a description of a stream, throwing an exception if the stream
does not exist.
 
Parameters:
-----------
 
entity:  the path of the stream
 
strategy:  how to handle capture fields on the stream
Client_getStreamPropertiesByHash(...)
Client_getStreamPropertiesByHash(Client self, string hex) -> StreamProperties
 
Returns a description of a stream, throwing an exception if the stream
does not exist.
Client_getTupleDequeueCount(...)
Client_getTupleDequeueCount(Client self) -> long long
 
Returns the number of tuples this client has dequeued from the server.
 
This number does not include tuples that may be dequeued as part of
system services such as heartbeating. This number does however include
tuples that have been dequeued but have been intercepted by the
Interceptor.
Client_getTupleEnqueueCount(...)
Client_getTupleEnqueueCount(Client self) -> long long
 
Returns the number of tuples this client has actually enqueued to the
server.
 
Note that this number will not include any tuples that have been
buffered but have not actually been enqueued to the server.
Client_getURI(...)
Client_getURI(Client self) -> URI
 
Return the URI we're talking to.
Client_getURIs(...)
Client_getURIs(Client self) -> URIVector
Client_getVersion(...)
Client_getVersion(Client self) -> string
 
Returns the client version as a string.
Client_internalCommand(...)
Client_internalCommand(Client self, StringVector arguments)
Client_isClosed(...)
Client_isClosed(Client self) -> bool
 
Return true if the client connection is closed.
 
The client connection can be closed by calling the close() method, or
by a server shutdown, or a network error.
Client_isConnected(...)
Client_isConnected(Client self) -> bool
 
Returns true if this TupleConnections has any live connections to a
server.
 
Note that a return of "false" doesn't necessarily indicate an error
since the TupleConnection's state (e.g., lack of subscriptions) might
mean no connections are needed. boolean if we are connected
Client_isStreamSubscribed(...)
Client_isStreamSubscribed(Client self, string entity) -> bool
 
Returns true if this stream has been subscribed to.
 
Parameters:
-----------
 
entity:  the path of the stream
Client_listEntities(...)
listEntities(string type, int flags)
listEntities(Type type, int flags)
Client_listEntities(Client self, Type type)
 
Lists all entities of a particular type.
 
(One can then use "describe" to obtain a description of an entity.)
names is cleared first.
Client_operatorStatus(...)
Client_operatorStatus(Client self, string containerName)
 
-> a list of the the statuses of Java operators and adapters as strings
Client_readTable(...)
readTable(string tablePath, int limit, string predicate = "") -> TupleList
Client_readTable(Client self, string tablePath, int limit) -> TupleList
 
Read rows out of the table at this path.
 
Limit to the specified number of rows returned, or -1 for no limit.
Filter rows according to predicate, or return all rows if predicate is
empty. a list of matching rows.
Client_resubscribe(...)
resubscribe(string stream_name, string logical_stream, string predicate) -> StreamProperties
Client_resubscribe(Client self, StreamProperties props, string logical_stream, 
    string predicate) -> StreamProperties
 
Resubscribes to an already subscribed stream.
 
the StreamProperties for the stream
Client_setDynamicVariable(...)
Client_setDynamicVariable(Client self, string dynamicVariablePath, string value)
 
Set the dynamic variable at the given path to the given value,
expressed as a string in CSV style.
 
Exceptions:
-----------
 
StreamBaseException if the dynamic variable does not exist, or the
value is not appropriate for setting the dynamic variable
Client_setQuiescentLimit(...)
Client_setQuiescentLimit(Client self, int timeoutMS) -> int
 
Sets how many milliseconds a dequeueing client will tolerate not
receiving a client heart beat from the StreamBase server that it is
connected to.
 
The default value is 120 seconds (120000). By default, StreamBase
servers emit "client heart beats" every 10 seconds so StreamBase
applications have no requirement to send data regularly.
 
Parameters:
-----------
 
timeoutMS:  The number of milliseconds that is allowed to pass without
receiving a message from the StreamBase server client heart beat
stream.
Client_status(...)
status(bool verbose = False)
Client_status(Client self)
 
status the streambase daemons
Client_subscribe(...)
subscribe(string stream_name) -> StreamProperties
subscribe(StreamProperties props) -> StreamProperties
subscribe(string stream_name, string logical_stream, string predicate) -> StreamProperties
Client_subscribe(Client self, StreamProperties props, string logical_stream, 
    string predicate) -> StreamProperties
 
Subscribes to a stream with a predicate to apply to output tuples.
 
The stream name of dequeued tuples is logical_stream. When
unsubscribing, use logical_stream.
 
Parameters:
-----------
 
props:  the stream to subscribe to, error if empty
 
logical_stream:  the name of the logical stream to associate with this
predicate (if empty, defaults to streamname)
 
predicate:  a predicate to apply to subset the stream, error if empty
 
the StreamProperties for the stream
Client_swigregister(...)
Client_typecheck(...)
typecheck(string sbapp, bool full = False)
Client_typecheck(Client self, string sbapp)
 
Typechecks a potential modification to the application, outputting
properties of all streams in the application.
 
streams is cleared first.
 
Parameters:
-----------
 
sbapp:  the application
 
streams:  the schema defs of the streams
 
full:  do a full typecheck
Client_unsubscribe(...)
unsubscribe(string stream_name)
Client_unsubscribe(Client self, StreamProperties props)
 
UnSubscribes to a stream.
 
Note: Any tuples that are in-flight during an unsubscribe request will
be dequeued until the stream is fully drained.
Client_useRawTuples_get(...)
Client_useRawTuples_set(...)
CompleteDataType___eq__(...)
x.__eq__(y) <==> x==y
CompleteDataType___ge__(...)
x.__ge__(y) <==> x>=y
CompleteDataType___gt__(...)
x.__gt__(y) <==> x>y
CompleteDataType___le__(...)
x.__le__(y) <==> x<=y
CompleteDataType___lt__(...)
x.__lt__(y) <==> x<y
CompleteDataType___ne__(...)
x.__ne__(y) <==> x!=y
CompleteDataType___nonzero__(...)
x.__nonzero__() <==> x != 0
CompleteDataType___str__(...)
x.__str__() <==> str(x)
 
Returns a string representation of this CompleteDataType.
CompleteDataType_compare(...)
CompleteDataType_compare(CompleteDataType self, CompleteDataType fv) -> int
 
Compare the current CompleteDataType against the provided
CompleteDataType by base type (eg DataType::BOOL, ::INT, ::TUPLE,
etc).
 
Therefore, for example a LIST of type INT and a LIST of type TUPLE are
equal.
 
-1 if the current CompleteDataType is less than the provided
CompleteDataType, 0 if the current is equal to the provided
CompleteDataType, and 1 if the current is greater than the provided
CompleteDataType.
CompleteDataType_forBlob(...)
CompleteDataType_forBlob() -> CompleteDataType
CompleteDataType_forBool(...)
CompleteDataType_forBool() -> CompleteDataType
CompleteDataType_forCapture(...)
CompleteDataType_forCapture(string captureName) -> CompleteDataType
CompleteDataType_forDouble(...)
CompleteDataType_forDouble() -> CompleteDataType
CompleteDataType_forFunction(...)
CompleteDataType_forFunction(Schema argumentSchema, CompleteDataType returnType) -> CompleteDataType
CompleteDataType_forInt(...)
CompleteDataType_forInt() -> CompleteDataType
CompleteDataType_forList(...)
CompleteDataType_forList(CompleteDataType elemType) -> CompleteDataType
CompleteDataType_forLong(...)
CompleteDataType_forLong() -> CompleteDataType
CompleteDataType_forSimpleType(...)
CompleteDataType_forSimpleType(DataType type) -> CompleteDataType
CompleteDataType_forString(...)
CompleteDataType_forString() -> CompleteDataType
CompleteDataType_forTimestamp(...)
CompleteDataType_forTimestamp() -> CompleteDataType
CompleteDataType_forTuple(...)
CompleteDataType_forTuple(Schema s) -> CompleteDataType
CompleteDataType_getArgumentSchema(...)
CompleteDataType_getArgumentSchema(CompleteDataType self) -> Schema
 
If this CompleteDataType has an argument schema, returns it
For all other types, returns None.
CompleteDataType_getCaptureTypeName(...)
CompleteDataType_getCaptureTypeName(CompleteDataType self) -> string
CompleteDataType_getElementCompleteType(...)
CompleteDataType_getElementCompleteType(CompleteDataType self) -> CompleteDataType
 
If this CompleteDataType has an element type, returns the element's
CompleteDataType.  For all other types, returns None.
CompleteDataType_getReturnType(...)
CompleteDataType_getReturnType(CompleteDataType self) -> CompleteDataType
 
If this CompleteDataType has a return type, returns it as a
CompleteDataType.  For all other types, returns None.
CompleteDataType_getSchema(...)
CompleteDataType_getSchema(CompleteDataType self) -> Schema
 
If this CompleteDataType has a nested tuple, return its Schema.
 
For all other types, return a null Schema.
CompleteDataType_getType(...)
CompleteDataType_getType(CompleteDataType self) -> DataType
 
Return the primitive DataType of the CompleteDataType.
CompleteDataType_hasElementType(...)
CompleteDataType_hasElementType(CompleteDataType self) -> bool
 
Returns true if this CompleteDataType has an element CompleteDataType
(eg it is a DataType::LIST of DataType::INTs, the latter being its
element type).
CompleteDataType_hasSchema(...)
CompleteDataType_hasSchema(CompleteDataType self) -> bool
 
Returns true if this CompleteDataType contains a Schema (eg it is a
DataType::TUPLE).
CompleteDataType_swigregister(...)
DataType___int__(...)
x.__int__() <==> int(x)
DataType___str__(...)
x.__str__() <==> str(x)
 
Return a string representation of the data type.
DataType_getSize(...)
DataType_getSize(DataType self) -> size_t
DataType_isFixedSize(...)
DataType_isFixedSize(DataType type) -> bool
DataType_swigregister(...)
DequeueResult_getLeadershipStatus(...)
DequeueResult_getLeadershipStatus(DequeueResult self) -> LeadershipStatus
 
Return the leadership status of the server that produced this dequeue
result.
DequeueResult_getServerURI(...)
DequeueResult_getServerURI(DequeueResult self) -> URI
 
Returns the URI of the server that produced these results.
DequeueResult_getStatus(...)
DequeueResult_getStatus(DequeueResult self) -> Status
 
Return the status of this DequeueResult.
 
DequeueResult::GOOD means the DequeueResult contains tuples. the
status of this DequeueResult
DequeueResult_getStreamName(...)
DequeueResult_getStreamName(DequeueResult self) -> string
 
Returns the name of the stream on which tuples were dequeued.
DequeueResult_getStreamProperties(...)
DequeueResult_getStreamProperties(DequeueResult self) -> StreamProperties
 
Returns the StreamProperties for this DequeueResult.
DequeueResult_getTuple(...)
DequeueResult_getTuple(DequeueResult self, int index) -> Tuple
 
Returns the index'th tuple.
DequeueResult_getTupleCount(...)
DequeueResult_getTupleCount(DequeueResult self) -> int
 
Returns the number of tuples dequeued.
DequeueResult_getTuples(...)
DequeueResult_getTuples(DequeueResult self) -> TupleList
 
Returns the list of tuples.
DequeueResult_reuseTuple(...)
DequeueResult_reuseTuple(DequeueResult self)
 
Currently a no-op maintained for backwards compatibility.
 
Deprecated
DequeueResult_swigregister(...)
DoubleVector___bool__(...)
DoubleVector___bool__(DoubleVector self) -> bool
DoubleVector___delitem__(...)
__delitem__(difference_type i)
DoubleVector___delitem__(DoubleVector self, PySliceObject slice)
DoubleVector___delslice__(...)
DoubleVector___delslice__(DoubleVector self, difference_type i, difference_type j)
DoubleVector___getitem__(...)
__getitem__(PySliceObject slice) -> DoubleVector
DoubleVector___getitem__(DoubleVector self, difference_type i) -> value_type
DoubleVector___getslice__(...)
DoubleVector___getslice__(DoubleVector self, difference_type i, difference_type j) -> DoubleVector
DoubleVector___len__(...)
DoubleVector___len__(DoubleVector self) -> size_type
DoubleVector___nonzero__(...)
DoubleVector___nonzero__(DoubleVector self) -> bool
DoubleVector___setitem__(...)
__setitem__(PySliceObject slice, DoubleVector v)
__setitem__(PySliceObject slice)
DoubleVector___setitem__(DoubleVector self, difference_type i, value_type x)
DoubleVector___setslice__(...)
__setslice__(difference_type i, difference_type j, DoubleVector v = std::vector< double,std::allocator< double > >())
DoubleVector___setslice__(DoubleVector self, difference_type i, difference_type j)
DoubleVector_append(...)
DoubleVector_append(DoubleVector self, value_type x)
DoubleVector_assign(...)
DoubleVector_assign(DoubleVector self, size_type n, value_type x)
DoubleVector_back(...)
DoubleVector_back(DoubleVector self) -> value_type
DoubleVector_begin(...)
DoubleVector_begin(DoubleVector self) -> iterator
DoubleVector_capacity(...)
DoubleVector_capacity(DoubleVector self) -> size_type
DoubleVector_clear(...)
DoubleVector_clear(DoubleVector self)
DoubleVector_empty(...)
DoubleVector_empty(DoubleVector self) -> bool
DoubleVector_end(...)
DoubleVector_end(DoubleVector self) -> iterator
DoubleVector_erase(...)
erase(iterator pos) -> iterator
DoubleVector_erase(DoubleVector self, iterator first, iterator last) -> iterator
DoubleVector_front(...)
DoubleVector_front(DoubleVector self) -> value_type
DoubleVector_get_allocator(...)
DoubleVector_get_allocator(DoubleVector self) -> allocator_type
DoubleVector_insert(...)
insert(iterator pos, value_type x) -> iterator
DoubleVector_insert(DoubleVector self, iterator pos, size_type n, value_type x)
DoubleVector_iterator(...)
DoubleVector_iterator(DoubleVector self) -> SwigPyIterator
DoubleVector_pop(...)
DoubleVector_pop(DoubleVector self) -> value_type
DoubleVector_pop_back(...)
DoubleVector_pop_back(DoubleVector self)
DoubleVector_push_back(...)
DoubleVector_push_back(DoubleVector self, value_type x)
DoubleVector_rbegin(...)
DoubleVector_rbegin(DoubleVector self) -> reverse_iterator
DoubleVector_rend(...)
DoubleVector_rend(DoubleVector self) -> reverse_iterator
DoubleVector_reserve(...)
DoubleVector_reserve(DoubleVector self, size_type n)
DoubleVector_resize(...)
resize(size_type new_size)
DoubleVector_resize(DoubleVector self, size_type new_size, value_type x)
DoubleVector_size(...)
DoubleVector_size(DoubleVector self) -> size_type
DoubleVector_swap(...)
DoubleVector_swap(DoubleVector self, DoubleVector v)
DoubleVector_swigregister(...)
EntityType___str__(...)
x.__str__() <==> str(x)
EntityType_as_enum(...)
as_enum(string aType, bool allow_plural = False) -> Type
EntityType_as_enum(string aType) -> Type
EntityType_swigregister(...)
Errors_swigregister(...)
FieldValueVector___bool__(...)
FieldValueVector___bool__(FieldValueVector self) -> bool
FieldValueVector___delitem__(...)
__delitem__(difference_type i)
FieldValueVector___delitem__(FieldValueVector self, PySliceObject slice)
FieldValueVector___delslice__(...)
FieldValueVector___delslice__(FieldValueVector self, difference_type i, difference_type j)
FieldValueVector___getitem__(...)
__getitem__(PySliceObject slice) -> FieldValueVector
FieldValueVector___getitem__(FieldValueVector self, difference_type i) -> value_type
FieldValueVector___getslice__(...)
FieldValueVector___getslice__(FieldValueVector self, difference_type i, difference_type j) -> FieldValueVector
FieldValueVector___len__(...)
FieldValueVector___len__(FieldValueVector self) -> size_type
FieldValueVector___nonzero__(...)
FieldValueVector___nonzero__(FieldValueVector self) -> bool
FieldValueVector___setitem__(...)
__setitem__(PySliceObject slice, FieldValueVector v)
__setitem__(PySliceObject slice)
FieldValueVector___setitem__(FieldValueVector self, difference_type i, value_type x)
FieldValueVector___setslice__(...)
__setslice__(difference_type i, difference_type j, FieldValueVector v = std::vector< sb::FieldValue,std::allocator< sb::FieldValue > >())
FieldValueVector___setslice__(FieldValueVector self, difference_type i, difference_type j)
FieldValueVector_append(...)
FieldValueVector_append(FieldValueVector self, value_type x)
FieldValueVector_assign(...)
FieldValueVector_assign(FieldValueVector self, size_type n, value_type x)
FieldValueVector_back(...)
FieldValueVector_back(FieldValueVector self) -> value_type
FieldValueVector_begin(...)
FieldValueVector_begin(FieldValueVector self) -> iterator
FieldValueVector_capacity(...)
FieldValueVector_capacity(FieldValueVector self) -> size_type
FieldValueVector_clear(...)
FieldValueVector_clear(FieldValueVector self)
FieldValueVector_empty(...)
FieldValueVector_empty(FieldValueVector self) -> bool
FieldValueVector_end(...)
FieldValueVector_end(FieldValueVector self) -> iterator
FieldValueVector_erase(...)
erase(iterator pos) -> iterator
FieldValueVector_erase(FieldValueVector self, iterator first, iterator last) -> iterator
FieldValueVector_front(...)
FieldValueVector_front(FieldValueVector self) -> value_type
FieldValueVector_get_allocator(...)
FieldValueVector_get_allocator(FieldValueVector self) -> allocator_type
FieldValueVector_insert(...)
insert(iterator pos, value_type x) -> iterator
FieldValueVector_insert(FieldValueVector self, iterator pos, size_type n, value_type x)
FieldValueVector_iterator(...)
FieldValueVector_iterator(FieldValueVector self) -> SwigPyIterator
FieldValueVector_pop(...)
FieldValueVector_pop(FieldValueVector self) -> value_type
FieldValueVector_pop_back(...)
FieldValueVector_pop_back(FieldValueVector self)
FieldValueVector_push_back(...)
FieldValueVector_push_back(FieldValueVector self, value_type x)
FieldValueVector_rbegin(...)
FieldValueVector_rbegin(FieldValueVector self) -> reverse_iterator
FieldValueVector_rend(...)
FieldValueVector_rend(FieldValueVector self) -> reverse_iterator
FieldValueVector_reserve(...)
FieldValueVector_reserve(FieldValueVector self, size_type n)
FieldValueVector_resize(...)
resize(size_type new_size)
FieldValueVector_resize(FieldValueVector self, size_type new_size, value_type x)
FieldValueVector_size(...)
FieldValueVector_size(FieldValueVector self) -> size_type
FieldValueVector_swap(...)
FieldValueVector_swap(FieldValueVector self, FieldValueVector v)
FieldValueVector_swigregister(...)
FieldValue___eq__(...)
x.__eq__(y) <==> x==y
FieldValue___ge__(...)
x.__ge__(y) <==> x>=y
FieldValue___gt__(...)
x.__gt__(y) <==> x>y
FieldValue___le__(...)
x.__le__(y) <==> x<=y
FieldValue___lt__(...)
x.__lt__(y) <==> x<y
FieldValue___ne__(...)
x.__ne__(y) <==> x!=y
FieldValue___str__(...)
x.__str__() <==> str(x)
 
Return a string representation of this FieldValue.
FieldValue_compare(...)
FieldValue_compare(FieldValue self, FieldValue fv) -> int
 
Compare the current FieldValue against the provided FieldValue.
 
Null FieldValues are less than non-null FieldValues. Provides a total
ordering over the set of possible FieldValues, so does not check
types. Ordering of FieldValues of heterogeneous types is not
guaranteed but is consistent.
 
-1 if the current FieldValue is less than the provided FieldValue, 0
if the current is equal to the provided FieldValue, and 1 if the
current is greater than the provided FieldValue.
FieldValue_forLong(...)
FieldValue_forLong(long long val) -> FieldValue
FieldValue_getBlob(...)
FieldValue_getBlob(FieldValue self) -> string
 
Return the value of a blob FieldValue as a string.
 
Will throw an exception if this FieldValue is not of type
DataType::BLOB.
FieldValue_getBool(...)
FieldValue_getBool(FieldValue self) -> bool
 
Return the value of a boolean FieldValue.
 
Will throw an exception if this FieldValue is not of type
DataType::BOOL.
FieldValue_getCapture(...)
FieldValue_getCapture(FieldValue self) -> string
 
Return the value of a Capture FieldValue, as a string Will throw an
exception if this FieldValue is not of type DataType::CAPTURE.
FieldValue_getCompleteType(...)
FieldValue_getCompleteType(FieldValue self) -> CompleteDataType
 
Returns the CompleteDataType of this FieldValue.
FieldValue_getDouble(...)
FieldValue_getDouble(FieldValue self) -> double
 
Return the value of a double FieldValue.
 
Will throw an exception if this FieldValue is not of type
DataType::DOUBLE.
FieldValue_getFalse(...)
FieldValue_getFalse() -> FieldValue
FieldValue_getFunction(...)
FieldValue_getFunction(FieldValue self) -> Function
 
Return the value of a Function FieldValue Will throw an exception if
this FieldValue is not of type DataType::FUNCTION.
FieldValue_getInt(...)
FieldValue_getInt(FieldValue self) -> int
 
Return the value of an integer FieldValue.
 
Will throw an exception if this FieldValue is not of type
DataType::INT.
FieldValue_getList(...)
FieldValue_getList(FieldValue self) -> FieldValueVector
 
Returns the value of a List FieldValue.
FieldValue_getLong(...)
FieldValue_getLong(FieldValue self) -> long long
 
Return the value of a long FieldValue.
 
Will throw an exception if this FieldValue is not of type
DataType::LONG.
FieldValue_getSize(...)
FieldValue_getSize(FieldValue self) -> size_t
FieldValue_getString(...)
FieldValue_getString(FieldValue self) -> string
 
Return the value of a string FieldValue.
 
Will throw an exception if this FieldValue is not of type
DataType::STRING.
FieldValue_getTimestamp(...)
FieldValue_getTimestamp(FieldValue self) -> Timestamp
 
Return the value of a Timestamp FieldValue as a Timestamp.
 
Will throw an exception if this FieldValue is not of type
DataType::TIMESTAMP.
FieldValue_getTrue(...)
FieldValue_getTrue() -> FieldValue
FieldValue_getTuple(...)
FieldValue_getTuple(FieldValue self) -> Tuple
 
Returns the value of a Tuple FieldValue.
FieldValue_getType(...)
FieldValue_getType(FieldValue self) -> DataType
 
Get the primitive DataType of this FieldValue.
FieldValue_isNull(...)
FieldValue_isNull(FieldValue self) -> bool
 
Return true if this FieldValue represents a null value.
FieldValue_sameType(...)
FieldValue_sameType(FieldValue self, FieldValue fv) -> bool
 
Returns true if this FieldValue and the provided FieldValue are of the
same type.
 
"Of the same type" is defined as their CompleteDataType members
being equivalent.
FieldValue_swigregister(...)
FieldValue_toCSVString(...)
FieldValue_toCSVString(FieldValue self, char delim, string null_string, char quote) -> string
FieldValue_toDelimitedString(...)
FieldValue_toDelimitedString(FieldValue self, string delimiter, string null_string, 
    bool include_names, bool quote_all_strings) -> string
FieldVector___bool__(...)
FieldVector___bool__(FieldVector self) -> bool
FieldVector___delitem__(...)
__delitem__(difference_type i)
FieldVector___delitem__(FieldVector self, PySliceObject slice)
FieldVector___delslice__(...)
FieldVector___delslice__(FieldVector self, difference_type i, difference_type j)
FieldVector___getitem__(...)
__getitem__(PySliceObject slice) -> FieldVector
FieldVector___getitem__(FieldVector self, difference_type i) -> value_type
FieldVector___getslice__(...)
FieldVector___getslice__(FieldVector self, difference_type i, difference_type j) -> FieldVector
FieldVector___len__(...)
FieldVector___len__(FieldVector self) -> size_type
FieldVector___nonzero__(...)
FieldVector___nonzero__(FieldVector self) -> bool
FieldVector___setitem__(...)
__setitem__(PySliceObject slice, FieldVector v)
__setitem__(PySliceObject slice)
FieldVector___setitem__(FieldVector self, difference_type i, value_type x)
FieldVector___setslice__(...)
__setslice__(difference_type i, difference_type j, FieldVector v = std::vector< sb::Field,std::allocator< sb::Field > >())
FieldVector___setslice__(FieldVector self, difference_type i, difference_type j)
FieldVector_append(...)
FieldVector_append(FieldVector self, value_type x)
FieldVector_assign(...)
FieldVector_assign(FieldVector self, size_type n, value_type x)
FieldVector_back(...)
FieldVector_back(FieldVector self) -> value_type
FieldVector_begin(...)
FieldVector_begin(FieldVector self) -> iterator
FieldVector_capacity(...)
FieldVector_capacity(FieldVector self) -> size_type
FieldVector_clear(...)
FieldVector_clear(FieldVector self)
FieldVector_empty(...)
FieldVector_empty(FieldVector self) -> bool
FieldVector_end(...)
FieldVector_end(FieldVector self) -> iterator
FieldVector_erase(...)
erase(iterator pos) -> iterator
FieldVector_erase(FieldVector self, iterator first, iterator last) -> iterator
FieldVector_front(...)
FieldVector_front(FieldVector self) -> value_type
FieldVector_get_allocator(...)
FieldVector_get_allocator(FieldVector self) -> allocator_type
FieldVector_insert(...)
insert(iterator pos, value_type x) -> iterator
FieldVector_insert(FieldVector self, iterator pos, size_type n, value_type x)
FieldVector_iterator(...)
FieldVector_iterator(FieldVector self) -> SwigPyIterator
FieldVector_pop(...)
FieldVector_pop(FieldVector self) -> value_type
FieldVector_pop_back(...)
FieldVector_pop_back(FieldVector self)
FieldVector_push_back(...)
FieldVector_push_back(FieldVector self, value_type x)
FieldVector_rbegin(...)
FieldVector_rbegin(FieldVector self) -> reverse_iterator
FieldVector_rend(...)
FieldVector_rend(FieldVector self) -> reverse_iterator
FieldVector_reserve(...)
FieldVector_reserve(FieldVector self, size_type n)
FieldVector_resize(...)
resize(size_type new_size)
FieldVector_resize(FieldVector self, size_type new_size, value_type x)
FieldVector_size(...)
FieldVector_size(FieldVector self) -> size_type
FieldVector_swap(...)
FieldVector_swap(FieldVector self, FieldVector v)
FieldVector_swigregister(...)
Field___str__(...)
x.__str__() <==> str(x)
 
Returns a string representation of a field.
Field_as_xml(...)
Field_as_xml(Field self) -> string
Field_getArgumentSchema(...)
Field_getArgumentSchema(Field self) -> Schema
Field_getCompleteType(...)
Field_getCompleteType(Field self) -> CompleteDataType
 
Returns the complete type of a field (e.g., DataType::LIST of
DataType::INTs).
Field_getElementCompleteType(...)
Field_getElementCompleteType(Field self) -> CompleteDataType
 
Returns the complete type of a field's elements (e.g., on a
DataType::LIST of DataType::INTs, returns a CompleteDataType of
DataType::INT).
Field_getFieldPath(...)
Field_getFieldPath(Field self) -> FieldVector
Field_getFixedSize(...)
Field_getFixedSize(Field self) -> size_t
 
Returns the size of a field if it has a fixed size or -1.
Field_getIndex(...)
Field_getIndex(Field self) -> int
 
Returns the index of the field.
Field_getName(...)
Field_getName(Field self) -> string
 
Returns the name of a field.
Field_getReturnType(...)
Field_getReturnType(Field self) -> CompleteDataType
Field_getSchema(...)
Field_getSchema(Field self) -> Schema
 
Returns the field's schema (valid only if the field's type is TUPLE)
Field_getType(...)
Field_getType(Field self) -> DataType
 
Returns the type of a field (e.g., DataType::INT).
Field_sameType(...)
Field_sameType(Field self, Field other) -> bool
 
Return true if the fields are the same type (including size
information)
Field_swigregister(...)
Function_compare(...)
Function_compare(Function self, Function f) -> int
Function_getBody(...)
Function_getBody(Function self) -> string
 
Returns the body of the function.
Function_getEnvironment(...)
Function_getEnvironment(Function self) -> Tuple
 
Returns a Tuple representing the environment against which the function body is evaluated.
Function_getFunctionDefinition(...)
Function_getFunctionDefinition(Function self) -> string
Function_getInFieldTransformer(...)
Function_getInFieldTransformer(Function self) -> string
Function_getInnerType(...)
Function_getInnerType(Function self) -> CompleteDataType
Function_getName(...)
Function_getName(Function self) -> string
 
Returns the name of the function.
Function_getOutFieldTransformer(...)
Function_getOutFieldTransformer(Function self) -> string
Function_getType(...)
Function_getType(Function self) -> CompleteDataType
Function_isCoerced(...)
Function_isCoerced(Function self) -> bool
Function_swigregister(...)
IntVector___bool__(...)
IntVector___bool__(IntVector self) -> bool
IntVector___delitem__(...)
__delitem__(difference_type i)
IntVector___delitem__(IntVector self, PySliceObject slice)
IntVector___delslice__(...)
IntVector___delslice__(IntVector self, difference_type i, difference_type j)
IntVector___getitem__(...)
__getitem__(PySliceObject slice) -> IntVector
IntVector___getitem__(IntVector self, difference_type i) -> value_type
IntVector___getslice__(...)
IntVector___getslice__(IntVector self, difference_type i, difference_type j) -> IntVector
IntVector___len__(...)
IntVector___len__(IntVector self) -> size_type
IntVector___nonzero__(...)
IntVector___nonzero__(IntVector self) -> bool
IntVector___setitem__(...)
__setitem__(PySliceObject slice, IntVector v)
__setitem__(PySliceObject slice)
IntVector___setitem__(IntVector self, difference_type i, value_type x)
IntVector___setslice__(...)
__setslice__(difference_type i, difference_type j, IntVector v = std::vector< int,std::allocator< int > >())
IntVector___setslice__(IntVector self, difference_type i, difference_type j)
IntVector_append(...)
IntVector_append(IntVector self, value_type x)
IntVector_assign(...)
IntVector_assign(IntVector self, size_type n, value_type x)
IntVector_back(...)
IntVector_back(IntVector self) -> value_type
IntVector_begin(...)
IntVector_begin(IntVector self) -> iterator
IntVector_capacity(...)
IntVector_capacity(IntVector self) -> size_type
IntVector_clear(...)
IntVector_clear(IntVector self)
IntVector_empty(...)
IntVector_empty(IntVector self) -> bool
IntVector_end(...)
IntVector_end(IntVector self) -> iterator
IntVector_erase(...)
erase(iterator pos) -> iterator
IntVector_erase(IntVector self, iterator first, iterator last) -> iterator
IntVector_front(...)
IntVector_front(IntVector self) -> value_type
IntVector_get_allocator(...)
IntVector_get_allocator(IntVector self) -> allocator_type
IntVector_insert(...)
insert(iterator pos, value_type x) -> iterator
IntVector_insert(IntVector self, iterator pos, size_type n, value_type x)
IntVector_iterator(...)
IntVector_iterator(IntVector self) -> SwigPyIterator
IntVector_pop(...)
IntVector_pop(IntVector self) -> value_type
IntVector_pop_back(...)
IntVector_pop_back(IntVector self)
IntVector_push_back(...)
IntVector_push_back(IntVector self, value_type x)
IntVector_rbegin(...)
IntVector_rbegin(IntVector self) -> reverse_iterator
IntVector_rend(...)
IntVector_rend(IntVector self) -> reverse_iterator
IntVector_reserve(...)
IntVector_reserve(IntVector self, size_type n)
IntVector_resize(...)
resize(size_type new_size)
IntVector_resize(IntVector self, size_type new_size, value_type x)
IntVector_size(...)
IntVector_size(IntVector self) -> size_type
IntVector_swap(...)
IntVector_swap(IntVector self, IntVector v)
IntVector_swigregister(...)
ListVector___bool__(...)
ListVector___bool__(ListVector self) -> bool
ListVector___delitem__(...)
__delitem__(difference_type i)
ListVector___delitem__(ListVector self, PySliceObject slice)
ListVector___delslice__(...)
ListVector___delslice__(ListVector self, difference_type i, difference_type j)
ListVector___getitem__(...)
__getitem__(PySliceObject slice) -> ListVector
ListVector___getitem__(ListVector self, difference_type i) -> value_type
ListVector___getslice__(...)
ListVector___getslice__(ListVector self, difference_type i, difference_type j) -> ListVector
ListVector___len__(...)
ListVector___len__(ListVector self) -> size_type
ListVector___nonzero__(...)
ListVector___nonzero__(ListVector self) -> bool
ListVector___setitem__(...)
__setitem__(PySliceObject slice, ListVector v)
__setitem__(PySliceObject slice)
ListVector___setitem__(ListVector self, difference_type i, value_type x)
ListVector___setslice__(...)
__setslice__(difference_type i, difference_type j, ListVector v = std::vector< std::vector< sb::FieldValue,std::allocator< sb::FieldValue > >,std::allocator< std::vector< sb::FieldValue,std::allocator< sb::FieldValue > > > >())
ListVector___setslice__(ListVector self, difference_type i, difference_type j)
ListVector_append(...)
ListVector_append(ListVector self, value_type x)
ListVector_assign(...)
ListVector_assign(ListVector self, size_type n, value_type x)
ListVector_back(...)
ListVector_back(ListVector self) -> value_type
ListVector_begin(...)
ListVector_begin(ListVector self) -> iterator
ListVector_capacity(...)
ListVector_capacity(ListVector self) -> size_type
ListVector_clear(...)
ListVector_clear(ListVector self)
ListVector_empty(...)
ListVector_empty(ListVector self) -> bool
ListVector_end(...)
ListVector_end(ListVector self) -> iterator
ListVector_erase(...)
erase(iterator pos) -> iterator
ListVector_erase(ListVector self, iterator first, iterator last) -> iterator
ListVector_front(...)
ListVector_front(ListVector self) -> value_type
ListVector_get_allocator(...)
ListVector_get_allocator(ListVector self) -> allocator_type
ListVector_insert(...)
insert(iterator pos, value_type x) -> iterator
ListVector_insert(ListVector self, iterator pos, size_type n, value_type x)
ListVector_iterator(...)
ListVector_iterator(ListVector self) -> SwigPyIterator
ListVector_pop(...)
ListVector_pop(ListVector self) -> value_type
ListVector_pop_back(...)
ListVector_pop_back(ListVector self)
ListVector_push_back(...)
ListVector_push_back(ListVector self, value_type x)
ListVector_rbegin(...)
ListVector_rbegin(ListVector self) -> reverse_iterator
ListVector_rend(...)
ListVector_rend(ListVector self) -> reverse_iterator
ListVector_reserve(...)
ListVector_reserve(ListVector self, size_type n)
ListVector_resize(...)
resize(size_type new_size)
ListVector_resize(ListVector self, size_type new_size, value_type x)
ListVector_size(...)
ListVector_size(ListVector self) -> size_type
ListVector_swap(...)
ListVector_swap(ListVector self, ListVector v)
ListVector_swigregister(...)
LongVector___bool__(...)
LongVector___bool__(LongVector self) -> bool
LongVector___delitem__(...)
__delitem__(difference_type i)
LongVector___delitem__(LongVector self, PySliceObject slice)
LongVector___delslice__(...)
LongVector___delslice__(LongVector self, difference_type i, difference_type j)
LongVector___getitem__(...)
__getitem__(PySliceObject slice) -> LongVector
LongVector___getitem__(LongVector self, difference_type i) -> value_type
LongVector___getslice__(...)
LongVector___getslice__(LongVector self, difference_type i, difference_type j) -> LongVector
LongVector___len__(...)
LongVector___len__(LongVector self) -> size_type
LongVector___nonzero__(...)
LongVector___nonzero__(LongVector self) -> bool
LongVector___setitem__(...)
__setitem__(PySliceObject slice, LongVector v)
__setitem__(PySliceObject slice)
LongVector___setitem__(LongVector self, difference_type i, value_type x)
LongVector___setslice__(...)
__setslice__(difference_type i, difference_type j, LongVector v = std::vector< long long,std::allocator< long long > >())
LongVector___setslice__(LongVector self, difference_type i, difference_type j)
LongVector_append(...)
LongVector_append(LongVector self, value_type x)
LongVector_assign(...)
LongVector_assign(LongVector self, size_type n, value_type x)
LongVector_back(...)
LongVector_back(LongVector self) -> value_type
LongVector_begin(...)
LongVector_begin(LongVector self) -> iterator
LongVector_capacity(...)
LongVector_capacity(LongVector self) -> size_type
LongVector_clear(...)
LongVector_clear(LongVector self)
LongVector_empty(...)
LongVector_empty(LongVector self) -> bool
LongVector_end(...)
LongVector_end(LongVector self) -> iterator
LongVector_erase(...)
erase(iterator pos) -> iterator
LongVector_erase(LongVector self, iterator first, iterator last) -> iterator
LongVector_front(...)
LongVector_front(LongVector self) -> value_type
LongVector_get_allocator(...)
LongVector_get_allocator(LongVector self) -> allocator_type
LongVector_insert(...)
insert(iterator pos, value_type x) -> iterator
LongVector_insert(LongVector self, iterator pos, size_type n, value_type x)
LongVector_iterator(...)
LongVector_iterator(LongVector self) -> SwigPyIterator
LongVector_pop(...)
LongVector_pop(LongVector self) -> value_type
LongVector_pop_back(...)
LongVector_pop_back(LongVector self)
LongVector_push_back(...)
LongVector_push_back(LongVector self, value_type x)
LongVector_rbegin(...)
LongVector_rbegin(LongVector self) -> reverse_iterator
LongVector_rend(...)
LongVector_rend(LongVector self) -> reverse_iterator
LongVector_reserve(...)
LongVector_reserve(LongVector self, size_type n)
LongVector_resize(...)
resize(size_type new_size)
LongVector_resize(LongVector self, size_type new_size, value_type x)
LongVector_size(...)
LongVector_size(LongVector self) -> size_type
LongVector_swap(...)
LongVector_swap(LongVector self, LongVector v)
LongVector_swigregister(...)
SWIG_PyInstanceMethod_New(...)
SchemaRep_swigregister(...)
Schema___eq__(...)
x.__eq__(y) <==> x==y
Schema___ne__(...)
x.__ne__(y) <==> x!=y
Schema___nonzero__(...)
x.__nonzero__() <==> x != 0
Schema___str__(...)
x.__str__() <==> str(x)
 
Returns a string representation of the schema.
Schema_as_xml(...)
as_xml(string name = std::string(), bool aAddUUID = True) -> string
as_xml(string name = std::string()) -> string
Schema_as_xml(Schema self) -> string
Schema_fromXml(...)
fromXml(string input, Flags flags = sb::Schema::Flags()) -> Schema
Schema_fromXml(string input) -> Schema
Schema_getField(...)
getField(size_t field_num) -> Field
Schema_getField(Schema self, string pathName) -> Field
 
Return the Fields object description of a field in the schema.
 
Parameters:
-----------
 
pathName:  the path name of the field to fetch.
 
Exceptions:
-----------
 
NoSuchFieldException if field is not found.
Schema_getFields(...)
Schema_getFields(Schema self) -> std::vector<(sb::Schema::Field,std::allocator<(sb::Schema::Field)>)>
 
Returns a reference to a vector of all fields in the schema.
Schema_getHeaderSize(...)
Schema_getHeaderSize(Schema self) -> size_t
 
Return the size of the header.
Schema_getName(...)
Schema_getName(Schema self) -> string
 
Returns the name of the schema or empty string at runtime.
Schema_getNullMaskOffset(...)
Schema_getNullMaskOffset(Schema self) -> size_t
Schema_getNullMaskSize(...)
Schema_getNullMaskSize(Schema self) -> size_t
Schema_getNumFields(...)
Schema_getNumFields(Schema self) -> size_t
 
Returns the number of fields in the schema.
Schema_hasField(...)
Schema_hasField(Schema self, string pathName) -> bool
 
Returns true if a field of a given path name is present, otherwise it
returns false.
 
Parameters:
-----------
 
pathName:  the path name of the field to fetch.
Schema_hasHeader(...)
Schema_hasHeader(Schema self) -> bool
 
Return true if the schema has space for a header, false otherwise.
 
Deprecated
Schema_indexOfField(...)
Schema_indexOfField(Schema self, string name) -> int
 
Returns the index of the field with a particular name (note: not path
name), or -1 if there is no such field.
Schema_sameFieldTypes(...)
Schema_sameFieldTypes(Schema self, Schema other) -> bool
 
Returns true if this schema has the same field types in the same order
as another Schema.
Schema_sameFields(...)
Schema_sameFields(Schema self, Schema other) -> bool
 
Returns true if this schema has the same field Names and Types in the
same order as another Schema.
Schema_swigregister(...)
StreamBaseException___str__(...)
x.__str__() <==> str(x)
StreamBaseException_asXmlString(...)
StreamBaseException_asXmlString(StreamBaseException self) -> string
StreamBaseException_asXmlStringSingle(...)
StreamBaseException_asXmlStringSingle(StreamBaseException self) -> string
StreamBaseException_boxname(...)
StreamBaseException_boxname(StreamBaseException self, string name) -> StreamBaseException
StreamBaseException_boxparam(...)
StreamBaseException_boxparam(StreamBaseException self, string name) -> StreamBaseException
StreamBaseException_cause(...)
StreamBaseException_cause(StreamBaseException self, StreamBaseException val) -> StreamBaseException
StreamBaseException_chainAsString(...)
StreamBaseException_chainAsString(StreamBaseException self) -> string
StreamBaseException_code(...)
code(string val) -> StreamBaseException
StreamBaseException_code(StreamBaseException self, int val) -> StreamBaseException
StreamBaseException_fieldname(...)
StreamBaseException_fieldname(StreamBaseException self, string name) -> StreamBaseException
StreamBaseException_file(...)
file(char val) -> StreamBaseException
StreamBaseException_file(StreamBaseException self, string val) -> StreamBaseException
StreamBaseException_findByType(...)
StreamBaseException_findByType(StreamBaseException self, string type) -> StreamBaseException
StreamBaseException_fromXmlString(...)
fromXmlString(string xmlstring, TIBCO_CEP_memory::shared_ptr<(sb::StreamBaseException)> cause = TIBCO_CEP_memory::shared_ptr< StreamBaseException >()) -> StreamBaseException
StreamBaseException_fromXmlString(string xmlstring) -> StreamBaseException
StreamBaseException_function(...)
function(char val) -> StreamBaseException
StreamBaseException_function(StreamBaseException self, string val) -> StreamBaseException
StreamBaseException_getBoxName(...)
StreamBaseException_getBoxName(StreamBaseException self) -> string
StreamBaseException_getBoxParam(...)
StreamBaseException_getBoxParam(StreamBaseException self) -> string
StreamBaseException_getCause(...)
StreamBaseException_getCause(StreamBaseException self) -> StreamBaseException
StreamBaseException_getChainOfMessages(...)
StreamBaseException_getChainOfMessages(StreamBaseException self) -> string
StreamBaseException_getCode(...)
StreamBaseException_getCode(StreamBaseException self) -> string
StreamBaseException_getDeepest(...)
StreamBaseException_getDeepest(StreamBaseException self) -> StreamBaseException
StreamBaseException_getErrorType(...)
StreamBaseException_getErrorType(StreamBaseException self) -> Type
StreamBaseException_getFieldName(...)
StreamBaseException_getFieldName(StreamBaseException self) -> string
StreamBaseException_getFile(...)
StreamBaseException_getFile(StreamBaseException self) -> string
StreamBaseException_getFunction(...)
StreamBaseException_getFunction(StreamBaseException self) -> string
StreamBaseException_getLine(...)
StreamBaseException_getLine(StreamBaseException self) -> unsigned int
StreamBaseException_getMessage(...)
StreamBaseException_getMessage(StreamBaseException self) -> string
StreamBaseException_getParam(...)
StreamBaseException_getParam(StreamBaseException self, string name) -> string
StreamBaseException_getStackTrace(...)
StreamBaseException_getStackTrace(StreamBaseException self) -> string
StreamBaseException_getSummary(...)
StreamBaseException_getSummary(StreamBaseException self) -> string
StreamBaseException_getType(...)
StreamBaseException_getType(StreamBaseException self) -> string
StreamBaseException_hasCause(...)
StreamBaseException_hasCause(StreamBaseException self) -> bool
StreamBaseException_line(...)
StreamBaseException_line(StreamBaseException self, int val) -> StreamBaseException
StreamBaseException_linkAsString(...)
StreamBaseException_linkAsString(StreamBaseException self) -> string
StreamBaseException_message(...)
StreamBaseException_message(StreamBaseException self, string val) -> StreamBaseException
StreamBaseException_param(...)
param(string name, string val) -> StreamBaseException
StreamBaseException_param(StreamBaseException self, string name, int val) -> StreamBaseException
StreamBaseException_summary(...)
StreamBaseException_summary(StreamBaseException self, string val) -> StreamBaseException
StreamBaseException_swigregister(...)
StreamBaseException_throwMyself(...)
StreamBaseException_throwMyself(StreamBaseException self)
StreamBaseException_type(...)
StreamBaseException_type(StreamBaseException self, string val) -> StreamBaseException
StreamBaseException_what(...)
StreamBaseException_what(StreamBaseException self) -> char
 
throw ()
Returns the message as a C string.
 
The string is owned by this object, so the pointer becomes invalid
upon destruction of the StreamBaseException.
StreamBaseXmlRpcFault_swigregister(...)
StreamBaseXmlRpcFault_throwMyself(...)
StreamBaseXmlRpcFault_throwMyself(StreamBaseXmlRpcFault self)
StreamProperties___eq__(...)
x.__eq__(y) <==> x==y
StreamProperties___lt__(...)
x.__lt__(y) <==> x<y
StreamProperties___ne__(...)
x.__ne__(y) <==> x!=y
StreamProperties_fromXml(...)
StreamProperties_fromXml(string input) -> StreamProperties
StreamProperties_getCaptureTransformStrategy(...)
StreamProperties_getCaptureTransformStrategy(StreamProperties self) -> CaptureTransformStrategy
StreamProperties_getContainerName(...)
StreamProperties_getContainerName(StreamProperties self) -> string
 
Returns the container part of the stream.
StreamProperties_getName(...)
StreamProperties_getName(StreamProperties self) -> string
 
Returns the name part of the stream.
StreamProperties_getQualifiedName(...)
StreamProperties_getQualifiedName(StreamProperties self) -> string
 
Returns the fully qualified name of the stream.
StreamProperties_getSchema(...)
StreamProperties_getSchema(StreamProperties self) -> Schema
 
Returns the schema of the stream.
StreamProperties_hashString(...)
StreamProperties_hashString(StreamProperties self) -> string
 
Returns the hash of the stream in binary.
StreamProperties_hashValue(...)
StreamProperties_hashValue(StreamProperties self) -> size_t
StreamProperties_hexString(...)
StreamProperties_hexString(StreamProperties self) -> string
StreamProperties_swigregister(...)
StringHashFunc___call__(...)
StringHashFunc___call__(StringHashFunc self, string str) -> size_t
StringHashFunc_swigregister(...)
StringVector___bool__(...)
StringVector___bool__(StringVector self) -> bool
StringVector___delitem__(...)
__delitem__(difference_type i)
StringVector___delitem__(StringVector self, PySliceObject slice)
StringVector___delslice__(...)
StringVector___delslice__(StringVector self, difference_type i, difference_type j)
StringVector___getitem__(...)
__getitem__(PySliceObject slice) -> StringVector
StringVector___getitem__(StringVector self, difference_type i) -> value_type
StringVector___getslice__(...)
StringVector___getslice__(StringVector self, difference_type i, difference_type j) -> StringVector
StringVector___len__(...)
StringVector___len__(StringVector self) -> size_type
StringVector___nonzero__(...)
StringVector___nonzero__(StringVector self) -> bool
StringVector___setitem__(...)
__setitem__(PySliceObject slice, StringVector v)
__setitem__(PySliceObject slice)
StringVector___setitem__(StringVector self, difference_type i, value_type x)
StringVector___setslice__(...)
__setslice__(difference_type i, difference_type j, StringVector v = std::vector< std::string,std::allocator< std::string > >())
StringVector___setslice__(StringVector self, difference_type i, difference_type j)
StringVector_append(...)
StringVector_append(StringVector self, value_type x)
StringVector_assign(...)
StringVector_assign(StringVector self, size_type n, value_type x)
StringVector_back(...)
StringVector_back(StringVector self) -> value_type
StringVector_begin(...)
StringVector_begin(StringVector self) -> iterator
StringVector_capacity(...)
StringVector_capacity(StringVector self) -> size_type
StringVector_clear(...)
StringVector_clear(StringVector self)
StringVector_empty(...)
StringVector_empty(StringVector self) -> bool
StringVector_end(...)
StringVector_end(StringVector self) -> iterator
StringVector_erase(...)
erase(iterator pos) -> iterator
StringVector_erase(StringVector self, iterator first, iterator last) -> iterator
StringVector_front(...)
StringVector_front(StringVector self) -> value_type
StringVector_get_allocator(...)
StringVector_get_allocator(StringVector self) -> allocator_type
StringVector_insert(...)
insert(iterator pos, value_type x) -> iterator
StringVector_insert(StringVector self, iterator pos, size_type n, value_type x)
StringVector_iterator(...)
StringVector_iterator(StringVector self) -> SwigPyIterator
StringVector_pop(...)
StringVector_pop(StringVector self) -> value_type
StringVector_pop_back(...)
StringVector_pop_back(StringVector self)
StringVector_push_back(...)
StringVector_push_back(StringVector self, value_type x)
StringVector_rbegin(...)
StringVector_rbegin(StringVector self) -> reverse_iterator
StringVector_rend(...)
StringVector_rend(StringVector self) -> reverse_iterator
StringVector_reserve(...)
StringVector_reserve(StringVector self, size_type n)
StringVector_resize(...)
resize(size_type new_size)
StringVector_resize(StringVector self, size_type new_size, value_type x)
StringVector_size(...)
StringVector_size(StringVector self) -> size_type
StringVector_swap(...)
StringVector_swap(StringVector self, StringVector v)
StringVector_swigregister(...)
SwigPyIterator___add__(...)
SwigPyIterator___add__(SwigPyIterator self, ptrdiff_t n) -> SwigPyIterator
SwigPyIterator___eq__(...)
SwigPyIterator___eq__(SwigPyIterator self, SwigPyIterator x) -> bool
SwigPyIterator___iadd__(...)
SwigPyIterator___iadd__(SwigPyIterator self, ptrdiff_t n) -> SwigPyIterator
SwigPyIterator___isub__(...)
SwigPyIterator___isub__(SwigPyIterator self, ptrdiff_t n) -> SwigPyIterator
SwigPyIterator___ne__(...)
SwigPyIterator___ne__(SwigPyIterator self, SwigPyIterator x) -> bool
SwigPyIterator___next__(...)
SwigPyIterator___next__(SwigPyIterator self) -> PyObject
SwigPyIterator___sub__(...)
__sub__(ptrdiff_t n) -> SwigPyIterator
SwigPyIterator___sub__(SwigPyIterator self, SwigPyIterator x) -> ptrdiff_t
SwigPyIterator_advance(...)
SwigPyIterator_advance(SwigPyIterator self, ptrdiff_t n) -> SwigPyIterator
SwigPyIterator_copy(...)
SwigPyIterator_copy(SwigPyIterator self) -> SwigPyIterator
SwigPyIterator_decr(...)
decr(size_t n = 1) -> SwigPyIterator
SwigPyIterator_decr(SwigPyIterator self) -> SwigPyIterator
SwigPyIterator_distance(...)
SwigPyIterator_distance(SwigPyIterator self, SwigPyIterator x) -> ptrdiff_t
SwigPyIterator_equal(...)
SwigPyIterator_equal(SwigPyIterator self, SwigPyIterator x) -> bool
SwigPyIterator_incr(...)
incr(size_t n = 1) -> SwigPyIterator
SwigPyIterator_incr(SwigPyIterator self) -> SwigPyIterator
SwigPyIterator_next(...)
SwigPyIterator_next(SwigPyIterator self) -> PyObject
SwigPyIterator_previous(...)
SwigPyIterator_previous(SwigPyIterator self) -> PyObject
SwigPyIterator_swigregister(...)
SwigPyIterator_value(...)
SwigPyIterator_value(SwigPyIterator self) -> PyObject
TimestampVector___bool__(...)
TimestampVector___bool__(TimestampVector self) -> bool
TimestampVector___delitem__(...)
__delitem__(difference_type i)
TimestampVector___delitem__(TimestampVector self, PySliceObject slice)
TimestampVector___delslice__(...)
TimestampVector___delslice__(TimestampVector self, difference_type i, difference_type j)
TimestampVector___getitem__(...)
__getitem__(PySliceObject slice) -> TimestampVector
TimestampVector___getitem__(TimestampVector self, difference_type i) -> value_type
TimestampVector___getslice__(...)
TimestampVector___getslice__(TimestampVector self, difference_type i, difference_type j) -> TimestampVector
TimestampVector___len__(...)
TimestampVector___len__(TimestampVector self) -> size_type
TimestampVector___nonzero__(...)
TimestampVector___nonzero__(TimestampVector self) -> bool
TimestampVector___setitem__(...)
__setitem__(PySliceObject slice, TimestampVector v)
__setitem__(PySliceObject slice)
TimestampVector___setitem__(TimestampVector self, difference_type i, value_type x)
TimestampVector___setslice__(...)
__setslice__(difference_type i, difference_type j, TimestampVector v = std::vector< sb::Timestamp,std::allocator< sb::Timestamp > >())
TimestampVector___setslice__(TimestampVector self, difference_type i, difference_type j)
TimestampVector_append(...)
TimestampVector_append(TimestampVector self, value_type x)
TimestampVector_assign(...)
TimestampVector_assign(TimestampVector self, size_type n, value_type x)
TimestampVector_back(...)
TimestampVector_back(TimestampVector self) -> value_type
TimestampVector_begin(...)
TimestampVector_begin(TimestampVector self) -> iterator
TimestampVector_capacity(...)
TimestampVector_capacity(TimestampVector self) -> size_type
TimestampVector_clear(...)
TimestampVector_clear(TimestampVector self)
TimestampVector_empty(...)
TimestampVector_empty(TimestampVector self) -> bool
TimestampVector_end(...)
TimestampVector_end(TimestampVector self) -> iterator
TimestampVector_erase(...)
erase(iterator pos) -> iterator
TimestampVector_erase(TimestampVector self, iterator first, iterator last) -> iterator
TimestampVector_front(...)
TimestampVector_front(TimestampVector self) -> value_type
TimestampVector_get_allocator(...)
TimestampVector_get_allocator(TimestampVector self) -> allocator_type
TimestampVector_insert(...)
insert(iterator pos, value_type x) -> iterator
TimestampVector_insert(TimestampVector self, iterator pos, size_type n, value_type x)
TimestampVector_iterator(...)
TimestampVector_iterator(TimestampVector self) -> SwigPyIterator
TimestampVector_pop(...)
TimestampVector_pop(TimestampVector self) -> value_type
TimestampVector_pop_back(...)
TimestampVector_pop_back(TimestampVector self)
TimestampVector_push_back(...)
TimestampVector_push_back(TimestampVector self, value_type x)
TimestampVector_rbegin(...)
TimestampVector_rbegin(TimestampVector self) -> reverse_iterator
TimestampVector_rend(...)
TimestampVector_rend(TimestampVector self) -> reverse_iterator
TimestampVector_reserve(...)
TimestampVector_reserve(TimestampVector self, size_type n)
TimestampVector_resize(...)
resize(size_type new_size)
TimestampVector_resize(TimestampVector self, size_type new_size, value_type x)
TimestampVector_size(...)
TimestampVector_size(TimestampVector self) -> size_type
TimestampVector_swap(...)
TimestampVector_swap(TimestampVector self, TimestampVector v)
TimestampVector_swigregister(...)
Timestamp___add__(...)
Timestamp___add__(Timestamp self, Timestamp rhs) -> Timestamp
Timestamp___div__(...)
Timestamp___div__(Timestamp self, Timestamp rhs) -> double
Timestamp___eq__(...)
x.__eq__(y) <==> x==y
Timestamp___ge__(...)
x.__ge__(y) <==> x>=y
Timestamp___gt__(...)
x.__gt__(y) <==> x>y
Timestamp___iadd__(...)
Timestamp___iadd__(Timestamp self, Timestamp rhs) -> Timestamp
Timestamp___imod__(...)
Timestamp___imod__(Timestamp self, Timestamp rhs) -> Timestamp
Timestamp___isub__(...)
Timestamp___isub__(Timestamp self, Timestamp rhs) -> Timestamp
Timestamp___le__(...)
x.__le__(y) <==> x<=y
Timestamp___lt__(...)
x.__lt__(y) <==> x<y
Timestamp___mod__(...)
Timestamp___mod__(Timestamp self, Timestamp rhs) -> Timestamp
Timestamp___ne__(...)
x.__ne__(y) <==> x!=y
Timestamp___neg__(...)
Timestamp___neg__(Timestamp self) -> Timestamp
Timestamp___str__(...)
x.__str__() <==> str(x)
x.__str__() <==> str(x)
 
Return a human readable string rep of this Timestamp.
Timestamp___sub__(...)
Timestamp___sub__(Timestamp self, Timestamp rhs) -> Timestamp
Timestamp_compare(...)
Timestamp_compare(Timestamp self, Timestamp other) -> int
 
compare 2 timestamps return less than zero this < other return greater
than zero this > other return 0 if they are the same
Timestamp_days(...)
Timestamp_days(double days) -> Timestamp
Timestamp_getDayOfMonth(...)
Timestamp_getDayOfMonth(Timestamp self) -> int
 
Return day of month.
Timestamp_getDayOfWeek(...)
Timestamp_getDayOfWeek(Timestamp self) -> int
 
Return day since Sunday.
Timestamp_getHour(...)
Timestamp_getHour(Timestamp self) -> int
 
Return hours since midnight.
Timestamp_getMillisecond(...)
Timestamp_getMillisecond(Timestamp self) -> double
 
Return milliseconds after the second.
Timestamp_getMinute(...)
Timestamp_getMinute(Timestamp self) -> int
 
Return minutes after hour.
Timestamp_getMonth(...)
Timestamp_getMonth(Timestamp self) -> int
 
Return month since January.
Timestamp_getSecond(...)
Timestamp_getSecond(Timestamp self) -> double
 
Return seconds after the minute.
Timestamp_getYear(...)
Timestamp_getYear(Timestamp self) -> int
 
Return year.
Timestamp_hours(...)
Timestamp_hours(double hours) -> Timestamp
Timestamp_isInterval(...)
Timestamp_isInterval(Timestamp self) -> bool
 
Return true if this Timestamp is an interval.
Timestamp_milliseconds(...)
Timestamp_milliseconds(long long milliseconds) -> Timestamp
Timestamp_minutes(...)
Timestamp_minutes(double minutes) -> Timestamp
Timestamp_now(...)
Timestamp_now() -> Timestamp
Timestamp_seconds(...)
Timestamp_seconds(double seconds) -> Timestamp
Timestamp_setDayOfMonth(...)
Timestamp_setDayOfMonth(Timestamp self, int day_of_month)
 
Set day of month.
Timestamp_setHour(...)
Timestamp_setHour(Timestamp self, int hours)
 
Set hours since midnight.
Timestamp_setMinute(...)
Timestamp_setMinute(Timestamp self, int minutes)
 
Set minutes after the hour.
Timestamp_setMonth(...)
Timestamp_setMonth(Timestamp self, int month)
 
Set month since January.
Timestamp_setSecond(...)
Timestamp_setSecond(Timestamp self, double seconds)
 
Set seconds after the minute.
Timestamp_setYear(...)
Timestamp_setYear(Timestamp self, int year)
 
Set year.
Timestamp_swigregister(...)
Timestamp_toMsecs(...)
Timestamp_toMsecs(Timestamp self) -> long long
 
Return the time as milliseconds.
Timestamp_toSecs(...)
Timestamp_toSecs(Timestamp self) -> long long
 
Return the time as seconds.
Timestamp_weeks(...)
Timestamp_weeks(double weeks) -> Timestamp
TupleList___getitem__(...)
x.__getitem__(y) <==> x[y]
TupleList___iter__(...)
x.__iter__() <==> iter(x)
TupleList___len__(...)
x.__len__() <==> len(x)
TupleList___setitem__(...)
x.__setitem__(y, i) <==> x[y]=i
TupleList___str__(...)
x.__str__() <==> str(x)
 
Return a human-readable string value representing this list in its
entirety (including all header values, if applicable).
 
the string value.
TupleList_back(...)
back() -> Tuple
TupleList_back(TupleList self) -> Tuple
 
return the last tuple in the list
TupleList_begin(...)
begin() -> iterator
TupleList_begin(TupleList self) -> const_iterator
 
STL compatible iterators.
TupleList_clear(...)
TupleList_clear(TupleList self)
 
clear the list
TupleList_copyIntoBuffer(...)
TupleList_copyIntoBuffer(TupleList self, char buf, size_t len, bool byteswap) -> size_t
TupleList_createFromPackedBuffer(...)
createFromPackedBuffer(size_t size_used, char buf, size_t buf_len, bool byteswap, 
    Schema s, size_t expect_num_tuples = (size_t) -1) -> TupleList
TupleList_createFromPackedBuffer(size_t size_used, char buf, size_t buf_len, bool byteswap, 
    Schema s) -> TupleList
TupleList_createRawFromPackedBuffer(...)
createRawFromPackedBuffer(size_t size_used, char buf, size_t buf_len, bool byteswap, 
    Schema s, size_t expect_num_tuples = (size_t) -1) -> TupleList
TupleList_createRawFromPackedBuffer(size_t size_used, char buf, size_t buf_len, bool byteswap, 
    Schema s) -> TupleList
TupleList_empty(...)
TupleList_empty(TupleList self) -> bool
 
Is the list empty?
TupleList_end(...)
end() -> iterator
TupleList_end(TupleList self) -> const_iterator
 
STL compatible iterators.
TupleList_getRawBits(...)
TupleList_getRawBits(TupleList self) -> string
TupleList_getSchema(...)
TupleList_getSchema(TupleList self) -> Schema
 
Get the schema.
TupleList_getSize(...)
TupleList_getSize(TupleList self) -> size_t
 
Get the number of tuples in the list.
TupleList_push_back(...)
TupleList_push_back(TupleList self, Tuple r)
 
append a tuple to the list
TupleList_resize(...)
TupleList_resize(TupleList self, size_t size)
 
Change the size of the list any new tuples will be entirely null.
TupleList_setRawBits(...)
TupleList_setRawBits(TupleList self, char bits, size_t len)
TupleList_setSchema(...)
TupleList_setSchema(TupleList self, Schema schema)
 
set the schema for this list (also setting the schema for any tuples
in the list)
TupleList_setSize(...)
TupleList_setSize(TupleList self, size_t size)
 
Change the size of the list any new tuples will be entirely null.
TupleList_size(...)
TupleList_size(TupleList self) -> size_t
 
Get the number of tuples in the list.
TupleList_swigregister(...)
TuplePrivateImpl___eq__(...)
x.__eq__(y) <==> x==y
TuplePrivateImpl_copyFieldValueIntoBuffer(...)
TuplePrivateImpl_copyFieldValueIntoBuffer(char buf, size_t buf_len, Field f, FieldValue fv, bool byteswap) -> size_t
TuplePrivateImpl_extractBlob(...)
TuplePrivateImpl_extractBlob(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractBool(...)
TuplePrivateImpl_extractBool(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractDouble(...)
TuplePrivateImpl_extractDouble(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractFunction(...)
TuplePrivateImpl_extractFunction(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractInt(...)
TuplePrivateImpl_extractInt(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractList(...)
TuplePrivateImpl_extractList(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractLong(...)
TuplePrivateImpl_extractLong(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractString(...)
TuplePrivateImpl_extractString(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractTimestamp(...)
TuplePrivateImpl_extractTimestamp(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractTuple(...)
TuplePrivateImpl_extractTuple(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_extractVarLength(...)
TuplePrivateImpl_extractVarLength(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_field_values_get(...)
TuplePrivateImpl_field_values_get(TuplePrivateImpl self) -> FieldValueVector
TuplePrivateImpl_field_values_set(...)
TuplePrivateImpl_field_values_set(TuplePrivateImpl self, FieldValueVector field_values)
TuplePrivateImpl_get(...)
get(Field f) -> FieldValue
TuplePrivateImpl_get(TuplePrivateImpl self, Field f) -> FieldValue
TuplePrivateImpl_getBlobFromFieldValue(...)
TuplePrivateImpl_getBlobFromFieldValue(Field f, FieldValue fv) -> string
TuplePrivateImpl_getBoolFromFieldValue(...)
TuplePrivateImpl_getBoolFromFieldValue(Field f, FieldValue fv) -> bool
TuplePrivateImpl_getDoubleFromFieldValue(...)
TuplePrivateImpl_getDoubleFromFieldValue(Field f, FieldValue fv) -> double
TuplePrivateImpl_getFunctionFromFieldValue(...)
TuplePrivateImpl_getFunctionFromFieldValue(Field f, FieldValue fv) -> Function
TuplePrivateImpl_getIntFromFieldValue(...)
TuplePrivateImpl_getIntFromFieldValue(Field f, FieldValue fv) -> int
TuplePrivateImpl_getListFromFieldValue(...)
TuplePrivateImpl_getListFromFieldValue(Field f, FieldValue fv) -> FieldValueVector
TuplePrivateImpl_getLongFromFieldValue(...)
TuplePrivateImpl_getLongFromFieldValue(Field f, FieldValue fv) -> long long
TuplePrivateImpl_getStringFromFieldValue(...)
TuplePrivateImpl_getStringFromFieldValue(Field f, FieldValue fv) -> string
TuplePrivateImpl_getTimestampFromFieldValue(...)
TuplePrivateImpl_getTimestampFromFieldValue(Field f, FieldValue fv) -> Timestamp
TuplePrivateImpl_getTimestampLongFromFieldValue(...)
TuplePrivateImpl_getTimestampLongFromFieldValue(Field f, FieldValue fv) -> long long
TuplePrivateImpl_getTupleFromFieldValue(...)
TuplePrivateImpl_getTupleFromFieldValue(Field f, FieldValue fv) -> Tuple
TuplePrivateImpl_getTupleMutableFromFieldValue(...)
TuplePrivateImpl_getTupleMutableFromFieldValue(Field f, FieldValue fv) -> Tuple
TuplePrivateImpl_getVarLengthFromFieldValue(...)
TuplePrivateImpl_getVarLengthFromFieldValue(CompleteDataType cdt, Field f, FieldValue fv) -> string
TuplePrivateImpl_id_get(...)
TuplePrivateImpl_id_get(TuplePrivateImpl self) -> unsigned int
TuplePrivateImpl_id_set(...)
TuplePrivateImpl_id_set(TuplePrivateImpl self, unsigned int id)
TuplePrivateImpl_injectBlob(...)
TuplePrivateImpl_injectBlob(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectBool(...)
TuplePrivateImpl_injectBool(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectDouble(...)
TuplePrivateImpl_injectDouble(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectFunction(...)
TuplePrivateImpl_injectFunction(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectInt(...)
TuplePrivateImpl_injectInt(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectList(...)
TuplePrivateImpl_injectList(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectLong(...)
TuplePrivateImpl_injectLong(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectString(...)
TuplePrivateImpl_injectString(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectTimestamp(...)
TuplePrivateImpl_injectTimestamp(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectTuple(...)
TuplePrivateImpl_injectTuple(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_injectVarLength(...)
TuplePrivateImpl_injectVarLength(char buf, size_t size, Field field, FieldValue fv, 
    bool byteswap) -> size_t
TuplePrivateImpl_schema_get(...)
TuplePrivateImpl_schema_get(TuplePrivateImpl self) -> Schema
TuplePrivateImpl_schema_set(...)
TuplePrivateImpl_schema_set(TuplePrivateImpl self, Schema schema)
TuplePrivateImpl_setBlobFieldValue(...)
TuplePrivateImpl_setBlobFieldValue(string value, Field f, FieldValue fv)
TuplePrivateImpl_setBoolFieldValue(...)
TuplePrivateImpl_setBoolFieldValue(bool value, Field f, FieldValue fv)
TuplePrivateImpl_setDoubleFieldValue(...)
TuplePrivateImpl_setDoubleFieldValue(double value, Field f, FieldValue fv)
TuplePrivateImpl_setFieldValue(...)
TuplePrivateImpl_setFieldValue(FieldValue value, Field f, FieldValue lhs)
TuplePrivateImpl_setFieldValueFromPackedBuffer(...)
TuplePrivateImpl_setFieldValueFromPackedBuffer(char buf, size_t buf_len, Field f, FieldValue fv, bool byteswap) -> size_t
TuplePrivateImpl_setFunctionFieldValue(...)
TuplePrivateImpl_setFunctionFieldValue(Function value, Field f, FieldValue fv)
TuplePrivateImpl_setIntFieldValue(...)
TuplePrivateImpl_setIntFieldValue(int value, Field f, FieldValue fv)
TuplePrivateImpl_setListFieldValue(...)
TuplePrivateImpl_setListFieldValue(FieldValueVector value, Field f, FieldValue fv)
TuplePrivateImpl_setLongFieldValue(...)
TuplePrivateImpl_setLongFieldValue(long long value, Field f, FieldValue fv)
TuplePrivateImpl_setStringFieldValue(...)
TuplePrivateImpl_setStringFieldValue(string value, Field f, FieldValue fv)
TuplePrivateImpl_setTimestampFieldValue(...)
TuplePrivateImpl_setTimestampFieldValue(Timestamp value, Field f, FieldValue fv)
TuplePrivateImpl_setTimestampLongFieldValue(...)
TuplePrivateImpl_setTimestampLongFieldValue(long long value, Field f, FieldValue fv)
TuplePrivateImpl_setTupleFieldValue(...)
TuplePrivateImpl_setTupleFieldValue(Tuple value, Field f, FieldValue fv)
TuplePrivateImpl_setVarLengthFieldValue(...)
TuplePrivateImpl_setVarLengthFieldValue(CompleteDataType cdt, string value, Field f, FieldValue fv)
TuplePrivateImpl_swigregister(...)
TupleVector___bool__(...)
TupleVector___bool__(TupleVector self) -> bool
TupleVector___delitem__(...)
__delitem__(difference_type i)
TupleVector___delitem__(TupleVector self, PySliceObject slice)
TupleVector___delslice__(...)
TupleVector___delslice__(TupleVector self, difference_type i, difference_type j)
TupleVector___getitem__(...)
__getitem__(PySliceObject slice) -> TupleVector
TupleVector___getitem__(TupleVector self, difference_type i) -> value_type
TupleVector___getslice__(...)
TupleVector___getslice__(TupleVector self, difference_type i, difference_type j) -> TupleVector
TupleVector___len__(...)
TupleVector___len__(TupleVector self) -> size_type
TupleVector___nonzero__(...)
TupleVector___nonzero__(TupleVector self) -> bool
TupleVector___setitem__(...)
__setitem__(PySliceObject slice, TupleVector v)
__setitem__(PySliceObject slice)
TupleVector___setitem__(TupleVector self, difference_type i, value_type x)
TupleVector___setslice__(...)
__setslice__(difference_type i, difference_type j, TupleVector v = std::vector< sb::Tuple,std::allocator< sb::Tuple > >())
TupleVector___setslice__(TupleVector self, difference_type i, difference_type j)
TupleVector_append(...)
TupleVector_append(TupleVector self, value_type x)
TupleVector_assign(...)
TupleVector_assign(TupleVector self, size_type n, value_type x)
TupleVector_back(...)
TupleVector_back(TupleVector self) -> value_type
TupleVector_begin(...)
TupleVector_begin(TupleVector self) -> iterator
TupleVector_capacity(...)
TupleVector_capacity(TupleVector self) -> size_type
TupleVector_clear(...)
TupleVector_clear(TupleVector self)
TupleVector_empty(...)
TupleVector_empty(TupleVector self) -> bool
TupleVector_end(...)
TupleVector_end(TupleVector self) -> iterator
TupleVector_erase(...)
erase(iterator pos) -> iterator
TupleVector_erase(TupleVector self, iterator first, iterator last) -> iterator
TupleVector_front(...)
TupleVector_front(TupleVector self) -> value_type
TupleVector_get_allocator(...)
TupleVector_get_allocator(TupleVector self) -> allocator_type
TupleVector_insert(...)
insert(iterator pos, value_type x) -> iterator
TupleVector_insert(TupleVector self, iterator pos, size_type n, value_type x)
TupleVector_iterator(...)
TupleVector_iterator(TupleVector self) -> SwigPyIterator
TupleVector_pop(...)
TupleVector_pop(TupleVector self) -> value_type
TupleVector_pop_back(...)
TupleVector_pop_back(TupleVector self)
TupleVector_push_back(...)
TupleVector_push_back(TupleVector self, value_type x)
TupleVector_rbegin(...)
TupleVector_rbegin(TupleVector self) -> reverse_iterator
TupleVector_rend(...)
TupleVector_rend(TupleVector self) -> reverse_iterator
TupleVector_reserve(...)
TupleVector_reserve(TupleVector self, size_type n)
TupleVector_resize(...)
resize(size_type new_size)
TupleVector_resize(TupleVector self, size_type new_size, value_type x)
TupleVector_size(...)
TupleVector_size(TupleVector self) -> size_type
TupleVector_swap(...)
TupleVector_swap(TupleVector self, TupleVector v)
TupleVector_swigregister(...)
Tuple___eq__(...)
x.__eq__(y) <==> x==y
 
If y is a Python tuple, before comparison it will be converted to a Tuple
with x's Schema.
Tuple___getitem__(...)
__getitem__(size_t field_num) -> FieldValue
__getitem__(string field_name) -> FieldValue
Tuple___getitem__(Tuple self, Field field) -> FieldValue
Tuple___len__(...)
x.__len__() <==> len(x)
Tuple___setitem__(...)
__setitem__(size_t field_num, FieldValue fv)
__setitem__(string field_name, FieldValue fv)
Tuple___setitem__(Tuple self, Field field, FieldValue fv)
Tuple___str__(...)
x.__str__() <==> str(x)
 
Return a human-readable string value representing this tuple in its
entirety (including all header values, if applicable).
 
the string value.
Tuple_as_string_external(...)
as_string_external(char delimiter = ',', string null_string = getNullString()) -> string
as_string_external(char delimiter = ',') -> string
Tuple_as_string_external(Tuple self) -> string
 
Return a human-readable string value representing this tuple.
 
It compares to as_string by allowing a user-specified delimiter
between fields, making the header timestamp stand out, and omitting
the TupleId header field. null_string is written out for any null
field. the string value
Tuple_clear(...)
Tuple_clear(Tuple self)
 
null all fields in the tuple
Tuple_copyIntoBuffer(...)
Tuple_copyIntoBuffer(Tuple self, void buf, size_t len, bool byteswap) -> size_t
Tuple_createFromPackedBuffer(...)
Tuple_createFromPackedBuffer(size_t size_used, void buf, size_t buf_len, bool byteswap, 
    Schema s) -> Tuple
Tuple_getBlobBuffer(...)
getBlobBuffer(Field f) -> string
getBlobBuffer(size_t i) -> string
Tuple_getBlobBuffer(Tuple self, string n) -> string
 
Return the value of a BLOB field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the BLOB value.
Tuple_getBool(...)
getBool(Field f) -> bool
getBool(size_t i) -> bool
Tuple_getBool(Tuple self, string n) -> bool
 
Return the value of a Boolean field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the Boolean value.
Tuple_getDouble(...)
getDouble(Field f) -> double
getDouble(size_t i) -> double
Tuple_getDouble(Tuple self, string n) -> double
 
Return the value of a double field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the double value.
Tuple_getFieldValue(...)
getFieldValue(Field f) -> FieldValue
getFieldValue(Field f) -> FieldValue
getFieldValue(size_t field_num) -> FieldValue
getFieldValue(size_t field_num) -> FieldValue
getFieldValue(string field_name) -> FieldValue
Tuple_getFieldValue(Tuple self, string field_name) -> FieldValue
 
Takes the name of a field in this tuple's schema, returns the
corresponding field value.
Tuple_getFunction(...)
getFunction(Field f) -> Function
getFunction(size_t i) -> Function
Tuple_getFunction(Tuple self, string n) -> Function
 
Return the value of a function field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the function value.
Tuple_getId(...)
Tuple_getId(Tuple self) -> unsigned int
 
The id for this tuple
Tuple_getInt(...)
getInt(Field f) -> int
getInt(size_t i) -> int
Tuple_getInt(Tuple self, string n) -> int
 
Return the value of an int field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the int value.
Tuple_getList(...)
getList(Field f) -> FieldValueVector
getList(size_t i) -> FieldValueVector
Tuple_getList(Tuple self, string n) -> FieldValueVector
 
Return the value of a LIST field.
 
The Schema::Field objects used to set and get Tuple field values must
be obtained via the Tuple's Schema object. A Schema.Field object that
has been created by the user or retrieved from a different Schema may
not work.
 
the LIST value.
Tuple_getLong(...)
getLong(Field f) -> long long
getLong(size_t i) -> long long
Tuple_getLong(Tuple self, string n) -> long long
 
Return the value of a long field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the long value.
Tuple_getNullString(...)
Tuple_getNullString() -> string
Tuple_getNumFields(...)
Tuple_getNumFields(Tuple self) -> size_t
 
the number of fields in the tuple's schema
Tuple_getSchema(...)
Tuple_getSchema(Tuple self) -> Schema
 
Returns the schema of the stream.
Tuple_getSize(...)
Tuple_getSize(Tuple self) -> size_t
 
the serialized size of this tuple
Tuple_getString(...)
getString(Field f) -> string
getString(size_t i) -> string
Tuple_getString(Tuple self, string n) -> string
 
Return the value of a string field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the string value.
Tuple_getTimestamp(...)
getTimestamp(Field f) -> Timestamp
getTimestamp(size_t i) -> Timestamp
Tuple_getTimestamp(Tuple self, string n) -> Timestamp
 
Return the value of a Timestamp field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the Timestamp value.
Tuple_getTuple(...)
getTuple(Field f) -> Tuple
getTuple(size_t i) -> Tuple
Tuple_getTuple(Tuple self, string n) -> Tuple
 
Return the value of a nested tuple field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
the nested tuple value.
Tuple_hasHeader(...)
Tuple_hasHeader(Tuple self) -> bool
 
true if tuple has a header, false otherwise
Tuple_isNull(...)
isNull(Field f) -> bool
isNull(size_t i) -> bool
Tuple_isNull(Tuple self, string n) -> bool
 
Test the null setting for field f.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
 
true if field is null, false otherwise
Tuple_setBlobBuffer(...)
setBlobBuffer(Field f, string v)
setBlobBuffer(size_t i, string v)
Tuple_setBlobBuffer(Tuple self, string n, string v)
 
Set the value of a BLOB field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setBool(...)
setBool(Field f, bool v)
setBool(size_t i, bool v)
Tuple_setBool(Tuple self, string n, bool v)
 
Set the value of a Boolean field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setDouble(...)
setDouble(Field f, double v)
setDouble(size_t i, double v)
Tuple_setDouble(Tuple self, string n, double v)
 
Set the value of a double field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setFieldValue(...)
setFieldValue(Field f, FieldValue fv)
setFieldValue(size_t field_num, FieldValue fv)
Tuple_setFieldValue(Tuple self, string field_name, FieldValue fv)
 
Takes the name of a field in this tuple's schema and sets the
corresponding field value.
Tuple_setFromPackedBuffer(...)
Tuple_setFromPackedBuffer(Tuple self, void buf, size_t buf_len, bool byteswap, 
    Schema s) -> size_t
Tuple_setFunction(...)
setFunction(Field f, Function v)
setFunction(size_t i, Function v)
Tuple_setFunction(Tuple self, string n, Function v)
 
Set the value of a function field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setId(...)
Tuple_setId(Tuple self, unsigned int tid)
 
set the id
Tuple_setInt(...)
setInt(Field f, int v)
setInt(size_t i, int v)
Tuple_setInt(Tuple self, string n, int v)
 
Set the value of an integer field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setList(...)
setList(Field f, FieldValueVector v)
setList(size_t i, FieldValueVector v)
Tuple_setList(Tuple self, string n, FieldValueVector v)
 
Set the value of a LIST field.
 
The Schema::Field objects used to set and get Tuple field values must
be obtained via the Tuple's Schema object. A Schema.Field object that
has been created by the user or retrieved from a different Schema may
not work.
Tuple_setLong(...)
setLong(Field f, long long v)
setLong(size_t i, long long v)
Tuple_setLong(Tuple self, string n, long long v)
 
Set the value of a long field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setNull(...)
setNull(Field f)
setNull(size_t i)
Tuple_setNull(Tuple self, string n)
 
Set the null setting for field f.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setSchema(...)
Tuple_setSchema(Tuple self, Schema arg1)
 
set the schema
Tuple_setString(...)
setString(Field field, string value, Flags flags = NONE)
setString(Field field, string value)
setString(size_t field, char data, size_t len, Flags flags = NONE)
setString(size_t field, char data, size_t len)
setString(string field, char data, size_t len, Flags flags = NONE)
setString(string field, char data, size_t len)
setString(Field field, char data, size_t len, Flags flags = NONE)
setString(Field field, char data, size_t len)
setString(size_t field_index, string value, Flags flags = NONE)
setString(size_t field_index, string value)
setString(string field_name, string value, Flags flags = NONE)
Tuple_setString(Tuple self, string field_name, string value)
 
Set the value of a string field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setTimestamp(...)
setTimestamp(Field f, Timestamp v)
setTimestamp(size_t i, Timestamp v)
Tuple_setTimestamp(Tuple self, string n, Timestamp v)
 
Set the value of a Timestamp field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_setTuple(...)
setTuple(Field f, Tuple v)
setTuple(size_t i, Tuple v)
Tuple_setTuple(Tuple self, string n, Tuple v)
 
Set the value of a nested tuple field.
 
The Field objects used to set and get Tuple field values must be
obtained via the Tuple's Schema object. A Schema.Field object that has
been created by the user or retrieved from a different Schema may not
work.
Tuple_swigregister(...)
Tuple_toDelimitedString(...)
toDelimitedString(string delimiter, string null_string = getNullString(), 
    bool include_names = False, bool quote_all_strings = False) -> string
toDelimitedString(string delimiter, string null_string = getNullString(), 
    bool include_names = False) -> string
toDelimitedString(string delimiter, string null_string = getNullString()) -> string
Tuple_toDelimitedString(Tuple self, string delimiter) -> string
 
Return a string value representing this tuple, separated by the given
delimiter.
 
Parameters:
-----------
 
delimiter:  the string to put between fields
 
null_string:  the string used to represent null values
 
include_names:  whether to preface each field with "<name>="
 
quote_all_strings:  whether to put quotes around all strings,
regardless of need
 
the result string
Tuple_verify(...)
Tuple_verify(Tuple self)
 
verify that the tuple is valid Throws StreamBaseException on invalid
tuple
Tuple_writeCSVString(...)
writeCSVString(std::ostream out, char delim, char quote, string null_string = getNullString())
Tuple_writeCSVString(Tuple self, std::ostream out, char delim, char quote)
URIVector___bool__(...)
URIVector___bool__(URIVector self) -> bool
URIVector___delitem__(...)
__delitem__(difference_type i)
URIVector___delitem__(URIVector self, PySliceObject slice)
URIVector___delslice__(...)
URIVector___delslice__(URIVector self, difference_type i, difference_type j)
URIVector___getitem__(...)
__getitem__(PySliceObject slice) -> URIVector
URIVector___getitem__(URIVector self, difference_type i) -> value_type
URIVector___getslice__(...)
URIVector___getslice__(URIVector self, difference_type i, difference_type j) -> URIVector
URIVector___len__(...)
URIVector___len__(URIVector self) -> size_type
URIVector___nonzero__(...)
URIVector___nonzero__(URIVector self) -> bool
URIVector___setitem__(...)
__setitem__(PySliceObject slice, URIVector v)
__setitem__(PySliceObject slice)
URIVector___setitem__(URIVector self, difference_type i, value_type x)
URIVector___setslice__(...)
__setslice__(difference_type i, difference_type j, URIVector v = std::vector< sb::StreamBaseURI,std::allocator< sb::StreamBaseURI > >())
URIVector___setslice__(URIVector self, difference_type i, difference_type j)
URIVector_append(...)
URIVector_append(URIVector self, value_type x)
URIVector_assign(...)
URIVector_assign(URIVector self, size_type n, value_type x)
URIVector_back(...)
URIVector_back(URIVector self) -> value_type
URIVector_begin(...)
URIVector_begin(URIVector self) -> iterator
URIVector_capacity(...)
URIVector_capacity(URIVector self) -> size_type
URIVector_clear(...)
URIVector_clear(URIVector self)
URIVector_empty(...)
URIVector_empty(URIVector self) -> bool
URIVector_end(...)
URIVector_end(URIVector self) -> iterator
URIVector_erase(...)
erase(iterator pos) -> iterator
URIVector_erase(URIVector self, iterator first, iterator last) -> iterator
URIVector_front(...)
URIVector_front(URIVector self) -> value_type
URIVector_get_allocator(...)
URIVector_get_allocator(URIVector self) -> allocator_type
URIVector_insert(...)
insert(iterator pos, value_type x) -> iterator
URIVector_insert(URIVector self, iterator pos, size_type n, value_type x)
URIVector_iterator(...)
URIVector_iterator(URIVector self) -> SwigPyIterator
URIVector_pop(...)
URIVector_pop(URIVector self) -> value_type
URIVector_pop_back(...)
URIVector_pop_back(URIVector self)
URIVector_push_back(...)
URIVector_push_back(URIVector self, value_type x)
URIVector_rbegin(...)
URIVector_rbegin(URIVector self) -> reverse_iterator
URIVector_rend(...)
URIVector_rend(URIVector self) -> reverse_iterator
URIVector_reserve(...)
URIVector_reserve(URIVector self, size_type n)
URIVector_resize(...)
resize(size_type new_size)
URIVector_resize(URIVector self, size_type new_size, value_type x)
URIVector_size(...)
URIVector_size(URIVector self) -> size_type
URIVector_swap(...)
URIVector_swap(URIVector self, URIVector v)
URIVector_swigregister(...)
URI___nonzero__(...)
x.__nonzero__() <==> x != 0
URI___str__(...)
x.__str__() <==> str(x)
x.__str__() <==> str(x)
 
Return the URI as a string.
URI_addParameter(...)
URI_addParameter(URI self, string key, string value)
 
Add a parameter.
URI_fromEnvironment(...)
URI_fromEnvironment() -> URI
URI_getBaseURI(...)
URI_getBaseURI(URI self) -> URI
 
return a StreamBaseURI without Parameters
URI_getContainer(...)
URI_getContainer(URI self) -> string
 
Returns the container name component of the URI.
 
May return an empty string if no container was specified.
URI_getHost(...)
URI_getHost(URI self) -> string
 
Return the host component of the URI.
URI_getNumParameters(...)
URI_getNumParameters(URI self) -> size_t
 
return the number of parameters
URI_getParam(...)
URI_getParam(URI self, string key) -> string
 
Return a parameter, or empty string if undefined.
URI_getParameter(...)
getParameter(string key) -> string
URI_getParameter(URI self, string key, string value) -> bool
 
Return a parameter into value (returning true if one was found).
 
Useful to distinguish an undefined parameter from an empty one.
URI_getPassword(...)
URI_getPassword(URI self) -> string
 
Return the password component of the URI.
URI_getPort(...)
URI_getPort(URI self) -> unsigned int
 
Return the port component of the URI.
URI_getUser(...)
URI_getUser(URI self) -> string
 
Return the user name component of the URI.
URI_removeParameter(...)
URI_removeParameter(URI self, string key)
 
Add a parameter.
URI_swigregister(...)
URI_vectorFromEnvironment(...)
URI_vectorFromEnvironment() -> URIVector
URI_vectorFromString(...)
URI_vectorFromString(string uris) -> URIVector
Version_checkPrintVersion(...)
Version_checkPrintVersion(int argc, char argv) -> bool
Version_swigregister(...)
assert_unreachable(...)
assert_unreachable()
delete_ArgumentOutOfRange(...)
delete_ArgumentOutOfRange(ArgumentOutOfRange self)
delete_BoolVector(...)
delete_BoolVector(BoolVector self)
delete_Client(...)
delete_Client(Client self)
 
Destroys a session.
delete_ClientSettings(...)
delete_ClientSettings(ClientSettings self)
delete_CompleteDataType(...)
delete_CompleteDataType(CompleteDataType self)
 
Destructor.
delete_DataType(...)
delete_DataType(DataType self)
delete_DequeueResult(...)
delete_DequeueResult(DequeueResult self)
delete_DoubleVector(...)
delete_DoubleVector(DoubleVector self)
delete_Errors(...)
delete_Errors(Errors self)
delete_Field(...)
delete_Field(Field self)
delete_FieldValue(...)
delete_FieldValue(FieldValue self)
 
Destructor.
delete_FieldValueVector(...)
delete_FieldValueVector(FieldValueVector self)
delete_FieldVector(...)
delete_FieldVector(FieldVector self)
delete_Function(...)
delete_Function(Function self)
delete_IntVector(...)
delete_IntVector(IntVector self)
delete_ListVector(...)
delete_ListVector(ListVector self)
delete_LongVector(...)
delete_LongVector(LongVector self)
delete_Schema(...)
delete_Schema(Schema self)
delete_SchemaRep(...)
delete_SchemaRep(SchemaRep self)
delete_StreamBaseException(...)
delete_StreamBaseException(StreamBaseException self)
 
throw () Destructor.
delete_StreamBaseXmlRpcFault(...)
delete_StreamBaseXmlRpcFault(StreamBaseXmlRpcFault self)
delete_StreamProperties(...)
delete_StreamProperties(StreamProperties self)
delete_StringHashFunc(...)
delete_StringHashFunc(StringHashFunc self)
delete_StringVector(...)
delete_StringVector(StringVector self)
delete_SwigPyIterator(...)
delete_SwigPyIterator(SwigPyIterator self)
delete_Timestamp(...)
delete_Timestamp(Timestamp self)
delete_TimestampVector(...)
delete_TimestampVector(TimestampVector self)
delete_Tuple(...)
delete_Tuple(Tuple self)
 
Destructor.
delete_TupleList(...)
delete_TupleList(TupleList self)
delete_TuplePrivateImpl(...)
delete_TuplePrivateImpl(TuplePrivateImpl self)
delete_TupleVector(...)
delete_TupleVector(TupleVector self)
delete_URI(...)
delete_URI(URI self)
delete_URIVector(...)
delete_URIVector(URIVector self)
delete_Version(...)
delete_Version(Version self)
demangle(...)
demangle(char type) -> string
demangle(string type) -> string
dummyFunctionToMakeSureStreamBaseExceptionsGetProperlyWrapped(...)
dummyFunctionToMakeSureStreamBaseExceptionsGetProperlyWrapped()
fvvFromBlobVector(...)
fvvFromBlobVector(StringVector arg) -> FieldValueVector
fvvFromBoolVector(...)
fvvFromBoolVector(BoolVector arg) -> FieldValueVector
fvvFromDoubleVector(...)
fvvFromDoubleVector(DoubleVector arg) -> FieldValueVector
fvvFromFieldValueVector(...)
fvvFromFieldValueVector(FieldValueVector arg) -> FieldValueVector
fvvFromIntVector(...)
fvvFromIntVector(IntVector arg) -> FieldValueVector
fvvFromListVector(...)
fvvFromListVector(ListVector arg) -> FieldValueVector
fvvFromLongVector(...)
fvvFromLongVector(LongVector arg) -> FieldValueVector
fvvFromStringVector(...)
fvvFromStringVector(StringVector arg) -> FieldValueVector
fvvFromTimestampVector(...)
fvvFromTimestampVector(TimestampVector arg) -> FieldValueVector
fvvFromTupleVector(...)
fvvFromTupleVector(TupleVector arg) -> FieldValueVector
getUnaligned(...)
getUnaligned(Timestamp p) -> Timestamp
leadershipStatusDecode(...)
leadershipStatusDecode(string stringStatus) -> LeadershipStatus
leadershipStatusDecode(int intStatus) -> LeadershipStatus
new_ArgumentOutOfRange(...)
ArgumentOutOfRange(string code, string message, Type a_error_type = NON_FATAL_ERROR, 
    char type = "ArgumentOutOfRange")
ArgumentOutOfRange(string code, string message, Type a_error_type = NON_FATAL_ERROR)
ArgumentOutOfRange(string code, string message)
ArgumentOutOfRange(string code, string message, StreamBaseException c, 
    Type a_error_type = NON_FATAL_ERROR, char type = "ArgumentOutOfRange")
ArgumentOutOfRange(string code, string message, StreamBaseException c, 
    Type a_error_type = NON_FATAL_ERROR)
new_ArgumentOutOfRange(string code, string message, StreamBaseException c) -> ArgumentOutOfRange
new_BoolVector(...)
BoolVector()
BoolVector(BoolVector arg0)
BoolVector(size_type size)
new_BoolVector(size_type size, value_type value) -> BoolVector
new_Client(...)
StreamBaseClient(URI uri = sb::StreamBaseURI::fromEnvironment(), int buffer_size = 0, 
    int flush_interval = DEFAULT_FLUSH_INTERVAL)
StreamBaseClient(URI uri = sb::StreamBaseURI::fromEnvironment(), int buffer_size = 0)
StreamBaseClient(URI uri = sb::StreamBaseURI::fromEnvironment())
StreamBaseClient()
StreamBaseClient(string uris, int buffer_size = 0, int flush_interval = DEFAULT_FLUSH_INTERVAL)
StreamBaseClient(string uris, int buffer_size = 0)
StreamBaseClient(string uris)
StreamBaseClient(URIVector uris, int buffer_size = 0, int flush_interval = DEFAULT_FLUSH_INTERVAL)
StreamBaseClient(URIVector uris, int buffer_size = 0)
StreamBaseClient(URIVector uris)
StreamBaseClient(URIVector uris, ClientSettings settings, int buffer_size = 0, 
    int flush_interval = DEFAULT_FLUSH_INTERVAL)
StreamBaseClient(URIVector uris, ClientSettings settings, int buffer_size = 0)
new_Client(URIVector uris, ClientSettings settings) -> Client
new_ClientSettings(...)
new_ClientSettings(bool haModeOn) -> ClientSettings
 
Loads all the client settings.
new_CompleteDataType(...)
CompleteDataType()
new_CompleteDataType(CompleteDataType cdt) -> CompleteDataType
 
Copy constructor.
new_DataType(...)
DataType()
new_DataType(Rep type) -> DataType
 
Construct a DataType equal to DataType::NONE.
new_DequeueResult(...)
DequeueResult()
new_DequeueResult(StreamProperties props, TupleList tuples, URI serverURI, 
    LeadershipStatus _leadershipStatus) -> DequeueResult
 
Create a Dequeue Result with a list of tuples, with the given
LeadershipStatus.
new_DoubleVector(...)
DoubleVector()
DoubleVector(DoubleVector arg0)
DoubleVector(size_type size)
new_DoubleVector(size_type size, value_type value) -> DoubleVector
new_Errors(...)
new_Errors() -> Errors
new_Field(...)
Field()
Field(string name, DataType type, size_t size = (size_t) -1)
Field(string name, DataType type)
Field(string name, DataType type, Schema schema)
Field(string name, CompleteDataType cdt)
new_Field(Field f) -> Field
 
Copy constructor.
new_FieldValue(...)
FieldValue()
FieldValue(CompleteDataType cdt)
FieldValue(bool value)
FieldValue(int value)
FieldValue(double value)
FieldValue(long long value)
FieldValue(Timestamp value)
FieldValue(char value)
FieldValue(string value)
FieldValue(DataType type, string value)
FieldValue(Tuple value)
FieldValue(Function value)
FieldValue(FieldValueVector value)
FieldValue(DataType type, CompleteDataType elemType)
new_FieldValue(FieldValue fv) -> FieldValue
 
Copy constructor.
new_FieldValueVector(...)
FieldValueVector()
FieldValueVector(FieldValueVector arg0)
FieldValueVector(size_type size)
new_FieldValueVector(size_type size, value_type value) -> FieldValueVector
new_FieldVector(...)
FieldVector()
FieldVector(FieldVector arg0)
FieldVector(size_type size)
new_FieldVector(size_type size, value_type value) -> FieldVector
new_Function(...)
Function(string name, string functionDefinition, string body, 
    Tuple environment, CompleteDataType type)
Function(string name, string functionDefinition, CompleteDataType type)
Function(Function f)
new_Function(Function f, string inFT, string outFT, CompleteDataType type) -> Function
new_IntVector(...)
IntVector()
IntVector(IntVector arg0)
IntVector(size_type size)
new_IntVector(size_type size, value_type value) -> IntVector
new_ListVector(...)
ListVector()
ListVector(ListVector arg0)
ListVector(size_type size)
new_ListVector(size_type size, value_type value) -> ListVector
new_LongVector(...)
LongVector()
LongVector(LongVector arg0)
LongVector(size_type size)
new_LongVector(size_type size, value_type value) -> LongVector
new_Schema(...)
Schema()
Schema(Schema schema)
Schema(string name, std::vector<(sb::Schema::Field,std::allocator<(sb::Schema::Field)>)> fields, 
    Flags flags = sb::Schema::Flags())
Schema(string name, std::vector<(sb::Schema::Field,std::allocator<(sb::Schema::Field)>)> fields)
Schema(std::vector<(sb::Schema::Field,std::allocator<(sb::Schema::Field)>)> fields, 
    Flags flags = sb::Schema::Flags())
new_Schema(std::vector<(sb::Schema::Field,std::allocator<(sb::Schema::Field)>)> fields) -> Schema
 
Constructs a Schema from a vector of Field objects.
 
If the vector is empty the Schema will contain no fields.
new_StreamBaseException(...)
StreamBaseException(string code, string message, Type error_type = UNKNOWNTYPE, 
    string type = "StreamBaseException")
StreamBaseException(string code, string message, Type error_type = UNKNOWNTYPE)
StreamBaseException(string code, string message)
StreamBaseException(string code, string message, StreamBaseException c, 
    Type error_type = UNKNOWNTYPE, string type = "StreamBaseException")
StreamBaseException(string code, string message, StreamBaseException c, 
    Type error_type = UNKNOWNTYPE)
new_StreamBaseException(string code, string message, StreamBaseException c) -> StreamBaseException
 
Constructor.
 
Parameters:
-----------
 
code:  see ExceptionsCodes.hpp; use SB_NEW_MESSAGE_CODE if in doubt
 
message:  the exception message
 
c:  an exception that is the "cause" of this exception
 
error_type:  the class of error, for server runtime error handling
 
type:  the type of the exception
new_StreamBaseXmlRpcFault(...)
StreamBaseXmlRpcFault(int fault_code, string fault_string)
StreamBaseXmlRpcFault(string code, string message, Type error_type = UNKNOWNTYPE, 
    string type = "StreamBaseXmlRpcFault")
StreamBaseXmlRpcFault(string code, string message, Type error_type = UNKNOWNTYPE)
StreamBaseXmlRpcFault(string code, string message)
StreamBaseXmlRpcFault(string code, string message, StreamBaseException c, 
    Type error_type = UNKNOWNTYPE, string type = "StreamBaseXmlRpcFault")
StreamBaseXmlRpcFault(string code, string message, StreamBaseException c, 
    Type error_type = UNKNOWNTYPE)
new_StreamBaseXmlRpcFault(string code, string message, StreamBaseException c) -> StreamBaseXmlRpcFault
new_StreamProperties(...)
new_StreamProperties() -> StreamProperties
 
Null constructor. Object will have no name and no schema.
new_StringHashFunc(...)
new_StringHashFunc() -> StringHashFunc
new_StringVector(...)
StringVector()
StringVector(StringVector arg0)
StringVector(size_type size)
new_StringVector(size_type size, value_type value) -> StringVector
new_Timestamp(...)
new_Timestamp() -> Timestamp
 
Create a default Timestamp.
 
Will initialized to 00:00:00 1 Jan 1970.
new_TimestampVector(...)
TimestampVector()
TimestampVector(TimestampVector arg0)
TimestampVector(size_type size)
new_TimestampVector(size_type size, value_type value) -> TimestampVector
new_Tuple(...)
Tuple()
Tuple(Tuple t)
new_Tuple(Schema s) -> Tuple
 
Construct a tuple of the specified schema.
new_TupleList(...)
TupleList()
TupleList(Tuple tuple)
TupleList(TupleList list)
TupleList(Schema schema, size_t size = 0)
new_TupleList(Schema schema) -> TupleList
 
Create tuple list with an initial size of size
new_TuplePrivateImpl(...)
TuplePrivateImpl()
new_TuplePrivateImpl(TuplePrivateImpl t) -> TuplePrivateImpl
new_TupleVector(...)
TupleVector()
TupleVector(TupleVector arg0)
TupleVector(size_type size)
new_TupleVector(size_type size, value_type value) -> TupleVector
new_URI(...)
StreamBaseURI()
StreamBaseURI(string uri)
StreamBaseURI(string host, unsigned int port, string user = "", string password = "")
StreamBaseURI(string host, unsigned int port, string user = "")
StreamBaseURI(string host, unsigned int port)
StreamBaseURI(string host, string container, unsigned int port, string user = "", 
    string password = "")
StreamBaseURI(string host, string container, unsigned int port, string user = "")
StreamBaseURI(string host, string container, unsigned int port)
StreamBaseURI(string host, unsigned int port, ParamMap paramMap)
new_URI(string host, string container, unsigned int port, ParamMap paramMap) -> URI
 
Create explicitly from host/port with container, including a map of
parameters.
new_URIVector(...)
URIVector()
URIVector(URIVector arg0)
URIVector(size_type size)
new_URIVector(size_type size, value_type value) -> URIVector
new_Version(...)
new_Version() -> Version
nmstl_memcpy(...)
nmstl_memcpy(void dest, void src, size_t n) -> void
setUnaligned(...)
setUnaligned(Timestamp p, Timestamp value)
to_escaped_string(...)
to_escaped_string(void data, size_t length) -> string
to_escaped_string(string s) -> string
to_hex_string(...)
to_hex_string(void data, size_t length) -> string
to_hex_string(string s) -> string
to_human_readable(...)
to_human_readable(void data, size_t length) -> string
to_human_readable(string s) -> string
to_lower(...)
to_lower(string a_input) -> string
to_string(...)
to_string(char ch) -> string
to_string(string s) -> string
to_string(void t) -> string
to_string(bool i) -> string
to_string(type_info i) -> string
to_string(char t) -> string
to_string(unsigned char t) -> string
to_string(short t) -> string
to_string(unsigned short t) -> string
to_string(int t) -> string
to_string(unsigned int t) -> string
to_string(long t) -> string
to_string(unsigned long t) -> string
to_string(long long t) -> string
to_string(unsigned long long t) -> string
to_string(float t) -> string
to_string(double t) -> string
to_upper(...)
to_upper(string a_input) -> string

 
Data
        Client_ALL_CONTAINERS = 5
Client_DEFAULT_FLUSH_INTERVAL = 250
Client_FULLY_QUALIFIED_NAMES = 1
Client_INCLUDE_MODULES = 2
DataType_BLOB = 14
DataType_BOOL = 12
DataType_CAPTURE = 17
DataType_DOUBLE = 8
DataType_FUNCTION = 18
DataType_INT = 7
DataType_LIST = 16
DataType_LONG = 13
DataType_NONE = 0
DataType_STRING = 10
DataType_TIMESTAMP = 11
DataType_TUPLE = 15
DequeueResult_CLOSED = 3
DequeueResult_GOOD = 1
DequeueResult_TIMEOUT = 2
DequeueResult_UNINITIALIZED = 0
EntityType_CONTAINER = 5
EntityType_INPUT_STREAMS = 100
EntityType_OPERATOR = 3
EntityType_OUTPUT_STREAMS = 101
EntityType_SCHEMA = 2
EntityType_STREAM = 1
EntityType_TABLE = 6
EntityType_WINDOW_SPEC = 4
Errors_ADAPTER_ERROR = 24
Errors_AUTHENTICATION_ERROR = 9
Errors_CHECKPOINT_CONSUMPTION_ERROR = 20
Errors_CHECKPOINT_CREATION_ERROR = 19
Errors_CHECKPOINT_ERROR = 17
Errors_CHECKPOINT_SETUP_ERROR = 18
Errors_CLUSTER_NETWORK_ERROR = 16
Errors_CONFIG_ERROR = 15
Errors_CONTAINER_ERROR = 25
Errors_DB_ERROR = 8
Errors_EVAL_ERROR = 2
Errors_EVAL_PLUGIN_ERROR = 13
Errors_EXPR_ERROR = 10
Errors_FATAL_ERROR = 1
Errors_HA_IO_ERROR = 22
Errors_MEM_ERROR = 3
Errors_NETWORK_ERROR = 4
Errors_NON_FATAL_ERROR = 1000
Errors_ORDERING_ERROR = 23
Errors_PAGE_POOL_ERROR = 21
Errors_PLUGIN_ERROR = 12
Errors_TUPLE_ERROR = 14
Errors_TYPECHECK_ERROR = 6
Errors_UNKNOWNTYPE = 0
Errors_USAGE_ERROR = 11
Errors_XMLRPC_ERROR = 7
Errors_XML_ERROR = 5
Field_LIST_HEADER_SIZE = 8
Field_NESTED_TUPLE_HEADER_SIZE = 4
Field_STRING_HEADER_SIZE = 4
Field_VARLEN_HEADER_SIZE = 4
LEADER = 1
NMSTL_VERSION = '0.5'
NON_LEADER = 0
SB_CONT_NOT_STARTED = 'SB-CT-0000'
SB_HA_BAD_METHOD = 'SB-HA-0001'
SB_NEW_MESSAGE_CODE = 'SB-NEW-0000'
SB_NOT_FOUND_CODE = 'SB-NOT-FOUND-0002'
STREAMBASE_MAJOR_MINOR_VERSION = '7.7'
STREAMBASE_VERSION = 70708
STREAMBASE_VERSION_MAJOR = 7
STREAMBASE_VERSION_MINOR = 7
STREAMBASE_VERSION_PATCH = 8
Schema_NO_HEADER = 1
StreamProperties_FLATTEN = 0
StreamProperties_NEST = 1
StreamProperties_RAW = 2
Timestamp_MAX_DAY = 31
Timestamp_MAX_HOUR = 23
Timestamp_MAX_MINUTE = 59
Timestamp_MAX_MONTH = 12
Timestamp_MAX_SECOND = 59
Timestamp_MAX_YEAR = 9999
Timestamp_MIN_DAY = 1
Timestamp_MIN_HOUR = 0
Timestamp_MIN_MINUTE = 0
Timestamp_MIN_MONTH = 1
Timestamp_MIN_SECOND = 0
Timestamp_MIN_YEAR = 1400
Tuple_NONE = 0
Tuple_TRUNCATE = 1
URI_DEFAULT_NODE_MANAGER_PORT = 10002
URI_DEFAULT_PORT = 10000
cvar = <Swig global variables>