Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id 08A13200B9F for ; Tue, 11 Oct 2016 23:33:55 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 071CA160AC3; Tue, 11 Oct 2016 21:33:55 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 79EE1160AF7 for ; Tue, 11 Oct 2016 23:33:49 +0200 (CEST) Received: (qmail 15241 invoked by uid 500); 11 Oct 2016 21:33:48 -0000 Mailing-List: contact commits-help@kudu.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@kudu.apache.org Delivered-To: mailing list commits@kudu.apache.org Received: (qmail 14714 invoked by uid 99); 11 Oct 2016 21:33:47 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Tue, 11 Oct 2016 21:33:47 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id BB5F5E0999; Tue, 11 Oct 2016 21:33:47 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: danburkert@apache.org To: commits@kudu.apache.org Date: Tue, 11 Oct 2016 21:34:34 -0000 Message-Id: <87f80e7636fa40aaaa2bdea823181772@git.apache.org> In-Reply-To: <3ead1f1bf9ed4a93b8b95585c75a0d50@git.apache.org> References: <3ead1f1bf9ed4a93b8b95585c75a0d50@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [49/51] [partial] kudu-site git commit: Publish commit(s) from site source repo: 76a99b4 Update docs from branch-1.0.x archived-at: Tue, 11 Oct 2016 21:33:55 -0000 http://git-wip-us.apache.org/repos/asf/kudu-site/blob/20adff6a/apidocs/index-all.html ---------------------------------------------------------------------- diff --git a/apidocs/index-all.html b/apidocs/index-all.html index 2ca0a83..10c75d0 100644 --- a/apidocs/index-all.html +++ b/apidocs/index-all.html @@ -2,20 +2,14 @@ - - -Index (Kudu 1.0.0 API) - - + +Index (Kudu 1.0.1 API) + @@ -23,22 +17,20 @@
JavaScript is disabled on your browser.
-
+ -
A B C D E F G H I K L M N O P R S T U V W  +
A B C D E F G H I K L M N O P R S T U V W 

A

-
Aborted(String) - Static method in class org.apache.kudu.client.Status
+
Aborted(String) - Static method in class org.apache.kudu.client.Status
 
-
Aborted(String, int) - 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
+
abortTask(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputCommitter
 
-
AbstractKuduScannerBuilder<S extends AbstractKuduScannerBuilder<? super S,T>,T> - Class in org.apache.kudu.client
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
addByte(String, byte) - Method in class org.apache.kudu.client.PartialRow
Add a byte for the specified column.
-
addColumn(String, Type, Object) - Method in class org.apache.kudu.client.AlterTableOptions
+
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
+
addColumnRangePredicate(ColumnRangePredicate) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
-
addColumnRangePredicatesRaw(byte[]) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
+
addColumnRangePredicatesRaw(byte[]) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
-
-
addDependencyJars(Job) - Static method in class org.apache.kudu.mapreduce.KuduTableMapReduceUtil
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
addNullableColumn(String, Type) - Method in class org.apache.kudu.client.AlterTableOptions
Add a new column that's nullable, thus has no default value.
-
addPredicate(KuduPredicate) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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
+
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) - Static method in class org.apache.kudu.client.Status
 
-
AlreadyPresent(String, int) - 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
+
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
+
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
+
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
+
AlterTableOptions() - Constructor for class org.apache.kudu.client.AlterTableOptions
 
-
AlterTableResponse - Class in org.apache.kudu.client
+
AlterTableResponse - Class in org.apache.kudu.client
 
-
apply(Operation) - Method in class org.apache.kudu.client.AsyncKuduSession
+
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(Operation) - Method in class org.apache.kudu.client.KuduSession
Blocking call with a different behavior based on the flush mode.
-
asyncGetTabletsLocations(long) - Method in class org.apache.kudu.client.KuduTable
+
asyncGetTabletsLocations(long) - Method in class org.apache.kudu.client.KuduTable
-
Deprecated. -
use the KuduScanToken API
+
Deprecated. +
use the KuduScanToken API
-
asyncGetTabletsLocations(byte[], byte[], long) - Method in class org.apache.kudu.client.KuduTable
+
asyncGetTabletsLocations(byte[], byte[], long) - Method in class org.apache.kudu.client.KuduTable
-
Deprecated. -
use the KuduScanToken API
+
Deprecated. +
use the KuduScanToken API
-
AsyncKuduClient - Class in org.apache.kudu.client
+
AsyncKuduClient - Class in org.apache.kudu.client
A fully asynchronous and thread-safe client for Kudu.
-
AsyncKuduClient.AsyncKuduClientBuilder - Class in org.apache.kudu.client
+
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
+
AsyncKuduClient.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
+
AsyncKuduClient.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
+
AsyncKuduScanner - Class in org.apache.kudu.client
Creates a scanner to read data from Kudu.
-
AsyncKuduScanner.AsyncKuduScannerBuilder - Class in org.apache.kudu.client
+
AsyncKuduScanner.AsyncKuduScannerBuilder - Class in org.apache.kudu.client
-
A Builder class to build AsyncKuduScanner.
+
A Builder class to build AsyncKuduScanner.
-
AsyncKuduScanner.ReadMode - Enum 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
+
AsyncKuduSession - Class in org.apache.kudu.client
A AsyncKuduSession belongs to a specific AsyncKuduClient, and represents a context in which all read/write data access should take place.
- +

B

-
BATCH_SIZE - Static variable in class org.apache.kudu.flume.sink.KuduSinkConfigurationConstants
+
BATCH_SIZE - Static variable in class org.apache.kudu.flume.sink.KuduSinkConfigurationConstants
Maximum number of events that the sink should take from the channel per transaction.
-
batchSizeBytes(int) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
+
batchSizeBytes(int) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
Sets the maximum number of bytes returned by the scanner, on each batch.
-
bossCount(int) - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
+
bossCount(int) - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
Set the maximum number of boss threads.
-
bossCount(int) - Method in class org.apache.kudu.client.KuduClient.KuduClientBuilder
+
bossCount(int) - Method in class org.apache.kudu.client.KuduClient.KuduClientBuilder
Set the maximum number of boss threads.
-
build() - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
+
build() - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
 
-
build() - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
+
build() - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
Creates a new client that connects to the masters.
-
build() - Method in class org.apache.kudu.client.AsyncKuduScanner.AsyncKuduScannerBuilder
+
build() - Method in class org.apache.kudu.client.AsyncKuduScanner.AsyncKuduScannerBuilder
-
Builds an AsyncKuduScanner using the passed configurations.
+
Builds an AsyncKuduScanner using the passed configurations.
-
build() - Method in class org.apache.kudu.client.KuduClient.KuduClientBuilder
+
build() - Method in class org.apache.kudu.client.KuduClient.KuduClientBuilder
Creates a new client that connects to the masters.
-
build() - Method in class org.apache.kudu.client.KuduScanner.KuduScannerBuilder
+
build() - Method in class org.apache.kudu.client.KuduScanner.KuduScannerBuilder
-
Builds a KuduScanner using the passed configurations.
+
Builds a KuduScanner using the passed configurations.
-
build() - Method in class org.apache.kudu.client.KuduScanToken.KuduScanTokenBuilder
+
build() - Method in class org.apache.kudu.client.KuduScanToken.KuduScanTokenBuilder
 
- +

C

-
cacheBlocks(boolean) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
+
cacheBlocks(boolean) - Method in class org.apache.kudu.client.AbstractKuduScannerBuilder
Sets the block caching policy for the scanner.
-
checkOutputSpecs(JobContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
+
checkOutputSpecs(JobContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputFormat
 
-
close() - Method in class org.apache.kudu.client.AsyncKuduClient
+
close() - Method in class org.apache.kudu.client.AsyncKuduClient
-
Invokes AsyncKuduClient.shutdown() and waits for the configured admin timeout.
+
Invokes AsyncKuduClient.shutdown() and waits for the configured admin timeout.
-
close() - Method in class org.apache.kudu.client.AsyncKuduScanner
+
close() - Method in class org.apache.kudu.client.AsyncKuduScanner
Closes this scanner (don't forget to call this when you're done with it!).
-
close() - Method in class org.apache.kudu.client.AsyncKuduSession
+
close() - Method in class org.apache.kudu.client.AsyncKuduSession
Flushes the buffered operations and marks this session as closed.
-
close() - Method in class org.apache.kudu.client.KuduClient
+
close() - Method in class org.apache.kudu.client.KuduClient
-
Analogous to KuduClient.shutdown().
+
Analogous to KuduClient.shutdown().
-
close() - Method in class org.apache.kudu.client.KuduScanner
+
close() - Method in class org.apache.kudu.client.KuduScanner
Closes this scanner (don't forget to call this when you're done with it!).
-
close() - Method in class org.apache.kudu.client.KuduSession
+
close() - Method in class org.apache.kudu.client.KuduSession
-
Blocking call that flushes the buffers (see KuduSession.flush() and closes the sessions.
+
Blocking call that flushes the buffers (see KuduSession.flush() and closes the sessions.
-
close() - Method in interface org.apache.kudu.flume.sink.KuduOperationsProducer
+
close() - Method in interface org.apache.kudu.flume.sink.KuduOperationsProducer
Cleans up any state.
-
collectErrors(List<OperationResponse>) - Static method in class org.apache.kudu.client.OperationResponse
+
collectErrors(List<OperationResponse>) - Static method in class org.apache.kudu.client.OperationResponse
Utility method that collects all the row errors from the given list of responses.
-
ColumnRangePredicate - Class in org.apache.kudu.client
+
ColumnRangePredicate - Class in org.apache.kudu.client
-
Deprecated. -
use the KuduPredicate class instead.
+
Deprecated. +
use the KuduPredicate class instead.
-
ColumnRangePredicate(ColumnSchema) - Constructor for class org.apache.kudu.client.ColumnRangePredicate
+
ColumnRangePredicate(ColumnSchema) - Constructor for class org.apache.kudu.client.ColumnRangePredicate
-
Deprecated.
+
Deprecated.
Create the predicate on the specified column
-
ColumnSchema - Class in org.apache.kudu
+
ColumnSchema - Class in org.apache.kudu
Represents a Kudu Table column.
-
CommandLineParser - Class in org.apache.kudu.mapreduce
+
CommandLineParser - Class in org.apache.kudu.mapreduce
Utility class that manages common configurations to all MR jobs.
-
CommandLineParser(Configuration) - Constructor for class org.apache.kudu.mapreduce.CommandLineParser
+
CommandLineParser(Configuration) - Constructor for class org.apache.kudu.mapreduce.CommandLineParser
Constructor that uses a Configuration that has already been through GenericOptionsParser's command line parsing.
-
commitTask(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputCommitter
+
commitTask(TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableOutputCommitter
 
-
compareTo(KuduScanToken) - Method in class org.apache.kudu.client.KuduScanToken
+
compareTo(KuduScanToken) - Method in class org.apache.kudu.client.KuduScanToken
 
-
ConfigurationError(String) - Static method in class org.apache.kudu.client.Status
+
ConfigurationError(String) - Static method in class org.apache.kudu.client.Status
 
-
ConfigurationError(String, int) - Static method in class org.apache.kudu.client.Status
+
ConfigurationError(String, int) - Static method in class org.apache.kudu.client.Status
 
-
configure(Context) - Method in class org.apache.kudu.flume.sink.KuduSink
+
configure(Context) - Method in class org.apache.kudu.flume.sink.KuduSink
 
-
Corruption(String) - Static method in class org.apache.kudu.client.Status
+
Corruption(String) - Static method in class org.apache.kudu.client.Status
 
-
Corruption(String, int) - Static method in class org.apache.kudu.client.Status
+
Corruption(String, int) - Static method in class org.apache.kudu.client.Status
 
-
countPendingErrors() - Method in class org.apache.kudu.client.AsyncKuduSession
+
countPendingErrors() - Method in class org.apache.kudu.client.AsyncKuduSession
 
-
countPendingErrors() - Method in class org.apache.kudu.client.KuduSession
+
countPendingErrors() - Method in class org.apache.kudu.client.KuduSession
 
-
countPendingErrors() - Method in interface org.apache.kudu.client.SessionConfiguration
+
countPendingErrors() - Method in interface org.apache.kudu.client.SessionConfiguration
Return the number of errors which are pending.
-
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableInputFormat
+
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.kudu.mapreduce.KuduTableInputFormat
 
-
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.kudu.mapreduce.tools.ImportCsv
+
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.kudu.mapreduce.tools.ImportCsv
Sets up the actual job.
-
createTable(String, Schema, CreateTableOptions) - Method in class org.apache.kudu.client.AsyncKuduClient
+
createTable(String, Schema, CreateTableOptions) - Method in class org.apache.kudu.client.AsyncKuduClient
Create a table on the cluster with the specified name, schema, and table configurations.
-
createTable(String, Schema, CreateTableOptions) - Method in class org.apache.kudu.client.KuduClient
+
createTable(String, Schema, CreateTableOptions) - Method in class org.apache.kudu.client.KuduClient
Create a table on the cluster with the specified name, schema, and table configurations.
-
CreateTableOptions - Class in org.apache.kudu.client
+
CreateTableOptions - Class in org.apache.kudu.client
This is a builder class for all the options that can be provided while creating a table.
-
CreateTableOptions() - Constructor for class org.apache.kudu.client.CreateTableOptions
+
CreateTableOptions() - Constructor for class org.apache.kudu.client.CreateTableOptions
 
-
CsvParser - Class in org.apache.kudu.mapreduce.tools
+
CsvParser - Class in org.apache.kudu.mapreduce.tools
Column-separated values parser that gives access to the different columns inside each line of data.
-
CsvParser(String, String) - Constructor for class org.apache.kudu.mapreduce.tools.CsvParser
+
CsvParser(String, String) - Constructor for class org.apache.kudu.mapreduce.tools.CsvParser
 
- +

D

-
DEFAULT_OPERATION_TIMEOUT_MS - Static variable in class org.apache.kudu.client.AsyncKuduClient
+
DEFAULT_OPERATION_TIMEOUT_MS - Static variable in class org.apache.kudu.client.AsyncKuduClient
 
-
DEFAULT_SOCKET_READ_TIMEOUT_MS - Static variable in class org.apache.kudu.client.AsyncKuduClient
+
DEFAULT_SOCKET_READ_TIMEOUT_MS - Static variable in class org.apache.kudu.client.AsyncKuduClient
 
-
defaultAdminOperationTimeoutMs(long) - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
+
defaultAdminOperationTimeoutMs(long) - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
Sets the default timeout used for administrative operations (e.g.
-
defaultAdminOperationTimeoutMs(long) - Method in class org.apache.kudu.client.KuduClient.KuduClientBuilder
+
defaultAdminOperationTimeoutMs(long) - Method in class org.apache.kudu.client.KuduClient.KuduClientBuilder
Sets the default timeout used for administrative operations (e.g.
-
defaultOperationTimeoutMs(long) - Method in class org.apache.kudu.client.AsyncKuduClient.AsyncKuduClientBuilder
+
defaultOperationTimeoutMs(long) - Method in class org.apache.kudu.client.