- Aborted(String) - Static method in class org.apache.kudu.client.Status
-
- Aborted(String, int) - Static method in class org.apache.kudu.client.Status
-
- abortTask(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputCommitter
-
- AbstractKuduScannerBuilder<S extends AbstractKuduScannerBuilder<? super S,T>,T> - Class in org.apache.kudu.client
-
Abstract class to extend in order to create builders for scanners.
- addBinary(int, byte[]) - Method in class org.apache.kudu.client.PartialRow
-
Add binary data with the specified value.
- addBinary(int, ByteBuffer) - Method in class org.apache.kudu.client.PartialRow
-
Add binary data with the specified value, from the current ByteBuffer's position to its limit.
- addBinary(String, byte[]) - Method in class org.apache.kudu.client.PartialRow
-
Add binary data with the specified value.
- addBinary(String, ByteBuffer) - Method in class org.apache.kudu.client.PartialRow
-
Add binary data with the specified value, from the current ByteBuffer's position to its limit.
- addBoolean(int, boolean) - Method in class org.apache.kudu.client.PartialRow
-
Add a boolean for the specified column.
- addBoolean(String, boolean) - Method in class org.apache.kudu.client.PartialRow
-
Add a boolean for the specified column.
- addByte(int, byte) - Method in class org.apache.kudu.client.PartialRow
-
Add a byte for the specified column.
- addByte(String, byte) - Method in class org.apache.kudu.client.PartialRow
-
Add a byte for the specified column.
- addColumn(ColumnSchema) - Method in class org.apache.kudu.client.AlterTableOptions
-
Add a new column.
- addColumn(String, Type, Object) - Method in class org.apache.kudu.client.AlterTableOptions
-
Add a new column that's not nullable.
- addColumnRangePredicate(ColumnRangePredicate) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
- addColumnRangePredicatesRaw(byte[]) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
- addCredentialsToJob(KuduClient, Job) - Static method in class org.apache.kudu.mapreduce.KuduTableMapReduceUtil
-
Export the credentials from a
KuduClient
and store them in the given MapReduce
Job
so that
KuduClient
s created from within tasks of that job can
authenticate to Kudu.
- addDependencyJars(Job) - Static method in class org.apache.kudu.mapreduce.KuduTableMapReduceUtil
-
Add the Kudu dependency jars as well as jars for any of the configured
job classes to the job configuration, so that JobClient will ship them
to the cluster and add them to the DistributedCache.
- addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.kudu.mapreduce.KuduTableMapReduceUtil
-
Add the jars containing the given classes to the job's configuration
such that JobClient will ship them to the cluster and add them to
the DistributedCache.
- addDouble(int, double) - Method in class org.apache.kudu.client.PartialRow
-
Add an double for the specified column.
- addDouble(String, double) - Method in class org.apache.kudu.client.PartialRow
-
Add an double for the specified column.
- addFloat(int, float) - Method in class org.apache.kudu.client.PartialRow
-
Add an float for the specified column.
- addFloat(String, float) - Method in class org.apache.kudu.client.PartialRow
-
Add an float for the specified column.
- addHashPartitions(List<String>, int) - Method in class org.apache.kudu.client.CreateTableOptions
-
Add a set of hash partitions to the table.
- addHashPartitions(List<String>, int, int) - Method in class org.apache.kudu.client.CreateTableOptions
-
Add a set of hash partitions to the table.
- addInt(int, int) - Method in class org.apache.kudu.client.PartialRow
-
Add an int for the specified column.
- addInt(String, int) - Method in class org.apache.kudu.client.PartialRow
-
Add an int for the specified column.
- addKuduDependencyJars(Configuration) - Static method in class org.apache.kudu.mapreduce.KuduTableMapReduceUtil
-
Add Kudu and its dependencies (only) to the job configuration.
- addLong(int, long) - Method in class org.apache.kudu.client.PartialRow
-
Add an long for the specified column.
- addLong(String, long) - Method in class org.apache.kudu.client.PartialRow
-
Add an long for the specified column.
- addNullableColumn(String, Type) - Method in class org.apache.kudu.client.AlterTableOptions
-
Add a new column that's nullable and has no default value.
- addNullableColumn(String, Type, Object) - Method in class org.apache.kudu.client.AlterTableOptions
-
Add a new column that's nullable.
- addPredicate(KuduPredicate) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
Adds a predicate to the scan.
- addRangePartition(PartialRow, PartialRow) - Method in class org.apache.kudu.client.AlterTableOptions
-
Add a range partition to the table with an inclusive lower bound and an exclusive upper bound.
- addRangePartition(PartialRow, PartialRow, RangePartitionBound, RangePartitionBound) - Method in class org.apache.kudu.client.AlterTableOptions
-
Add a range partition to the table with a lower bound and upper bound.
- addRangePartition(PartialRow, PartialRow) - Method in class org.apache.kudu.client.CreateTableOptions
-
Add a range partition partition to the table with an inclusive lower bound
and an exclusive upper bound.
- addRangePartition(PartialRow, PartialRow, RangePartitionBound, RangePartitionBound) - Method in class org.apache.kudu.client.CreateTableOptions
-
Add a range partition partition to the table with a lower bound and upper
bound.
- addShort(int, short) - Method in class org.apache.kudu.client.PartialRow
-
Add a short for the specified column.
- addShort(String, short) - Method in class org.apache.kudu.client.PartialRow
-
Add a short for the specified column.
- addSplitRow(PartialRow) - Method in class org.apache.kudu.client.CreateTableOptions
-
Add a range partition split.
- addString(int, String) - Method in class org.apache.kudu.client.PartialRow
-
Add a String for the specified column.
- addString(String, String) - Method in class org.apache.kudu.client.PartialRow
-
Add a String for the specified column.
- addStringUtf8(int, byte[]) - Method in class org.apache.kudu.client.PartialRow
-
Add a String for the specified value, encoded as UTF8.
- addStringUtf8(String, byte[]) - Method in class org.apache.kudu.client.PartialRow
-
Add a String for the specified value, encoded as UTF8.
- ADMIN_OPERATION_TIMEOUT_MS_KEY - Static variable in class org.apache.kudu.mapreduce.CommandLineParser
-
- AlreadyPresent(String) - Static method in class org.apache.kudu.client.Status
-
- AlreadyPresent(String, int) - Static method in class org.apache.kudu.client.Status
-
- alterTable(String, AlterTableOptions) - Method in class org.apache.kudu.client.AsyncKuduClient
-
Alter a table on the cluster as specified by the builder.
- alterTable(String, AlterTableOptions) - Method in class org.apache.kudu.client.KuduClient
-
Alter a table on the cluster as specified by the builder.
- AlterTableOptions - Class in org.apache.kudu.client
-
This builder must be used to alter a table.
- AlterTableOptions() - Constructor for class org.apache.kudu.client.AlterTableOptions
-
- AlterTableResponse - Class in org.apache.kudu.client
-
- apply(Operation) - Method in class org.apache.kudu.client.AsyncKuduSession
-
Apply the given operation.
- apply(Operation) - Method in class org.apache.kudu.client.KuduSession
-
Apply a given
Operation
to Kudu as part of this session.
- asyncGetTabletsLocations(long) - Method in class org.apache.kudu.client.KuduTable
-
- asyncGetTabletsLocations(byte[], byte[], long) - Method in class org.apache.kudu.client.KuduTable
-
- AsyncKuduClient - Class in org.apache.kudu.client
-
A fully asynchronous and thread-safe client for Kudu.
- AsyncKuduClient.AsyncKuduClientBuilder - Class in org.apache.kudu.client
-
Builder class to use in order to connect to Kudu.
- AsyncKuduClientBuilder(String) - Constructor for class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
-
Creates a new builder for a client that will connect to the specified masters.
- AsyncKuduClientBuilder(List<String>) - Constructor for class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
-
Creates a new builder for a client that will connect to the specified masters.
- AsyncKuduScanner - Class in org.apache.kudu.client
-
Creates a scanner to read data from Kudu.
- AsyncKuduScanner.AsyncKuduScannerBuilder - Class in org.apache.kudu.client
-
- AsyncKuduScanner.ReadMode - Enum in org.apache.kudu.client
-
The possible read modes for scanners.
- AsyncKuduSession - Class in org.apache.kudu.client
-
An
AsyncKuduSession
belongs to a specific
AsyncKuduClient
, and represents a
context in which all write data access should take place.
- AvroKuduOperationsProducer - Class in org.apache.kudu.flume.sink
-
An Avro serializer that generates one operation per event by deserializing the event
body as an Avro record and mapping its fields to columns in a Kudu table.
- AvroKuduOperationsProducer() - Constructor for class org.apache.kudu.flume.sink.AvroKuduOperationsProducer
-
- getAdminOperationTimeoutMs() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get the configured timeout for admin operations.
- getAsyncClient() - Method in class org.apache.kudu.client.KuduTable
-
Get the async client that created this instance.
- getAsyncClient() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get an async client connected to the configured Master(s).
- getBatchSizeBytes() - Method in class org.apache.kudu.client.AsyncKuduScanner
-
Returns the maximum number of bytes returned by the scanner, on each batch.
- getBatchSizeBytes() - Method in class org.apache.kudu.client.KuduScanner
-
Returns the maximum number of bytes returned by the scanner, on each batch.
- getBinary(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's binary data.
- getBinary(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's binary data.
- getBinaryCopy(String) - Method in class org.apache.kudu.client.RowResult
-
Get a copy of the specified column's binary data.
- getBinaryCopy(int) - Method in class org.apache.kudu.client.RowResult
-
Get a copy of the specified column's binary data.
- getBoolean(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's boolean
- getBoolean(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's boolean
- getByte(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's byte
- getByte(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's byte
- getCacheBlocks() - Method in class org.apache.kudu.client.AsyncKuduScanner
-
Returns if this scanner was configured to cache data blocks or not.
- getCacheBlocks() - Method in class org.apache.kudu.client.KuduScanner
-
Returns if this scanner was configured to cache data blocks or not.
- getClient() - Method in class org.apache.kudu.flume.sink.KuduSink
-
- getClient() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get a client connected to the configured Master(s).
- getClientStatistic(Statistics.Statistic) - Method in class org.apache.kudu.client.Statistics
-
Get the statistic count of the whole client.
- getColumn() - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Get the column used by this predicate
- getColumn(String) - Method in class org.apache.kudu.Schema
-
Get the column associated with the specified name
- getColumnByIndex(int) - Method in class org.apache.kudu.Schema
-
Get the column at the specified index in the original list
- getColumnCount() - Method in class org.apache.kudu.Schema
-
Get the count of columns in this schema
- getColumnIndex(String) - Method in class org.apache.kudu.Schema
-
Get the index for the provided column name.
- getColumnIndex(int) - Method in class org.apache.kudu.Schema
-
Get the column index of the column with the provided ID.
- getColumnOffset(int) - Method in class org.apache.kudu.Schema
-
Get the index at which this column can be found in the backing byte array
- getColumnProjection() - Method in class org.apache.kudu.client.RowResult
-
Get the schema used for this scanner's column projection.
- getColumns() - Method in class org.apache.kudu.Schema
-
Get the list of columns used to create this schema
- getColumnType(String) - Method in class org.apache.kudu.client.RowResult
-
Get the type of a column in this result.
- getColumnType(int) - Method in class org.apache.kudu.client.RowResult
-
Get the type of a column in this result.
- getCompressionAlgorithm() - Method in class org.apache.kudu.ColumnSchema
-
Return the compression algorithm of this column, or null if it is not known.
- getConf() - Method in class org.apache.kudu.mapreduce.KuduTableInputFormat
-
- getConf() - Method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
-
- getDataType() - Method in enum org.apache.kudu.Type
-
Get the data type from the common's pb
- getDefaultAdminOperationTimeoutMs() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Get the timeout used for admin operations.
- getDefaultAdminOperationTimeoutMs() - Method in class org.apache.kudu.client.KuduClient
-
Get the timeout used for admin operations.
- getDefaultOperationTimeoutMs() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Get the timeout used for operations on sessions and scanners.
- getDefaultOperationTimeoutMs() - Method in class org.apache.kudu.client.KuduClient
-
Get the timeout used for operations on sessions and scanners.
- getDefaultSocketReadTimeoutMs() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Get the timeout used when waiting to read data from a socket.
- getDefaultValue() - Method in class org.apache.kudu.ColumnSchema
-
The Java object representation of the default value that's read
- getDeferred() - Method in exception org.apache.kudu.client.PleaseThrottleException
-
Returns a deferred one can wait on before retrying the failed RPC.
- getDesiredBlockSize() - Method in class org.apache.kudu.ColumnSchema
-
Gets the desired block size for this column.
- getDouble(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's double
- getDouble(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's double
- getEncoding() - Method in class org.apache.kudu.ColumnSchema
-
Return the encoding of this column, or null if it is not known.
- getEndKey() - Method in class org.apache.kudu.client.LocatedTablet
-
Deprecated.
- getErrorStatus() - Method in class org.apache.kudu.client.RowError
-
Get the status code and message of the row error.
- getFailedRpc() - Method in interface org.apache.kudu.client.HasFailedRpcException
-
Returns the RPC that caused this exception.
- getFailedRpc() - Method in exception org.apache.kudu.client.PleaseThrottleException
-
The RPC that was made to fail with this exception.
- getFloat(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's float
- getFloat(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's float
- getFlushMode() - Method in class org.apache.kudu.client.AsyncKuduSession
-
- getFlushMode() - Method in class org.apache.kudu.client.KuduSession
-
- getFlushMode() - Method in interface org.apache.kudu.client.SessionConfiguration
-
Get the current flush mode.
- getFormattedRangePartitions(long) - Method in class org.apache.kudu.client.KuduTable
-
Retrieves a formatted representation of this table's range partitions.
- getHelpSnippet() - Static method in class org.apache.kudu.mapreduce.CommandLineParser
-
This method returns a single multi-line string that contains the help snippet to append to
the tail of a usage() or help() type of method.
- getInt(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's integer
- getInt(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's integer
- getKuduTable(String) - Static method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
-
- getLastPropagatedTimestamp() - Method in class org.apache.kudu.client.AsyncKuduClient
-
- getLeaderReplica() - Method in class org.apache.kudu.client.LocatedTablet
-
Return the current leader, or null if there is none.
- getLimit() - Method in class org.apache.kudu.client.AsyncKuduScanner
-
Returns the maximum number of rows that this scanner was configured to return.
- getLimit() - Method in class org.apache.kudu.client.KuduScanner
-
Returns the maximum number of rows that this scanner was configured to return.
- getLong(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's long
If this is a UNIXTIME_MICROS column, the long value corresponds to a number of microseconds
since midnight, January 1, 1970 UTC.
- getLong(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's long
If this is a UNIXTIME_MICROS column, the long value corresponds to a number of microseconds
since midnight, January 1, 1970 UTC.
- getLowerBound() - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Get the lower bound in its raw representation
- getMasterAddresses() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get the configured master's config.
- getMasterAddressesAsString() - Method in class org.apache.kudu.client.AsyncKuduClient
-
- getMasterAddressesAsString() - Method in class org.apache.kudu.client.KuduClient
-
- getMessage() - Method in class org.apache.kudu.client.RowError
-
- getName() - Method in class org.apache.kudu.client.KuduTable
-
Get this table's name.
- getName() - Method in class org.apache.kudu.ColumnSchema
-
Get the column's name
- getName() - Method in enum org.apache.kudu.Type
-
Get the string representation of this type
- getNumReplicas() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get the number of replicas to use when configuring a new table.
- getNumRows() - Method in class org.apache.kudu.client.RowResultIterator
-
Get the number of rows in this iterator.
- getOperation() - Method in class org.apache.kudu.client.RowError
-
Get the Operation that failed.
- getOperations(Event) - Method in class org.apache.kudu.flume.sink.AvroKuduOperationsProducer
-
- getOperations(Event) - Method in interface org.apache.kudu.flume.sink.KuduOperationsProducer
-
Returns the operations that should be written to Kudu as a result of this event.
- getOperations(Event) - Method in class org.apache.kudu.flume.sink.RegexpKuduOperationsProducer
-
- getOperations(Event) - Method in class org.apache.kudu.flume.sink.SimpleKeyedKuduOperationsProducer
-
- getOperations(Event) - Method in class org.apache.kudu.flume.sink.SimpleKuduOperationsProducer
-
- getOperationTimeoutMs() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get the configured timeout for operations on sessions and scanners.
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
-
- getPartition() - Method in class org.apache.kudu.client.LocatedTablet
-
- getPartitionSchema() - Method in class org.apache.kudu.client.KuduTable
-
Gets the table's partition schema.
- getPendingErrors() - Method in class org.apache.kudu.client.AsyncKuduSession
-
- getPendingErrors() - Method in class org.apache.kudu.client.KuduSession
-
- getPendingErrors() - Method in interface org.apache.kudu.client.SessionConfiguration
-
Return any errors from previous calls.
- getPosixCode() - Method in class org.apache.kudu.client.Status
-
Get the posix code associated with the error.
- getPrimaryKeyColumnCount() - Method in class org.apache.kudu.Schema
-
Get the count of columns that are part of the primary key.
- getPrimaryKeyColumns() - Method in class org.apache.kudu.Schema
-
Get the primary key columns.
- getProjectionSchema() - Method in class org.apache.kudu.client.AsyncKuduScanner
-
Returns the projection schema of this scanner.
- getProjectionSchema() - Method in class org.apache.kudu.client.KuduScanner
-
Returns the projection schema of this scanner.
- getReadMode() - Method in class org.apache.kudu.client.AsyncKuduScanner
-
Returns the ReadMode for this scanner.
- getReadMode() - Method in class org.apache.kudu.client.KuduScanner
-
Returns the ReadMode for this scanner.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
-
- getReplicas() - Method in class org.apache.kudu.client.LocatedTablet
-
- getRole() - Method in class org.apache.kudu.client.LocatedTablet.Replica
-
- getRow() - Method in class org.apache.kudu.client.Operation
-
Get the underlying row to modify.
- getRowError() - Method in class org.apache.kudu.client.OperationResponse
-
Returns a row error.
- getRowErrors() - Method in class org.apache.kudu.client.RowErrorsAndOverflowStatus
-
Get the collected row errors.
- getRowKeyProjection() - Method in class org.apache.kudu.Schema
-
Get a schema that only contains the columns which are part of the key
- getRowSize() - Method in class org.apache.kudu.Schema
-
Get the size a row built using this schema would be
- getRpcHost() - Method in class org.apache.kudu.client.LocatedTablet.Replica
-
- getRpcPort() - Method in class org.apache.kudu.client.LocatedTablet.Replica
-
- getSchema() - Method in class org.apache.kudu.client.KuduTable
-
Get this table's schema, as of the moment this instance was created.
- getSchema() - Method in class org.apache.kudu.client.RowResult
-
Get the schema associated with this result.
- getShort(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's short
- getShort(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's short
- getSize() - Method in enum org.apache.kudu.Type
-
The size of this type on the wire
- getSocketReadTimeoutMs() - Method in class org.apache.kudu.mapreduce.CommandLineParser
-
Get the configured timeout for socket reads.
- getSplits(JobContext) - Method in class org.apache.kudu.mapreduce.KuduTableInputFormat
-
- getStartKey() - Method in class org.apache.kudu.client.LocatedTablet
-
Deprecated.
- getStatistics() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Get the statistics object of this client.
- getStatistics() - Method in class org.apache.kudu.client.KuduClient
-
Get the statistics object of this client.
- getStatus() - Method in exception org.apache.kudu.client.KuduException
-
Get the Status object for this exception.
- getStatus() - Method in class org.apache.kudu.client.RowError
-
- getString(String) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's string.
- getString(int) - Method in class org.apache.kudu.client.RowResult
-
Get the specified column's string.
- getTableFromContext(TaskInputOutputContext) - Static method in class org.apache.kudu.mapreduce.KuduTableMapReduceUtil
-
Use this method when setting up a task to get access to the KuduTable in order to create
Inserts, Updates, and Deletes.
- getTableId() - Method in class org.apache.kudu.client.AlterTableResponse
-
- getTableId() - Method in class org.apache.kudu.client.KuduTable
-
Get this table's unique identifier.
- getTableName(String) - Method in class org.apache.kudu.client.Statistics
-
Get table name of the given tablet id.
- getTableSet() - Method in class org.apache.kudu.client.Statistics
-
Get the set of tables which have been written into by this client,
which have statistics information.
- getTablesList() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Get the list of all the tables.
- getTablesList(String) - Method in class org.apache.kudu.client.AsyncKuduClient
-
Get a list of table names.
- getTablesList() - Method in class org.apache.kudu.client.KuduClient
-
Get the list of all the tables.
- getTablesList(String) - Method in class org.apache.kudu.client.KuduClient
-
Get a list of table names.
- getTablesList() - Method in class org.apache.kudu.client.ListTablesResponse
-
Get the list of tables as specified in the request.
- getTableStatistic(String, Statistics.Statistic) - Method in class org.apache.kudu.client.Statistics
-
Get the statistic count of this table.
- getTablet() - Method in class org.apache.kudu.client.KuduScanToken
-
Returns the tablet which the scanner created from this token will access.
- getTabletId() - Method in class org.apache.kudu.client.LocatedTablet
-
- getTabletServersCount() - Method in class org.apache.kudu.client.ListTabletServersResponse
-
Get the count of tablet servers as reported by the master.
- getTabletServersList() - Method in class org.apache.kudu.client.ListTabletServersResponse
-
Get the list of tablet servers, as represented by their hostname.
- getTabletSet() - Method in class org.apache.kudu.client.Statistics
-
Get the set of tablets which have been written into by this client,
which have statistics information.
- getTabletsLocations(long) - Method in class org.apache.kudu.client.KuduTable
-
- getTabletsLocations(byte[], byte[], long) - Method in class org.apache.kudu.client.KuduTable
-
- getTabletStatistic(String, Statistics.Statistic) - Method in class org.apache.kudu.client.Statistics
-
Get the statistic count of this tablet.
- getTimeoutMillis() - Method in class org.apache.kudu.client.AsyncKuduSession
-
- getTimeoutMillis() - Method in class org.apache.kudu.client.KuduSession
-
- getTimeoutMillis() - Method in interface org.apache.kudu.client.SessionConfiguration
-
Get the current timeout.
- getTsUUID() - Method in class org.apache.kudu.client.RowError
-
Get the identifier of the tablet server that sent the error.
- getType() - Method in class org.apache.kudu.ColumnSchema
-
Get the column's Type
- getTypeForDataType(Common.DataType) - Static method in enum org.apache.kudu.Type
-
Convert the pb DataType to a Type
- getUpperBound() - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Get the upper bound in its raw representation
- getVarLengthColumnCount() - Method in class org.apache.kudu.Schema
-
Get the count of columns with variable length (BINARY/STRING) in
this schema.
- getWriteTimestampRaw() - Method in class org.apache.kudu.client.OperationResponse
-
Gives the write timestamp that was returned by the Tablet Server.
- scanRequestTimeout(long) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
Sets how long each scan request to a server can last.
- Schema - Class in org.apache.kudu
-
Represents table's schema which is essentially a list of columns.
- Schema(List<ColumnSchema>) - Constructor for class org.apache.kudu.Schema
-
Constructs a schema using the specified columns and does some internal accounting
- Schema(List<ColumnSchema>, List<Integer>) - Constructor for class org.apache.kudu.Schema
-
Constructs a schema using the specified columns and IDs.
- SCHEMA_LITERAL_HEADER - Static variable in class org.apache.kudu.flume.sink.AvroKuduOperationsProducer
-
- SCHEMA_PROP - Static variable in class org.apache.kudu.flume.sink.AvroKuduOperationsProducer
-
- SCHEMA_URL_HEADER - Static variable in class org.apache.kudu.flume.sink.AvroKuduOperationsProducer
-
- serialize() - Method in class org.apache.kudu.client.KuduScanToken
-
Serializes this KuduScanToken
into a byte array.
- ServiceUnavailable(String) - Static method in class org.apache.kudu.client.Status
-
- ServiceUnavailable(String, int) - Static method in class org.apache.kudu.client.Status
-
- SessionConfiguration - Interface in org.apache.kudu.client
-
Interface that defines the methods used to configure a session.
- SessionConfiguration.FlushMode - Enum in org.apache.kudu.client
-
- setConf(Configuration) - Method in class org.apache.kudu.mapreduce.KuduTableInputFormat
-
- setConf(Configuration) - Method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
-
- setExternalConsistencyMode(ExternalConsistencyMode) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setExternalConsistencyMode(ExternalConsistencyMode) - Method in class org.apache.kudu.client.KuduSession
-
- setExternalConsistencyMode(ExternalConsistencyMode) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Set the new external consistency mode for this session.
- setFlushInterval(int) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setFlushInterval(int) - Method in class org.apache.kudu.client.KuduSession
-
- setFlushInterval(int) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Set the flush interval, which will be used for the next scheduling decision.
- setFlushMode(SessionConfiguration.FlushMode) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setFlushMode(SessionConfiguration.FlushMode) - Method in class org.apache.kudu.client.KuduSession
-
- setFlushMode(SessionConfiguration.FlushMode) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Set the new flush mode for this session.
- setIgnoreAllDuplicateRows(boolean) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setIgnoreAllDuplicateRows(boolean) - Method in class org.apache.kudu.client.KuduSession
-
- setIgnoreAllDuplicateRows(boolean) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Configures the option to ignore all the row errors if they are all of the AlreadyPresent type.
- setLowerBound(boolean) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a boolean for the lower bound
- setLowerBound(byte) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a byte for the lower bound
- setLowerBound(short) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a short for the lower bound
- setLowerBound(int) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set an int for the lower bound
- setLowerBound(long) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
- setLowerBound(String) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a string for the lower bound
- setLowerBound(byte[]) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a binary value for the lower bound
- setLowerBound(float) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a float for the lower bound
- setLowerBound(double) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a double for the lower bound
- setMutationBufferLowWatermark(float) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setMutationBufferLowWatermark(float) - Method in class org.apache.kudu.client.KuduSession
-
- setMutationBufferLowWatermark(float) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Set the low watermark for this session.
- setMutationBufferSpace(int) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setMutationBufferSpace(int) - Method in class org.apache.kudu.client.KuduSession
-
- setMutationBufferSpace(int) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Set the number of operations that can be buffered.
- setNull(int) - Method in class org.apache.kudu.client.PartialRow
-
Set the specified column to null
- setNull(String) - Method in class org.apache.kudu.client.PartialRow
-
Set the specified column to null
- setNumReplicas(int) - Method in class org.apache.kudu.client.CreateTableOptions
-
Sets the number of replicas that each tablet will have.
- setProjectedColumnIndexes(List<Integer>) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
Set which columns will be read by the Scanner.
- setProjectedColumnNames(List<String>) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
Set which columns will be read by the Scanner.
- setRangePartitionColumns(List<String>) - Method in class org.apache.kudu.client.CreateTableOptions
-
Set the columns on which the table will be range-partitioned.
- setTimeout(long) - Method in class org.apache.kudu.client.KuduScanToken.KuduScanTokenBuilder
-
Sets a timeout value to use when building the list of scan tokens.
- setTimeoutMillis(long) - Method in class org.apache.kudu.client.AsyncKuduSession
-
- setTimeoutMillis(long) - Method in class org.apache.kudu.client.KuduSession
-
- setTimeoutMillis(long) - Method in interface org.apache.kudu.client.SessionConfiguration
-
Sets the timeout for the next applied operations.
- setupJob(JobContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputCommitter
-
- setUpperBound(boolean) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a boolean for the upper bound
- setUpperBound(byte) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a byte for the upper bound
- setUpperBound(short) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a short for the upper bound
- setUpperBound(int) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set an int for the upper bound
- setUpperBound(long) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
- setUpperBound(String) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a string for the upper bound
- setUpperBound(byte[]) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a binary value for the upper bound
- setUpperBound(float) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a float for the upper bound
- setUpperBound(double) - Method in class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
Set a double for the upper bound
- setupTask(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputCommitter
-
- shutdown() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Performs a graceful shutdown of this instance.
- shutdown() - Method in class org.apache.kudu.client.KuduClient
-
Performs a graceful shutdown of this instance.
- SimpleKeyedKuduOperationsProducer - Class in org.apache.kudu.flume.sink
-
A simple serializer that generates one
Insert
or
Upsert
per
Event
by writing the event body into a BINARY column.
- SimpleKeyedKuduOperationsProducer() - Constructor for class org.apache.kudu.flume.sink.SimpleKeyedKuduOperationsProducer
-
- SimpleKuduOperationsProducer - Class in org.apache.kudu.flume.sink
-
A simple serializer that generates one
Insert
per
Event
by writing the event body into a BINARY column.
- SimpleKuduOperationsProducer() - Constructor for class org.apache.kudu.flume.sink.SimpleKuduOperationsProducer
-
- SKIP_BAD_COLUMN_VALUE_PROP - Static variable in class org.apache.kudu.flume.sink.RegexpKuduOperationsProducer
-
- SKIP_MISSING_COLUMN_PROP - Static variable in class org.apache.kudu.flume.sink.RegexpKuduOperationsProducer
-
- SLEEP_TIME - Static variable in class org.apache.kudu.client.AsyncKuduClient
-
- snapshotTimestampMicros(long) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
Sets the timestamp the scan must be executed at, in microseconds since the Unix epoch.
- snapshotTimestampRaw(long) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
Sets a previously encoded HT timestamp as a snapshot timestamp, for tests.
- SOCKET_READ_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.kudu.mapreduce.CommandLineParser
-
- SOCKET_READ_TIMEOUT_MS_KEY - Static variable in class org.apache.kudu.mapreduce.CommandLineParser
-
- start() - Method in class org.apache.kudu.flume.sink.KuduSink
-
- Statistics - Class in org.apache.kudu.client
-
A Statistics belongs to a specific AsyncKuduClient.
- Statistics() - Constructor for class org.apache.kudu.client.Statistics
-
- Statistics.Statistic - Enum in org.apache.kudu.client
-
The statistic enum to pass when querying.
- Status - Class in org.apache.kudu.client
-
Representation of an error code and message.
- stop() - Method in class org.apache.kudu.flume.sink.KuduSink
-
- stringifyRowKey() - Method in class org.apache.kudu.client.PartialRow
-
Transforms the row key into a string representation where each column is in the format:
"type col_name=value".
- stringifySerializedToken(byte[], KuduClient) - Static method in class org.apache.kudu.client.KuduScanToken
-
Formats the serialized token for debug printing.
- syncClient() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Returns a synchronous
KuduClient
which wraps this asynchronous client.